You are viewing a plain text version of this content. The canonical link for it is here.
Posted to muse-commits@ws.apache.org by da...@apache.org on 2007/03/24 14:14:24 UTC

svn commit: r522019 [9/12] - in /webservices/muse/trunk/modules: muse-tools/src/org/apache/muse/tools/generator/ muse-tools/src/org/apache/muse/tools/generator/analyzer/ muse-tools/src/org/apache/muse/tools/generator/projectizer/ muse-tools/src/org/apa...

Modified: webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/generator/util/SimpleLogFormatter.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/generator/util/SimpleLogFormatter.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/generator/util/SimpleLogFormatter.java (original)
+++ webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/generator/util/SimpleLogFormatter.java Sat Mar 24 06:14:20 2007
@@ -1,66 +1,70 @@
-/*=============================================================================*
- *  Copyright 2006 The Apache Software Foundation
- *
- *  Licensed under the Apache License, Version 2.0 (the "License");
- *  you may not use this file except in compliance with the License.
- *  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- *=============================================================================*/
-
-package org.apache.muse.tools.generator.util;
-
-import java.io.PrintWriter;
-import java.io.StringWriter;
-import java.util.logging.Formatter;
-import java.util.logging.Level;
-import java.util.logging.LogRecord;
-import java.util.logging.Logger;
-
-import org.apache.muse.util.messages.Messages;
-import org.apache.muse.util.messages.MessagesFactory;
-
-/**
- * @author Andrew Eberbach (aeberbac)
- *
- */
-public class SimpleLogFormatter extends Formatter {	
-	private Messages _MESSAGES = MessagesFactory.get(SimpleLogFormatter.class);
-
-	private Logger _logger = Logger.getLogger(AbstractCommandLineApp.TOP_LEVEL_PACKAGE);
-	
-	public String format(LogRecord record) {
-		StringBuffer result = new StringBuffer("\n");
-		
-		if(!record.getLevel().equals(Level.INFO)) {
-			result.append(record.getLevel().getName() + ": ");
-		}
-
-		result.append(record.getMessage());
-		
-		Throwable thrown = record.getThrown();
-		if(thrown != null) {
-			result.append("\n\n" + _MESSAGES.get("ExceptionMessage",false));
-			result.append(thrown.getMessage() + "\n\n");						
-
-			if(_logger.getLevel().intValue() == Level.ALL.intValue()) {
-				result.append(_MESSAGES.get("StackTrace",false) + "\n\n");
-				
-				StringWriter sw = new StringWriter();
-				PrintWriter pw = new PrintWriter(sw);
-				thrown.printStackTrace(pw);
-				result.append(sw.getBuffer().toString());
-			}
-		}
-					
-		result.append("\n");
-		
-		return result.toString();
-	}
-}
+/* 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+
+package org.apache.muse.tools.generator.util;
+
+import java.io.PrintWriter;
+import java.io.StringWriter;
+import java.util.logging.Formatter;
+import java.util.logging.Level;
+import java.util.logging.LogRecord;
+import java.util.logging.Logger;
+
+import org.apache.muse.util.messages.Messages;
+import org.apache.muse.util.messages.MessagesFactory;
+
+/**
+ * @author Andrew Eberbach (aeberbac)
+ *
+ */
+public class SimpleLogFormatter extends Formatter {	
+	private Messages _MESSAGES = MessagesFactory.get(SimpleLogFormatter.class);
+
+	private Logger _logger = Logger.getLogger(AbstractCommandLineApp.TOP_LEVEL_PACKAGE);
+	
+	public String format(LogRecord record) {
+		StringBuffer result = new StringBuffer("\n");
+		
+		if(!record.getLevel().equals(Level.INFO)) {
+			result.append(record.getLevel().getName() + ": ");
+		}
+
+		result.append(record.getMessage());
+		
+		Throwable thrown = record.getThrown();
+		if(thrown != null) {
+			result.append("\n\n" + _MESSAGES.get("ExceptionMessage",false));
+			result.append(thrown.getMessage() + "\n\n");						
+
+			if(_logger.getLevel().intValue() == Level.ALL.intValue()) {
+				result.append(_MESSAGES.get("StackTrace",false) + "\n\n");
+				
+				StringWriter sw = new StringWriter();
+				PrintWriter pw = new PrintWriter(sw);
+				thrown.printStackTrace(pw);
+				result.append(sw.getBuffer().toString());
+			}
+		}
+					
+		result.append("\n");
+		
+		return result.toString();
+	}
+}

Modified: webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/generator/util/SubscriptionManagerHelper.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/generator/util/SubscriptionManagerHelper.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/generator/util/SubscriptionManagerHelper.java (original)
+++ webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/generator/util/SubscriptionManagerHelper.java Sat Mar 24 06:14:20 2007
@@ -1,200 +1,204 @@
-/*=============================================================================*
- *  Copyright 2006 The Apache Software Foundation
- *
- *  Licensed under the Apache License, Version 2.0 (the "License");
- *  you may not use this file except in compliance with the License.
- *  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- *=============================================================================*/
-
-package org.apache.muse.tools.generator.util;
-
-import java.io.InputStream;
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.Map;
-
-import org.apache.muse.util.FileUtils;
-import org.apache.muse.util.xml.XmlUtils;
-import org.apache.muse.ws.notification.WsnConstants;
-import org.apache.muse.ws.notification.impl.SimpleSubscriptionManager;
-import org.apache.muse.ws.resource.lifetime.WsrlConstants;
-import org.apache.muse.ws.resource.lifetime.impl.SimpleImmediateTermination;
-import org.apache.muse.ws.resource.lifetime.impl.SimpleScheduledTermination;
-import org.apache.muse.ws.resource.metadata.MetadataDescriptor;
-import org.apache.muse.ws.resource.properties.WsrpConstants;
-import org.apache.muse.ws.resource.properties.get.impl.SimpleGetCapability;
-import org.w3c.dom.Document;
-import org.w3c.dom.Element;
-import org.w3c.dom.Node;
-
-/**
- * Endpoints that have <code>resource-type</code>s that are <code>NotificationProducer</code>s
- * need to have a <code>SubscriptionManager</code> included as a sibling <code>resource-type</code>. 
- * Without this <code>SubscriptionManager</code> the <code>NotificationProducer</code> capability
- * will not function. This class will analyze the <code>ConfigurationData</code> and modify it
- * if a <code>resource-type</code> that has a <code>SubscriptionManager</code> is not found. 
- * 
- * @author Andrew Eberbach (aeberbac)
- */
-public class SubscriptionManagerHelper {
-	
-    public static final String SUBSCRIPTION_MANAGER_DIR = "/resources/common/subscription-manager";
-    public static final String SUBSCRIPTION_MANAGER_RESOURCE_TYPE = SUBSCRIPTION_MANAGER_DIR + "/muse.xml";
-    public static final String SUBSCRIPTION_MANAGER_WSDL = SUBSCRIPTION_MANAGER_DIR + "/SubscriptionManager.wsdl";
-		
-	public static ConfigurationData addSubscriptionManager(ConfigurationData data) {
-		
-		if(needsSubscriptionManager(data)) {
-			modifyDescriptorDocument(data);
-            addSubscriptionManagerCapabilities(data);
-			addSubscriptionManagerWsdl(data);
-			addSubscriptionManagerMetadata(data);
-		}
-		
-		return data;
-	}
-    
-    private static void addSubscriptionManagerMetadata(ConfigurationData data) {
-		MetadataDescriptor[] oldMetadatas = (MetadataDescriptor[])data.getParameter(ConfigurationData.METADATA_DESCRIPTOR_LIST);
-		MetadataDescriptor[] newMetadatas = new MetadataDescriptor[oldMetadatas.length + 1];
-		System.arraycopy(oldMetadatas, 0, newMetadatas, 0, oldMetadatas.length);
-		
-		//
-		// Explicitly set the last metadata to null since there
-		// is no metadata associated with the subscription manager we're generating
-		//
-		newMetadatas[oldMetadatas.length] = null;
-		
-		data.addParameter(ConfigurationData.METADATA_DESCRIPTOR_LIST, newMetadatas);
-	}
-
-	private static void addSubscriptionManagerCapabilities(ConfigurationData data){
-        Map[] oldCaps = (Map[])data.getParameter(ConfigurationData.CAPABILITIES_MAP_LIST);
-        Map[] newCaps = new Map[oldCaps.length + 1];
-        System.arraycopy(oldCaps, 0, newCaps, 0, oldCaps.length);
-        
-        Map subMgrCaps = new HashMap();
-        
-        Capability wsrpGet = new Capability(WsrpConstants.GET_CAPABILITY);
-        wsrpGet.setBuiltIn(true);
-        wsrpGet.setImplementingClass(SimpleGetCapability.class.getName());
-        
-        Capability wsrlImmediate = new Capability(WsrlConstants.IMMEDIATE_TERMINATION_URI);
-        wsrlImmediate.setBuiltIn(true);
-        wsrlImmediate.setImplementingClass(SimpleImmediateTermination.class.getName());
-        
-        Capability wsrlScheduled = new Capability(WsrlConstants.SCHEDULED_TERMINATION_URI);
-        wsrlScheduled.setBuiltIn(true);
-        wsrlScheduled.setImplementingClass(SimpleScheduledTermination.class.getName());
-        
-        Capability subMgr = new Capability(WsnConstants.SUBSCRIPTION_MGR_URI);
-        subMgr.setBuiltIn(true);
-        subMgr.setImplementingClass(SimpleSubscriptionManager.class.getName());
-        
-        subMgrCaps.put(wsrpGet.getURI(), wsrpGet);
-        subMgrCaps.put(wsrlImmediate.getURI(), wsrlImmediate);
-        subMgrCaps.put(wsrlScheduled.getURI(), wsrlScheduled);
-        subMgrCaps.put(subMgr.getURI(), subMgr);
-        
-        newCaps[oldCaps.length] = subMgrCaps;
-        
-        data.addParameter(ConfigurationData.CAPABILITIES_MAP_LIST, newCaps);
-    }
-	
-	private static void addSubscriptionManagerWsdl(ConfigurationData data) {        
-		Document[] oldWsdls = (Document[]) data.getParameter(ConfigurationData.WSDL_DOCUMENT_LIST);
-		Document[] newWsdls = new Document[oldWsdls.length + 1];
-		System.arraycopy(oldWsdls, 0, newWsdls, 0, oldWsdls.length);
-		newWsdls[oldWsdls.length] = loadDocument(SUBSCRIPTION_MANAGER_WSDL);
-        
-        data.addParameter(ConfigurationData.WSDL_DOCUMENT_LIST, newWsdls);
-	}
-
-	private static void modifyDescriptorDocument(ConfigurationData data) {
-		Document subscriptionType = loadDocument(SUBSCRIPTION_MANAGER_RESOURCE_TYPE);
-		
-		Document descriptorDocument = (Document)data.getParameter(ConfigurationData.DESCRIPTOR_DOCUMENT);
-		
-		Node importedSubscriptionType = descriptorDocument.importNode(subscriptionType.getDocumentElement(), true);
-		
-		insertAfterLastResourceType(descriptorDocument, importedSubscriptionType);
-	}
-	
-	private static void insertAfterLastResourceType(Document descriptorDocument, Node importedSubscriptionType) {		
-		Element nodeAfterLastResourceType = getNodeAfterLastResourceType(descriptorDocument);
-		
-		if(nodeAfterLastResourceType == null) {
-			descriptorDocument.getDocumentElement().appendChild(importedSubscriptionType);
-		} else {
-			descriptorDocument.getDocumentElement().insertBefore(nodeAfterLastResourceType, importedSubscriptionType);
-		}
-	}
-
-	private static Element getNodeAfterLastResourceType(Document descriptorDocument) {
-		Element[] elements = XmlUtils.getAllElements(descriptorDocument.getDocumentElement());
-		
-		//
-		// This is the marker for the last resource-type element. We're going to do this by finding
-		// the last resource-type element and then repeatedly doing a getNextSibling, 
-		// checking to see if it's an Element until it is, or the getNextSibling is null.
-		//
-		// Remember, getNextSibling returns a *Node* so who knows if it's not a text node...
-		//
-		Node last = elements[elements.length - 1].getNextSibling();
-		
-		while(last != null) {	
-			
-			//
-			// If this is true it has to be a non-resource-type element
-			//
-			if(last instanceof Element) {
-				return (Element)last;
-			}
-			last = last.getNextSibling();
-		} 
-		
-		//
-		// We ran off the end
-		//
-		return null;
-	}
-
-	private static Document loadDocument(String path) {
-		InputStream inputStream = FileUtils.loadFromContext(SubscriptionManagerHelper.class, path);
-		try {
-			return XmlUtils.createDocument(inputStream);
-		} catch (Exception e) {
-			throw new RuntimeException(e.getMessage(), e);
-		}
-	}
-
-	private static boolean needsSubscriptionManager(ConfigurationData data) {
-		Map[] capabilityMaps = (Map[])data.getParameter(ConfigurationData.CAPABILITIES_MAP_LIST);
-		
-		boolean hasNotificationProducer = false;
-		boolean hasSubscriptionManager = false;		
-		
-		for(int j=0; j < capabilityMaps.length; j++) {
-			for(Iterator i = capabilityMaps[j].values().iterator(); i.hasNext(); ) {
-				Capability capability = (Capability)i.next();				
-				String uri = capability.getURI();
-				if(uri.equals(WsnConstants.SUBSCRIPTION_MGR_URI)) {
-					hasSubscriptionManager = true;
-				}
-				if(uri.equals(WsnConstants.PRODUCER_URI)) {
-					hasNotificationProducer = true;
-				}
-			}
-		}
-		
-		return hasNotificationProducer && !hasSubscriptionManager;
-	}
-}
+/* 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+
+package org.apache.muse.tools.generator.util;
+
+import java.io.InputStream;
+import java.util.HashMap;
+import java.util.Iterator;
+import java.util.Map;
+
+import org.apache.muse.util.FileUtils;
+import org.apache.muse.util.xml.XmlUtils;
+import org.apache.muse.ws.notification.WsnConstants;
+import org.apache.muse.ws.notification.impl.SimpleSubscriptionManager;
+import org.apache.muse.ws.resource.lifetime.WsrlConstants;
+import org.apache.muse.ws.resource.lifetime.impl.SimpleImmediateTermination;
+import org.apache.muse.ws.resource.lifetime.impl.SimpleScheduledTermination;
+import org.apache.muse.ws.resource.metadata.MetadataDescriptor;
+import org.apache.muse.ws.resource.properties.WsrpConstants;
+import org.apache.muse.ws.resource.properties.get.impl.SimpleGetCapability;
+import org.w3c.dom.Document;
+import org.w3c.dom.Element;
+import org.w3c.dom.Node;
+
+/**
+ * Endpoints that have <code>resource-type</code>s that are <code>NotificationProducer</code>s
+ * need to have a <code>SubscriptionManager</code> included as a sibling <code>resource-type</code>. 
+ * Without this <code>SubscriptionManager</code> the <code>NotificationProducer</code> capability
+ * will not function. This class will analyze the <code>ConfigurationData</code> and modify it
+ * if a <code>resource-type</code> that has a <code>SubscriptionManager</code> is not found. 
+ * 
+ * @author Andrew Eberbach (aeberbac)
+ */
+public class SubscriptionManagerHelper {
+	
+    public static final String SUBSCRIPTION_MANAGER_DIR = "/resources/common/subscription-manager";
+    public static final String SUBSCRIPTION_MANAGER_RESOURCE_TYPE = SUBSCRIPTION_MANAGER_DIR + "/muse.xml";
+    public static final String SUBSCRIPTION_MANAGER_WSDL = SUBSCRIPTION_MANAGER_DIR + "/SubscriptionManager.wsdl";
+		
+	public static ConfigurationData addSubscriptionManager(ConfigurationData data) {
+		
+		if(needsSubscriptionManager(data)) {
+			modifyDescriptorDocument(data);
+            addSubscriptionManagerCapabilities(data);
+			addSubscriptionManagerWsdl(data);
+			addSubscriptionManagerMetadata(data);
+		}
+		
+		return data;
+	}
+    
+    private static void addSubscriptionManagerMetadata(ConfigurationData data) {
+		MetadataDescriptor[] oldMetadatas = (MetadataDescriptor[])data.getParameter(ConfigurationData.METADATA_DESCRIPTOR_LIST);
+		MetadataDescriptor[] newMetadatas = new MetadataDescriptor[oldMetadatas.length + 1];
+		System.arraycopy(oldMetadatas, 0, newMetadatas, 0, oldMetadatas.length);
+		
+		//
+		// Explicitly set the last metadata to null since there
+		// is no metadata associated with the subscription manager we're generating
+		//
+		newMetadatas[oldMetadatas.length] = null;
+		
+		data.addParameter(ConfigurationData.METADATA_DESCRIPTOR_LIST, newMetadatas);
+	}
+
+	private static void addSubscriptionManagerCapabilities(ConfigurationData data){
+        Map[] oldCaps = (Map[])data.getParameter(ConfigurationData.CAPABILITIES_MAP_LIST);
+        Map[] newCaps = new Map[oldCaps.length + 1];
+        System.arraycopy(oldCaps, 0, newCaps, 0, oldCaps.length);
+        
+        Map subMgrCaps = new HashMap();
+        
+        Capability wsrpGet = new Capability(WsrpConstants.GET_CAPABILITY);
+        wsrpGet.setBuiltIn(true);
+        wsrpGet.setImplementingClass(SimpleGetCapability.class.getName());
+        
+        Capability wsrlImmediate = new Capability(WsrlConstants.IMMEDIATE_TERMINATION_URI);
+        wsrlImmediate.setBuiltIn(true);
+        wsrlImmediate.setImplementingClass(SimpleImmediateTermination.class.getName());
+        
+        Capability wsrlScheduled = new Capability(WsrlConstants.SCHEDULED_TERMINATION_URI);
+        wsrlScheduled.setBuiltIn(true);
+        wsrlScheduled.setImplementingClass(SimpleScheduledTermination.class.getName());
+        
+        Capability subMgr = new Capability(WsnConstants.SUBSCRIPTION_MGR_URI);
+        subMgr.setBuiltIn(true);
+        subMgr.setImplementingClass(SimpleSubscriptionManager.class.getName());
+        
+        subMgrCaps.put(wsrpGet.getURI(), wsrpGet);
+        subMgrCaps.put(wsrlImmediate.getURI(), wsrlImmediate);
+        subMgrCaps.put(wsrlScheduled.getURI(), wsrlScheduled);
+        subMgrCaps.put(subMgr.getURI(), subMgr);
+        
+        newCaps[oldCaps.length] = subMgrCaps;
+        
+        data.addParameter(ConfigurationData.CAPABILITIES_MAP_LIST, newCaps);
+    }
+	
+	private static void addSubscriptionManagerWsdl(ConfigurationData data) {        
+		Document[] oldWsdls = (Document[]) data.getParameter(ConfigurationData.WSDL_DOCUMENT_LIST);
+		Document[] newWsdls = new Document[oldWsdls.length + 1];
+		System.arraycopy(oldWsdls, 0, newWsdls, 0, oldWsdls.length);
+		newWsdls[oldWsdls.length] = loadDocument(SUBSCRIPTION_MANAGER_WSDL);
+        
+        data.addParameter(ConfigurationData.WSDL_DOCUMENT_LIST, newWsdls);
+	}
+
+	private static void modifyDescriptorDocument(ConfigurationData data) {
+		Document subscriptionType = loadDocument(SUBSCRIPTION_MANAGER_RESOURCE_TYPE);
+		
+		Document descriptorDocument = (Document)data.getParameter(ConfigurationData.DESCRIPTOR_DOCUMENT);
+		
+		Node importedSubscriptionType = descriptorDocument.importNode(subscriptionType.getDocumentElement(), true);
+		
+		insertAfterLastResourceType(descriptorDocument, importedSubscriptionType);
+	}
+	
+	private static void insertAfterLastResourceType(Document descriptorDocument, Node importedSubscriptionType) {		
+		Element nodeAfterLastResourceType = getNodeAfterLastResourceType(descriptorDocument);
+		
+		if(nodeAfterLastResourceType == null) {
+			descriptorDocument.getDocumentElement().appendChild(importedSubscriptionType);
+		} else {
+			descriptorDocument.getDocumentElement().insertBefore(nodeAfterLastResourceType, importedSubscriptionType);
+		}
+	}
+
+	private static Element getNodeAfterLastResourceType(Document descriptorDocument) {
+		Element[] elements = XmlUtils.getAllElements(descriptorDocument.getDocumentElement());
+		
+		//
+		// This is the marker for the last resource-type element. We're going to do this by finding
+		// the last resource-type element and then repeatedly doing a getNextSibling, 
+		// checking to see if it's an Element until it is, or the getNextSibling is null.
+		//
+		// Remember, getNextSibling returns a *Node* so who knows if it's not a text node...
+		//
+		Node last = elements[elements.length - 1].getNextSibling();
+		
+		while(last != null) {	
+			
+			//
+			// If this is true it has to be a non-resource-type element
+			//
+			if(last instanceof Element) {
+				return (Element)last;
+			}
+			last = last.getNextSibling();
+		} 
+		
+		//
+		// We ran off the end
+		//
+		return null;
+	}
+
+	private static Document loadDocument(String path) {
+		InputStream inputStream = FileUtils.loadFromContext(SubscriptionManagerHelper.class, path);
+		try {
+			return XmlUtils.createDocument(inputStream);
+		} catch (Exception e) {
+			throw new RuntimeException(e.getMessage(), e);
+		}
+	}
+
+	private static boolean needsSubscriptionManager(ConfigurationData data) {
+		Map[] capabilityMaps = (Map[])data.getParameter(ConfigurationData.CAPABILITIES_MAP_LIST);
+		
+		boolean hasNotificationProducer = false;
+		boolean hasSubscriptionManager = false;		
+		
+		for(int j=0; j < capabilityMaps.length; j++) {
+			for(Iterator i = capabilityMaps[j].values().iterator(); i.hasNext(); ) {
+				Capability capability = (Capability)i.next();				
+				String uri = capability.getURI();
+				if(uri.equals(WsnConstants.SUBSCRIPTION_MGR_URI)) {
+					hasSubscriptionManager = true;
+				}
+				if(uri.equals(WsnConstants.PRODUCER_URI)) {
+					hasNotificationProducer = true;
+				}
+			}
+		}
+		
+		return hasNotificationProducer && !hasSubscriptionManager;
+	}
+}

Modified: webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/generator/util/WsdlEnvironment.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/generator/util/WsdlEnvironment.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/generator/util/WsdlEnvironment.java (original)
+++ webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/generator/util/WsdlEnvironment.java Sat Mar 24 06:14:20 2007
@@ -1,54 +1,58 @@
-/*=============================================================================*
- *  Copyright 2007 The Apache Software Foundation
- *
- *  Licensed under the Apache License, Version 2.0 (the "License");
- *  you may not use this file except in compliance with the License.
- *  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- *=============================================================================*/
-
-package org.apache.muse.tools.generator.util;
-
-import java.io.File;
-import java.io.InputStream;
-import java.net.URI;
-import java.net.URL;
-import java.net.URLConnection;
-
-import org.apache.muse.util.messages.Messages;
-import org.apache.muse.util.messages.MessagesFactory;
-
-public class WsdlEnvironment extends LocalEnvironment {
-
-	private Messages _MESSAGES = MessagesFactory.get(WsdlEnvironment.class);
-	
-    private static final String HTTP_SCHEME = "http";
-
-	public WsdlEnvironment(File wsdl) {
-		super(wsdl);
-	}
-
-	public InputStream getDataResourceStream(String path) 
-    {
-    	URI uri = URI.create(path);		
-		String scheme = uri.getScheme();
-		
-		if(scheme != null && uri.getScheme().equals(HTTP_SCHEME)) {
-			try {
-				URLConnection conn = new URL(path).openConnection();
-				return conn.getInputStream();
-			} catch (Exception e) {				
-				Object[] filler = { path, e.getMessage() };
-				throw new MuseRuntimeException("FailedRemoteFile", _MESSAGES.get("FailedRemoteFile", filler), e);
-			}
-		}
-        return super.getDataResourceStream(path);
-    }
-}
+/* 
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
+ */
+
+package org.apache.muse.tools.generator.util;
+
+import java.io.File;
+import java.io.InputStream;
+import java.net.URI;
+import java.net.URL;
+import java.net.URLConnection;
+
+import org.apache.muse.util.messages.Messages;
+import org.apache.muse.util.messages.MessagesFactory;
+
+public class WsdlEnvironment extends LocalEnvironment {
+
+	private Messages _MESSAGES = MessagesFactory.get(WsdlEnvironment.class);
+	
+    private static final String HTTP_SCHEME = "http";
+
+	public WsdlEnvironment(File wsdl) {
+		super(wsdl);
+	}
+
+	public InputStream getDataResourceStream(String path) 
+    {
+    	URI uri = URI.create(path);		
+		String scheme = uri.getScheme();
+		
+		if(scheme != null && uri.getScheme().equals(HTTP_SCHEME)) {
+			try {
+				URLConnection conn = new URL(path).openConnection();
+				return conn.getInputStream();
+			} catch (Exception e) {				
+				Object[] filler = { path, e.getMessage() };
+				throw new MuseRuntimeException("FailedRemoteFile", _MESSAGES.get("FailedRemoteFile", filler), e);
+			}
+		}
+        return super.getDataResourceStream(path);
+    }
+}

Modified: webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/inspector/JavaMethod.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/inspector/JavaMethod.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/inspector/JavaMethod.java (original)
+++ webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/inspector/JavaMethod.java Sat Mar 24 06:14:20 2007
@@ -1,18 +1,22 @@
-/*=============================================================================*
- *  Copyright 2006 The Apache Software Foundation
+/* 
+ * 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.
  *
- *  Licensed under the Apache License, Version 2.0 (the "License");
- *  you may not use this file except in compliance with the License.
- *  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- *=============================================================================*/
+ */
 
 package org.apache.muse.tools.inspector;
 

Modified: webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/inspector/JavaProperty.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/inspector/JavaProperty.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/inspector/JavaProperty.java (original)
+++ webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/inspector/JavaProperty.java Sat Mar 24 06:14:20 2007
@@ -1,19 +1,21 @@
-/*******************************************************************************
- * =============================================================================
- * Copyright 2006 The Apache Software Foundation
- * 
- * Licensed 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
+/* 
+ * 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.
- * =============================================================================
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ *
  */
 
 package org.apache.muse.tools.inspector;

Modified: webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/inspector/ResourceInspector.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/inspector/ResourceInspector.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/inspector/ResourceInspector.java (original)
+++ webservices/muse/trunk/modules/muse-tools/src/org/apache/muse/tools/inspector/ResourceInspector.java Sat Mar 24 06:14:20 2007
@@ -1,18 +1,22 @@
-/*=============================================================================*
- *  Copyright 2006 The Apache Software Foundation
+/* 
+ * 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.
  *
- *  Licensed under the Apache License, Version 2.0 (the "License");
- *  you may not use this file except in compliance with the License.
- *  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- *=============================================================================*/
+ */
 
 package org.apache.muse.tools.inspector;
 

Modified: webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/ConsoleHandler.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/ConsoleHandler.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/ConsoleHandler.java (original)
+++ webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/ConsoleHandler.java Sat Mar 24 06:14:20 2007
@@ -1,36 +1,40 @@
-/*=============================================================================*
- *  Copyright 2007 The Apache Software Foundation
- *
- *  Licensed 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 java.util.logging;
-
-/**
- * 
- * @author Barry Atkins
- *
- */
-
-public class ConsoleHandler extends Handler
-{
-    public void close()
-    {
-        System.out.flush();
-    }
-    
-    public void publish(LogRecord record)
-    {
-        System.out.println(record);
-    }
-}
+/* 
+ * 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 java.util.logging;
+
+/**
+ * 
+ * @author Barry Atkins
+ *
+ */
+
+public class ConsoleHandler extends Handler
+{
+    public void close()
+    {
+        System.out.flush();
+    }
+    
+    public void publish(LogRecord record)
+    {
+        System.out.println(record);
+    }
+}

Modified: webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/FileHandler.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/FileHandler.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/FileHandler.java (original)
+++ webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/FileHandler.java Sat Mar 24 06:14:20 2007
@@ -1,71 +1,75 @@
-/*=============================================================================*
- *  Copyright 2007 The Apache Software Foundation
- *
- *  Licensed 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 java.util.logging;
-
-import java.io.FileWriter;
-import java.io.IOException;
-import java.util.Date;
-
-/**
- * 
- * @author Barry Atkins
- *
- */
-
-public class FileHandler extends Handler
-{
-    private FileWriter _writer = null;
-    
-    public FileHandler(String fileName)
-        throws IOException
-    {
-        _writer = new FileWriter(fileName);
-    }
-    
-    public void close()
-    {
-        try
-        {
-            _writer.flush();
-            _writer.close();
-        }
-        
-        catch (IOException error)
-        {
-            error.printStackTrace();
-        }
-    }
-
-    public void publish(LogRecord record)
-    {
-        try
-        {
-            Date time = new Date(record.getMillis());
-            
-            _writer.write("[ ");
-            _writer.write(time.toString());
-            _writer.write(" ] ");
-            _writer.write(record.getMessage());
-            _writer.write('\n');
-        }
-        
-        catch (IOException error)
-        {
-            error.printStackTrace();
-        }
-    }
-}
+/* 
+ * 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 java.util.logging;
+
+import java.io.FileWriter;
+import java.io.IOException;
+import java.util.Date;
+
+/**
+ * 
+ * @author Barry Atkins
+ *
+ */
+
+public class FileHandler extends Handler
+{
+    private FileWriter _writer = null;
+    
+    public FileHandler(String fileName)
+        throws IOException
+    {
+        _writer = new FileWriter(fileName);
+    }
+    
+    public void close()
+    {
+        try
+        {
+            _writer.flush();
+            _writer.close();
+        }
+        
+        catch (IOException error)
+        {
+            error.printStackTrace();
+        }
+    }
+
+    public void publish(LogRecord record)
+    {
+        try
+        {
+            Date time = new Date(record.getMillis());
+            
+            _writer.write("[ ");
+            _writer.write(time.toString());
+            _writer.write(" ] ");
+            _writer.write(record.getMessage());
+            _writer.write('\n');
+        }
+        
+        catch (IOException error)
+        {
+            error.printStackTrace();
+        }
+    }
+}

Modified: webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Formatter.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Formatter.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Formatter.java (original)
+++ webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Formatter.java Sat Mar 24 06:14:20 2007
@@ -1,28 +1,32 @@
-/*=============================================================================*
- *  Copyright 2007 The Apache Software Foundation
- *
- *  Licensed 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 java.util.logging;
-
-/**
- * 
- * @author Barry Atkins
- *
- */
-
-public abstract class Formatter
-{
-    public abstract String format(LogRecord record);
-}
+/* 
+ * 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 java.util.logging;
+
+/**
+ * 
+ * @author Barry Atkins
+ *
+ */
+
+public abstract class Formatter
+{
+    public abstract String format(LogRecord record);
+}

Modified: webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Handler.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Handler.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Handler.java (original)
+++ webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Handler.java Sat Mar 24 06:14:20 2007
@@ -1,54 +1,58 @@
-/*=============================================================================*
- *  Copyright 2007 The Apache Software Foundation
- *
- *  Licensed 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 java.util.logging;
-
-/**
- * 
- * @author Barry Atkins
- * 
- */
-
-public abstract class Handler
-{
-    private Formatter _formatter = null;
-    
-    private Level _level = null;
-    
-    public Formatter getFormatter()
-    {
-        return _formatter;
-    }
-    
-    public Level getLevel()
-    {
-        return _level;
-    }
-
-    public void setFormatter(Formatter formatter)
-    {
-        _formatter = formatter;
-    }
-    
-    public void setLevel(Level level)
-    {
-        _level = level;
-    }
-    
-    public abstract void close();
-    
-    public abstract void publish(LogRecord record);
-}
+/* 
+ * 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 java.util.logging;
+
+/**
+ * 
+ * @author Barry Atkins
+ * 
+ */
+
+public abstract class Handler
+{
+    private Formatter _formatter = null;
+    
+    private Level _level = null;
+    
+    public Formatter getFormatter()
+    {
+        return _formatter;
+    }
+    
+    public Level getLevel()
+    {
+        return _level;
+    }
+
+    public void setFormatter(Formatter formatter)
+    {
+        _formatter = formatter;
+    }
+    
+    public void setLevel(Level level)
+    {
+        _level = level;
+    }
+    
+    public abstract void close();
+    
+    public abstract void publish(LogRecord record);
+}

Modified: webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Level.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Level.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Level.java (original)
+++ webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Level.java Sat Mar 24 06:14:20 2007
@@ -1,97 +1,101 @@
-/*=============================================================================*
- *  Copyright 2007 The Apache Software Foundation
- *
- *  Licensed 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 java.util.logging;
-
-import java.util.HashMap;
-import java.util.Map;
-
-/**
- * 
- * @author Barry Atkins
- * 
- */
-
-public class Level
-{
-    public static final Level OFF = new Level("OFF", 0);
-    
-    public static final Level SEVERE = new Level("SEVERE", 1);
-    
-    public static final Level WARNING = new Level("WARNING", 2);
-    
-    public static final Level INFO = new Level("INFO", 3);
-    
-    public static final Level CONFIG = new Level("CONFIG", 4);
-    
-    public static final Level FINE = new Level("FINE", 5);
-    
-    public static final Level FINER = new Level("FINER", 6);
-    
-    public static final Level FINEST = new Level("FINEST", 7);
-    
-    public static final Level ALL = new Level("ALL", 8);
-    
-    private static final Map _LEVELS_BY_NAME = new HashMap();
-    
-    static
-    {
-        _LEVELS_BY_NAME.put(OFF.getName(), OFF);
-        _LEVELS_BY_NAME.put(SEVERE.getName(), SEVERE);
-        _LEVELS_BY_NAME.put(WARNING.getName(), WARNING);
-        _LEVELS_BY_NAME.put(INFO.getName(), INFO);
-        _LEVELS_BY_NAME.put(CONFIG.getName(), CONFIG);
-        _LEVELS_BY_NAME.put(FINE.getName(), FINE);
-        _LEVELS_BY_NAME.put(FINER.getName(), FINER);
-        _LEVELS_BY_NAME.put(FINEST.getName(), FINEST);
-        _LEVELS_BY_NAME.put(ALL.getName(), ALL);
-    }
-    
-    private String _name = null;
-    
-    private int _value;
-    
-    private Level(String name, int value)
-    {
-        _name = name;
-        _value = value;
-    }
-    
-    public String getName()
-    {
-        return _name;
-    }
-    
-    public int intValue()
-    {
-        return _value;
-    }
-    
-    public static Level parse(String name)
-    {
-        Level level = (Level)_LEVELS_BY_NAME.get(name);
-        
-        if (level == null)
-            throw new IllegalArgumentException("Invalid logging level: " + name);
-        
-        return level;
-    }
-    
-    public String toString()
-    {
-        return getName();
-    }
-}
+/* 
+ * 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 java.util.logging;
+
+import java.util.HashMap;
+import java.util.Map;
+
+/**
+ * 
+ * @author Barry Atkins
+ * 
+ */
+
+public class Level
+{
+    public static final Level OFF = new Level("OFF", 0);
+    
+    public static final Level SEVERE = new Level("SEVERE", 1);
+    
+    public static final Level WARNING = new Level("WARNING", 2);
+    
+    public static final Level INFO = new Level("INFO", 3);
+    
+    public static final Level CONFIG = new Level("CONFIG", 4);
+    
+    public static final Level FINE = new Level("FINE", 5);
+    
+    public static final Level FINER = new Level("FINER", 6);
+    
+    public static final Level FINEST = new Level("FINEST", 7);
+    
+    public static final Level ALL = new Level("ALL", 8);
+    
+    private static final Map _LEVELS_BY_NAME = new HashMap();
+    
+    static
+    {
+        _LEVELS_BY_NAME.put(OFF.getName(), OFF);
+        _LEVELS_BY_NAME.put(SEVERE.getName(), SEVERE);
+        _LEVELS_BY_NAME.put(WARNING.getName(), WARNING);
+        _LEVELS_BY_NAME.put(INFO.getName(), INFO);
+        _LEVELS_BY_NAME.put(CONFIG.getName(), CONFIG);
+        _LEVELS_BY_NAME.put(FINE.getName(), FINE);
+        _LEVELS_BY_NAME.put(FINER.getName(), FINER);
+        _LEVELS_BY_NAME.put(FINEST.getName(), FINEST);
+        _LEVELS_BY_NAME.put(ALL.getName(), ALL);
+    }
+    
+    private String _name = null;
+    
+    private int _value;
+    
+    private Level(String name, int value)
+    {
+        _name = name;
+        _value = value;
+    }
+    
+    public String getName()
+    {
+        return _name;
+    }
+    
+    public int intValue()
+    {
+        return _value;
+    }
+    
+    public static Level parse(String name)
+    {
+        Level level = (Level)_LEVELS_BY_NAME.get(name);
+        
+        if (level == null)
+            throw new IllegalArgumentException("Invalid logging level: " + name);
+        
+        return level;
+    }
+    
+    public String toString()
+    {
+        return getName();
+    }
+}

Modified: webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/LogRecord.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/LogRecord.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/LogRecord.java (original)
+++ webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/LogRecord.java Sat Mar 24 06:14:20 2007
@@ -1,60 +1,64 @@
-/*=============================================================================*
- *  Copyright 2007 The Apache Software Foundation
- *
- *  Licensed 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 java.util.logging;
-
-import java.util.Date;
-
-/**
- * 
- * @author Barry Atkins
- * 
- */
-
-public class LogRecord
-{
-    private Level _level = null;
-    
-    private String _message = null;
-    
-    private Date _time = new Date();
-    
-    public LogRecord(Level level, String message)
-    {
-        _level = level;
-        _message = message;
-    }
-    
-    public Level getLevel()
-    {
-        return _level;
-    }
-    
-    public String getMessage()
-    {
-        return _message;
-    }
-    
-    public long getMillis()
-    {
-        return _time.getTime();
-    }
-    
-    public String toString()
-    {
-        return getMessage();
-    }
-}
+/* 
+ * 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 java.util.logging;
+
+import java.util.Date;
+
+/**
+ * 
+ * @author Barry Atkins
+ * 
+ */
+
+public class LogRecord
+{
+    private Level _level = null;
+    
+    private String _message = null;
+    
+    private Date _time = new Date();
+    
+    public LogRecord(Level level, String message)
+    {
+        _level = level;
+        _message = message;
+    }
+    
+    public Level getLevel()
+    {
+        return _level;
+    }
+    
+    public String getMessage()
+    {
+        return _message;
+    }
+    
+    public long getMillis()
+    {
+        return _time.getTime();
+    }
+    
+    public String toString()
+    {
+        return getMessage();
+    }
+}

Modified: webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Logger.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Logger.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Logger.java (original)
+++ webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/Logger.java Sat Mar 24 06:14:20 2007
@@ -1,142 +1,146 @@
-/*=============================================================================*
- *  Copyright 2007 The Apache Software Foundation
- *
- *  Licensed 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 java.util.logging;
-
-import java.util.*;
-
-/**
- * 
- * @author Barry Atkins
- * 
- */
-
-public class Logger
-{
-    private static final Map _LOGGERS = new HashMap();
-    
-    private List _handlers = new LinkedList();
-    
-    private Level _level = Level.ALL;
-    
-    private String _name = null;
-    
-    private Logger(String name)
-    {
-        _name = name;
-    }
-    
-    public void addHandler(Handler handler)
-    {
-        handler.setLevel(getLevel());
-        _handlers.add(handler);
-    }
-    
-    public void config(String message)
-    {
-        log(Level.CONFIG, message);
-    }
-    
-    public void fine(String message)
-    {
-        log(Level.FINE, message);
-    }
-    
-    public void finer(String message)
-    {
-        log(Level.FINER, message);
-    }
-    
-    public void finest(String message)
-    {
-        log(Level.FINEST, message);
-    }
-    
-    public Handler[] getHandlers()
-    {
-        Handler[] array = new Handler[_handlers.size()];
-        return (Handler[])_handlers.toArray(array);
-    }
-    
-    public Level getLevel()
-    {
-        return _level;
-    }
-    
-    public static Logger getLogger(String name)
-    {
-        if (!_LOGGERS.containsKey(name))
-            _LOGGERS.put(name, new Logger(name));
-        
-        return (Logger)_LOGGERS.get(name);
-    }
-        
-    public String getName()
-    {
-        return _name;
-    }
-    
-    public void info(String message)
-    {
-        log(Level.INFO, message);
-    }
-    
-    public boolean isLoggable(LogRecord record)
-    {
-        return getLevel().intValue() >= record.getLevel().intValue();
-    }
-    
-    public void log(Level level, String message)
-    {
-        LogRecord record = new LogRecord(level, message);
-        
-        if (!isLoggable(record))
-            return;
-        
-        Iterator i = _handlers.iterator();
-        
-        while (i.hasNext())
-        {
-            Handler next = (Handler)i.next();
-            next.publish(record);
-        }
-    }
-    
-    public void removeHandler(Handler handler)
-    {
-        _handlers.remove(handler);
-    }
-    
-    public void setLevel(Level level)
-    {
-        _level = level;
-    }
-    
-    public void severe(String message)
-    {
-        log(Level.SEVERE, message);
-    }
-    
-    public String toString()
-    {
-        return getName();
-    }
-    
-    public void warning(String message)
-    {
-        log(Level.WARNING, message);
-    }
-}
+/* 
+ * 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 java.util.logging;
+
+import java.util.*;
+
+/**
+ * 
+ * @author Barry Atkins
+ * 
+ */
+
+public class Logger
+{
+    private static final Map _LOGGERS = new HashMap();
+    
+    private List _handlers = new LinkedList();
+    
+    private Level _level = Level.ALL;
+    
+    private String _name = null;
+    
+    private Logger(String name)
+    {
+        _name = name;
+    }
+    
+    public void addHandler(Handler handler)
+    {
+        handler.setLevel(getLevel());
+        _handlers.add(handler);
+    }
+    
+    public void config(String message)
+    {
+        log(Level.CONFIG, message);
+    }
+    
+    public void fine(String message)
+    {
+        log(Level.FINE, message);
+    }
+    
+    public void finer(String message)
+    {
+        log(Level.FINER, message);
+    }
+    
+    public void finest(String message)
+    {
+        log(Level.FINEST, message);
+    }
+    
+    public Handler[] getHandlers()
+    {
+        Handler[] array = new Handler[_handlers.size()];
+        return (Handler[])_handlers.toArray(array);
+    }
+    
+    public Level getLevel()
+    {
+        return _level;
+    }
+    
+    public static Logger getLogger(String name)
+    {
+        if (!_LOGGERS.containsKey(name))
+            _LOGGERS.put(name, new Logger(name));
+        
+        return (Logger)_LOGGERS.get(name);
+    }
+        
+    public String getName()
+    {
+        return _name;
+    }
+    
+    public void info(String message)
+    {
+        log(Level.INFO, message);
+    }
+    
+    public boolean isLoggable(LogRecord record)
+    {
+        return getLevel().intValue() >= record.getLevel().intValue();
+    }
+    
+    public void log(Level level, String message)
+    {
+        LogRecord record = new LogRecord(level, message);
+        
+        if (!isLoggable(record))
+            return;
+        
+        Iterator i = _handlers.iterator();
+        
+        while (i.hasNext())
+        {
+            Handler next = (Handler)i.next();
+            next.publish(record);
+        }
+    }
+    
+    public void removeHandler(Handler handler)
+    {
+        _handlers.remove(handler);
+    }
+    
+    public void setLevel(Level level)
+    {
+        _level = level;
+    }
+    
+    public void severe(String message)
+    {
+        log(Level.SEVERE, message);
+    }
+    
+    public String toString()
+    {
+        return getName();
+    }
+    
+    public void warning(String message)
+    {
+        log(Level.WARNING, message);
+    }
+}

Modified: webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/SimpleFormatter.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/SimpleFormatter.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/SimpleFormatter.java (original)
+++ webservices/muse/trunk/modules/muse-util-logging/src/java/util/logging/SimpleFormatter.java Sat Mar 24 06:14:20 2007
@@ -1,31 +1,35 @@
-/*=============================================================================*
- *  Copyright 2007 The Apache Software Foundation
- *
- *  Licensed 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 java.util.logging;
-
-/**
- * 
- * @author Barry Atkins
- *
- */
-
-public class SimpleFormatter extends Formatter
-{
-    public String format(LogRecord record)
-    {
-        return record.getMessage();
-    }
-}
+/* 
+ * 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 java.util.logging;
+
+/**
+ * 
+ * @author Barry Atkins
+ *
+ */
+
+public class SimpleFormatter extends Formatter
+{
+    public String format(LogRecord record)
+    {
+        return record.getMessage();
+    }
+}

Modified: webservices/muse/trunk/modules/muse-util-qname/src/javax/xml/namespace/NamespaceContext.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-qname/src/javax/xml/namespace/NamespaceContext.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-qname/src/javax/xml/namespace/NamespaceContext.java (original)
+++ webservices/muse/trunk/modules/muse-util-qname/src/javax/xml/namespace/NamespaceContext.java Sat Mar 24 06:14:20 2007
@@ -1,18 +1,22 @@
-/*=============================================================================*
- *  Copyright 2006 The Apache Software Foundation
+/* 
+ * 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.
  *
- *  Licensed 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 javax.xml.namespace;
 

Modified: webservices/muse/trunk/modules/muse-util-qname/src/javax/xml/namespace/QName.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-qname/src/javax/xml/namespace/QName.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-qname/src/javax/xml/namespace/QName.java (original)
+++ webservices/muse/trunk/modules/muse-util-qname/src/javax/xml/namespace/QName.java Sat Mar 24 06:14:20 2007
@@ -1,18 +1,22 @@
-/*=============================================================================*
- *  Copyright 2006 The Apache Software Foundation
+/* 
+ * 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.
  *
- *  Licensed 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 javax.xml.namespace;
 

Modified: webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XPathUtils.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XPathUtils.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XPathUtils.java (original)
+++ webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XPathUtils.java Sat Mar 24 06:14:20 2007
@@ -1,18 +1,22 @@
-/*=============================================================================*
- *  Copyright 2006 The Apache Software Foundation
+/* 
+ * 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.
  *
- *  Licensed under the Apache License, Version 2.0 (the "License");
- *  you may not use this file except in compliance with the License.
- *  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- *=============================================================================*/
+ */
 
 package org.apache.muse.util.xml;
 

Modified: webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XmlFileFilter.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XmlFileFilter.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XmlFileFilter.java (original)
+++ webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XmlFileFilter.java Sat Mar 24 06:14:20 2007
@@ -1,18 +1,22 @@
-/*=============================================================================*
- *  Copyright 2006 The Apache Software Foundation
+/* 
+ * 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.
  *
- *  Licensed under the Apache License, Version 2.0 (the "License");
- *  you may not use this file except in compliance with the License.
- *  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- *=============================================================================*/
+ */
 
 package org.apache.muse.util.xml;
 

Modified: webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XmlSerializable.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XmlSerializable.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XmlSerializable.java (original)
+++ webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XmlSerializable.java Sat Mar 24 06:14:20 2007
@@ -1,18 +1,22 @@
-/*=============================================================================*
- *  Copyright 2006 The Apache Software Foundation
+/* 
+ * 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.
  *
- *  Licensed under the Apache License, Version 2.0 (the "License");
- *  you may not use this file except in compliance with the License.
- *  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- *=============================================================================*/
+ */
 
 package org.apache.muse.util.xml;
 

Modified: webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XmlUtils.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XmlUtils.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XmlUtils.java (original)
+++ webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XmlUtils.java Sat Mar 24 06:14:20 2007
@@ -1,18 +1,22 @@
-/*=============================================================================*
- *  Copyright 2006 The Apache Software Foundation
+/* 
+ * 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.
  *
- *  Licensed under the Apache License, Version 2.0 (the "License");
- *  you may not use this file except in compliance with the License.
- *  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- *=============================================================================*/
+ */
 
 package org.apache.muse.util.xml;
 

Modified: webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XsdFileFilter.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XsdFileFilter.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XsdFileFilter.java (original)
+++ webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XsdFileFilter.java Sat Mar 24 06:14:20 2007
@@ -1,18 +1,22 @@
-/*=============================================================================*
- *  Copyright 2006 The Apache Software Foundation
+/* 
+ * 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.
  *
- *  Licensed under the Apache License, Version 2.0 (the "License");
- *  you may not use this file except in compliance with the License.
- *  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- *=============================================================================*/
+ */
 
 package org.apache.muse.util.xml;
 

Modified: webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XsdUtils.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XsdUtils.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XsdUtils.java (original)
+++ webservices/muse/trunk/modules/muse-util-xml/src/org/apache/muse/util/xml/XsdUtils.java Sat Mar 24 06:14:20 2007
@@ -1,18 +1,22 @@
-/*=============================================================================*
- *  Copyright 2006 The Apache Software Foundation
+/* 
+ * 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.
  *
- *  Licensed under the Apache License, Version 2.0 (the "License");
- *  you may not use this file except in compliance with the License.
- *  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- *=============================================================================*/
+ */
 
 package org.apache.muse.util.xml;
 

Modified: webservices/muse/trunk/modules/muse-util/src/org/apache/muse/util/CommandLine.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-util/src/org/apache/muse/util/CommandLine.java?view=diff&rev=522019&r1=522018&r2=522019
==============================================================================
--- webservices/muse/trunk/modules/muse-util/src/org/apache/muse/util/CommandLine.java (original)
+++ webservices/muse/trunk/modules/muse-util/src/org/apache/muse/util/CommandLine.java Sat Mar 24 06:14:20 2007
@@ -1,18 +1,22 @@
-/*=============================================================================*
- *  Copyright 2006 The Apache Software Foundation
+/* 
+ * 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.
  *
- *  Licensed under the Apache License, Version 2.0 (the "License");
- *  you may not use this file except in compliance with the License.
- *  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- *=============================================================================*/
+ */
 
 package org.apache.muse.util;
 



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