You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by ra...@apache.org on 2010/02/12 05:38:57 UTC

svn commit: r909229 [4/5] - in /qpid/branches/0.6-release/qpid: cpp/examples/ cpp/src/qpid/framing/ cpp/src/tests/ cpp/src/tests/cluster_test_scripts/ dotnet/client-010/client/client/ dotnet/client-010/client/transport/ dotnet/client-010/demo/Propertie...

Modified: qpid/branches/0.6-release/qpid/java/management/client/src/main/java/org/apache/qpid/management/domain/model/QpidEntity.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.6-release/qpid/java/management/client/src/main/java/org/apache/qpid/management/domain/model/QpidEntity.java?rev=909229&r1=909228&r2=909229&view=diff
==============================================================================
--- qpid/branches/0.6-release/qpid/java/management/client/src/main/java/org/apache/qpid/management/domain/model/QpidEntity.java (original)
+++ qpid/branches/0.6-release/qpid/java/management/client/src/main/java/org/apache/qpid/management/domain/model/QpidEntity.java Fri Feb 12 04:38:52 2010
@@ -1,163 +1,184 @@
-package org.apache.qpid.management.domain.model;
-
-import java.util.HashMap;
-import java.util.Map;
-
-import javax.management.Attribute;
-import javax.management.AttributeList;
-import javax.management.DynamicMBean;
-import javax.management.MBeanInfo;
-import javax.management.NotificationBroadcasterSupport;
-import javax.management.ObjectName;
-import javax.management.RuntimeOperationsException;
-
-import org.apache.qpid.management.Messages;
-import org.apache.qpid.management.Names;
-import org.apache.qpid.management.domain.model.type.Binary;
-import org.apache.qpid.management.domain.services.QpidService;
-import org.apache.qpid.management.jmx.EntityLifecycleNotification;
-import org.apache.qpid.transport.util.Logger;
-
-/**
- * Layer supertype for QMan entities.
- */
-public abstract class QpidEntity extends NotificationBroadcasterSupport
-{  
-	/**
-	 * Layer supertype for QMan managed bean entities. 
-	 */
-	abstract class QManManagedEntity implements DynamicMBean
-	{
-        // After mbean is registered with the MBean server this collection holds the mbean attribute values.
-        Map<String,Object> _attributes = new HashMap<String, Object>();
-        
-        /**
-         * Creates or replace the given attribute.
-         * Note that this is not part of the management interface of this object instance and therefore will be accessible only
-         * from within this class.
-         * It is used to update directly the object attributes bypassing jmx interface.
-         * 
-         * @param attributeName the name of the attribute.
-         * @param property newValue the new value of the attribute.
-         */
-        void createOrReplaceAttributeValue(String attributeName, Object newValue) 
-        {
-        	_attributes.put(attributeName, newValue);
-        }
-        
-        /**
-         * Get the values of several attributes of the Dynamic MBean.
-         *
-         * @param attributes A list of the attributes to be retrieved.
-         *
-         * @return  The list of attributes retrieved.
-         */
-         public AttributeList getAttributes (String[] attributes)
-         {
-             if (attributes == null) 
-             {
-                 throw new RuntimeOperationsException(new IllegalArgumentException("Attributes array must not be null"));
-             }
-             
-             AttributeList result = new AttributeList(attributes.length);
-             for (int i = 0; i < attributes.length; i++)
-             {
-                 String attributeName = attributes[i];
-                 try 
-                 {
-                     result.add(new Attribute(attributeName,getAttribute(attributeName)));
-                 } catch(Exception exception) 
-                 {
-                     // Already logged.
-                 }
-             } 
-             return result;
-         }
-         
-         /**
-          * Returns metadata for this object instance.
-          */
-         // Developer Note : note that this metadata is a member of the outer class definition : in that way we create 
-         // that metadata only once and then it will be shared between all object instances (it's a readonly object)
-         public MBeanInfo getMBeanInfo ()
-         {
-             return _metadata;
-         }         
-	};
-	
-    final Logger _logger = Logger.get(getClass());
-    final static JmxService JMX_SERVICE = new JmxService();
-    
-    final String _name;
-    final Binary _hash;
-    
-    final QpidPackage _parent;
-    MBeanInfo _metadata;
-    final QpidService _service;
-
-    protected ObjectName _objectName;
-    
-    private final String _type;
-    
-    /**
-     * Builds a new class with the given name and package as parent.
-     * 
-     * @param className the name of the class.
-     * @param hash the class schema hash.
-     * @param parentPackage the parent of this class.
-     */
-    QpidEntity(String className, Binary hash, QpidPackage parentPackage,String type)
-    {
-        this._name = className;
-        this._parent = parentPackage;
-        this._hash = hash;
-        this._type = type;
-        this._service = new QpidService(_parent.getOwnerId());
-        
-        _logger.debug(
-                Messages.QMAN_200020_ENTITY_DEFINITION_HAS_BEEN_BUILT, 
-                _parent.getOwnerId(),
-                _parent.getName(),
-                _name);        
-    }
-    
-    public String getName()
-    {
-    	return _name;
-    }
-    
-    public String getPackageName()
-    {
-    	return _parent.getName();
-    }
-    
-    /**
-     * Internal method used to send a schema request for this entity.
-     * 
-     * @throws Exception when the request cannot be sent.
-     */
-    void requestSchema() throws Exception
-    {     
-
-       	_objectName = JMX_SERVICE.createEntityDefinitionName(_parent.getName(), _name,_type);
-     	 JMX_SERVICE.registerEntityDefinition(_objectName,this,_parent.getName(),_name);
-
-    	try
-        {
-            _service.connect();
-           _service.requestSchema(_parent.getName(), _name, _hash);
-            _service.sync();
-        } finally
-        {
-            _service.close();
-        }                
-        
-      	 EntityLifecycleNotification notification = new EntityLifecycleNotification(
-          		 EntityLifecycleNotification.SCHEMA_REQUESTED_NOTIFICATION_TYPE,
-          		 _parent.getName(), 
-          		 _name, 
-          		 Names.CLASS,
-          		 _objectName);
-           sendNotification(notification);
-    }    
-}
+package org.apache.qpid.management.domain.model;
+/*
+ * 
+ * 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.
+ * 
+ */
+
+
+import java.util.HashMap;
+import java.util.Map;
+
+import javax.management.Attribute;
+import javax.management.AttributeList;
+import javax.management.DynamicMBean;
+import javax.management.MBeanInfo;
+import javax.management.NotificationBroadcasterSupport;
+import javax.management.ObjectName;
+import javax.management.RuntimeOperationsException;
+
+import org.apache.qpid.management.Messages;
+import org.apache.qpid.management.Names;
+import org.apache.qpid.management.domain.model.type.Binary;
+import org.apache.qpid.management.domain.services.QpidService;
+import org.apache.qpid.management.jmx.EntityLifecycleNotification;
+import org.apache.qpid.transport.util.Logger;
+
+/**
+ * Layer supertype for QMan entities.
+ */
+public abstract class QpidEntity extends NotificationBroadcasterSupport
+{  
+	/**
+	 * Layer supertype for QMan managed bean entities. 
+	 */
+	abstract class QManManagedEntity implements DynamicMBean
+	{
+        // After mbean is registered with the MBean server this collection holds the mbean attribute values.
+        Map<String,Object> _attributes = new HashMap<String, Object>();
+        
+        /**
+         * Creates or replace the given attribute.
+         * Note that this is not part of the management interface of this object instance and therefore will be accessible only
+         * from within this class.
+         * It is used to update directly the object attributes bypassing jmx interface.
+         * 
+         * @param attributeName the name of the attribute.
+         * @param property newValue the new value of the attribute.
+         */
+        void createOrReplaceAttributeValue(String attributeName, Object newValue) 
+        {
+        	_attributes.put(attributeName, newValue);
+        }
+        
+        /**
+         * Get the values of several attributes of the Dynamic MBean.
+         *
+         * @param attributes A list of the attributes to be retrieved.
+         *
+         * @return  The list of attributes retrieved.
+         */
+         public AttributeList getAttributes (String[] attributes)
+         {
+             if (attributes == null) 
+             {
+                 throw new RuntimeOperationsException(new IllegalArgumentException("Attributes array must not be null"));
+             }
+             
+             AttributeList result = new AttributeList(attributes.length);
+             for (int i = 0; i < attributes.length; i++)
+             {
+                 String attributeName = attributes[i];
+                 try 
+                 {
+                     result.add(new Attribute(attributeName,getAttribute(attributeName)));
+                 } catch(Exception exception) 
+                 {
+                     // Already logged.
+                 }
+             } 
+             return result;
+         }
+         
+         /**
+          * Returns metadata for this object instance.
+          */
+         // Developer Note : note that this metadata is a member of the outer class definition : in that way we create 
+         // that metadata only once and then it will be shared between all object instances (it's a readonly object)
+         public MBeanInfo getMBeanInfo ()
+         {
+             return _metadata;
+         }         
+	};
+	
+    final Logger _logger = Logger.get(getClass());
+    final static JmxService JMX_SERVICE = new JmxService();
+    
+    final String _name;
+    final Binary _hash;
+    
+    final QpidPackage _parent;
+    MBeanInfo _metadata;
+    final QpidService _service;
+
+    protected ObjectName _objectName;
+    
+    private final String _type;
+    
+    /**
+     * Builds a new class with the given name and package as parent.
+     * 
+     * @param className the name of the class.
+     * @param hash the class schema hash.
+     * @param parentPackage the parent of this class.
+     */
+    QpidEntity(String className, Binary hash, QpidPackage parentPackage,String type)
+    {
+        this._name = className;
+        this._parent = parentPackage;
+        this._hash = hash;
+        this._type = type;
+        this._service = new QpidService(_parent.getOwnerId());
+        
+        _logger.debug(
+                Messages.QMAN_200020_ENTITY_DEFINITION_HAS_BEEN_BUILT, 
+                _parent.getOwnerId(),
+                _parent.getName(),
+                _name);        
+    }
+    
+    public String getName()
+    {
+    	return _name;
+    }
+    
+    public String getPackageName()
+    {
+    	return _parent.getName();
+    }
+    
+    /**
+     * Internal method used to send a schema request for this entity.
+     * 
+     * @throws Exception when the request cannot be sent.
+     */
+    void requestSchema() throws Exception
+    {     
+
+       	_objectName = JMX_SERVICE.createEntityDefinitionName(_parent.getName(), _name,_type);
+     	 JMX_SERVICE.registerEntityDefinition(_objectName,this,_parent.getName(),_name);
+
+    	try
+        {
+            _service.connect();
+           _service.requestSchema(_parent.getName(), _name, _hash);
+            _service.sync();
+        } finally
+        {
+            _service.close();
+        }                
+        
+      	 EntityLifecycleNotification notification = new EntityLifecycleNotification(
+          		 EntityLifecycleNotification.SCHEMA_REQUESTED_NOTIFICATION_TYPE,
+          		 _parent.getName(), 
+          		 _name, 
+          		 Names.CLASS,
+          		 _objectName);
+           sendNotification(notification);
+    }    
+}

Modified: qpid/branches/0.6-release/qpid/java/management/client/src/main/java/org/apache/qpid/management/wsdm/muse/engine/WSDMAdapterEnvironment.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.6-release/qpid/java/management/client/src/main/java/org/apache/qpid/management/wsdm/muse/engine/WSDMAdapterEnvironment.java?rev=909229&r1=909228&r2=909229&view=diff
==============================================================================
--- qpid/branches/0.6-release/qpid/java/management/client/src/main/java/org/apache/qpid/management/wsdm/muse/engine/WSDMAdapterEnvironment.java (original)
+++ qpid/branches/0.6-release/qpid/java/management/client/src/main/java/org/apache/qpid/management/wsdm/muse/engine/WSDMAdapterEnvironment.java Fri Feb 12 04:38:52 2010
@@ -1,97 +1,118 @@
-package org.apache.qpid.management.wsdm.muse.engine;
-
-import java.io.File;
-import java.net.URI;
-
-import javax.servlet.ServletContext;
-
-import org.apache.muse.core.AbstractEnvironment;
-import org.apache.muse.util.FileUtils;
-import org.apache.muse.ws.addressing.EndpointReference;
-import org.apache.qpid.management.Messages;
-import org.apache.qpid.management.Names;
-import org.apache.qpid.management.Protocol;
-import org.apache.qpid.transport.util.Logger;
-
-/**
- * QMan Adapter enviroment implementation.
- * 
- * @author Andrea Gazzarini
- */
-public class WSDMAdapterEnvironment  extends AbstractEnvironment
-{
-	private final static Logger LOGGER = Logger.get(WSDMAdapterEnvironment.class);
-	private final File _realDirectory;
-    private final ServletContext _servletContext;
-	
-    /**
-     * Builds a new qman environment with the given application context.
-     *  
-     * @param servletContext the application context. 
-     */
-    public WSDMAdapterEnvironment(ServletContext servletContext)
-    {
-    	this._servletContext = servletContext;
-    	String realDirectoryPath = servletContext.getRealPath(Names.WEB_APP_CLASSES_FOLDER);
-        
-        _realDirectory = (realDirectoryPath != null) 
-        	? new File(realDirectoryPath) 
-        	: FileUtils.CURRENT_DIR;
-        	
-        String defaultURI = getDefaultURIPrefix()+"adapter";
-        setDefaultURI(defaultURI);
-        
-        LOGGER.info(Messages.QMAN_000029_DEFAULT_URI, defaultURI);
-    }
-    
-    /**
-     * Returns the endpoint created starting by this application default URI.
-     * 
-     * @return the endpoint created starting by this application default URI.
-     */
-    public EndpointReference getDeploymentEPR()
-    {
-        return new EndpointReference(URI.create(getDefaultURI()));
-    }
-
-    /**
-     * Returns the application classes folder.
-     * 
-     * @return the application classes folder.
-     */
-    public File getRealDirectory()
-    {
-        return _realDirectory;
-    }
-    
-    /**
-     * Returns the default endpoint reference URI.
-     * 
-     * @return the default endpoint reference URI.
-     */
-    public String getDefaultURIPrefix()
-    {
-        return new StringBuilder()
-    		.append("http://")
-    		.append(System.getProperty(
-    				Names.ADAPTER_HOST_PROPERTY_NAME,
-    				Protocol.DEFAULT_QMAN_HOSTNAME))
-    		.append(":")
-    		.append(System.getProperty(
-    				Names.ADAPTER_PORT_PROPERTY_NAME,
-    				String.valueOf(Protocol.DEFAULT_QMAN_PORT_NUMBER)))
-    		.append(_servletContext.getContextPath())
-    		.append("/services/")
-    		.toString();    	
-    }
-    
-    /**
-     * Returns the context path name of QMan application.
-     * 
-     * @return the context path name of QMan application.
-     */
-    public String getContextPath()
-    {
-    	return _servletContext.getContextPath();
-    }
-}
\ No newline at end of file
+package org.apache.qpid.management.wsdm.muse.engine;
+/*
+ * 
+ * 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.
+ * 
+ */
+
+
+import java.io.File;
+import java.net.URI;
+
+import javax.servlet.ServletContext;
+
+import org.apache.muse.core.AbstractEnvironment;
+import org.apache.muse.util.FileUtils;
+import org.apache.muse.ws.addressing.EndpointReference;
+import org.apache.qpid.management.Messages;
+import org.apache.qpid.management.Names;
+import org.apache.qpid.management.Protocol;
+import org.apache.qpid.transport.util.Logger;
+
+/**
+ * QMan Adapter enviroment implementation.
+ * 
+ * @author Andrea Gazzarini
+ */
+public class WSDMAdapterEnvironment  extends AbstractEnvironment
+{
+	private final static Logger LOGGER = Logger.get(WSDMAdapterEnvironment.class);
+	private final File _realDirectory;
+    private final ServletContext _servletContext;
+	
+    /**
+     * Builds a new qman environment with the given application context.
+     *  
+     * @param servletContext the application context. 
+     */
+    public WSDMAdapterEnvironment(ServletContext servletContext)
+    {
+    	this._servletContext = servletContext;
+    	String realDirectoryPath = servletContext.getRealPath(Names.WEB_APP_CLASSES_FOLDER);
+        
+        _realDirectory = (realDirectoryPath != null) 
+        	? new File(realDirectoryPath) 
+        	: FileUtils.CURRENT_DIR;
+        	
+        String defaultURI = getDefaultURIPrefix()+"adapter";
+        setDefaultURI(defaultURI);
+        
+        LOGGER.info(Messages.QMAN_000029_DEFAULT_URI, defaultURI);
+    }
+    
+    /**
+     * Returns the endpoint created starting by this application default URI.
+     * 
+     * @return the endpoint created starting by this application default URI.
+     */
+    public EndpointReference getDeploymentEPR()
+    {
+        return new EndpointReference(URI.create(getDefaultURI()));
+    }
+
+    /**
+     * Returns the application classes folder.
+     * 
+     * @return the application classes folder.
+     */
+    public File getRealDirectory()
+    {
+        return _realDirectory;
+    }
+    
+    /**
+     * Returns the default endpoint reference URI.
+     * 
+     * @return the default endpoint reference URI.
+     */
+    public String getDefaultURIPrefix()
+    {
+        return new StringBuilder()
+    		.append("http://")
+    		.append(System.getProperty(
+    				Names.ADAPTER_HOST_PROPERTY_NAME,
+    				Protocol.DEFAULT_QMAN_HOSTNAME))
+    		.append(":")
+    		.append(System.getProperty(
+    				Names.ADAPTER_PORT_PROPERTY_NAME,
+    				String.valueOf(Protocol.DEFAULT_QMAN_PORT_NUMBER)))
+    		.append(_servletContext.getContextPath())
+    		.append("/services/")
+    		.toString();    	
+    }
+    
+    /**
+     * Returns the context path name of QMan application.
+     * 
+     * @return the context path name of QMan application.
+     */
+    public String getContextPath()
+    {
+    	return _servletContext.getContextPath();
+    }
+}

Modified: qpid/branches/0.6-release/qpid/java/management/client/src/main/java/org/apache/qpid/management/wsdm/muse/engine/WSDMAdapterIsolationLayer.java
URL: http://svn.apache.org/viewvc/qpid/branches/0.6-release/qpid/java/management/client/src/main/java/org/apache/qpid/management/wsdm/muse/engine/WSDMAdapterIsolationLayer.java?rev=909229&r1=909228&r2=909229&view=diff
==============================================================================
--- qpid/branches/0.6-release/qpid/java/management/client/src/main/java/org/apache/qpid/management/wsdm/muse/engine/WSDMAdapterIsolationLayer.java (original)
+++ qpid/branches/0.6-release/qpid/java/management/client/src/main/java/org/apache/qpid/management/wsdm/muse/engine/WSDMAdapterIsolationLayer.java Fri Feb 12 04:38:52 2010
@@ -1,36 +1,57 @@
-package org.apache.qpid.management.wsdm.muse.engine;
-
-import javax.servlet.ServletContext;
-
-import org.apache.muse.core.Environment;
-import org.apache.muse.core.platform.mini.MiniIsolationLayer;
-
-/**
- * QMan specific implementation of the Apache Muse isolation layer.
- * If you are a Muse expert you were wondering why don't we use the muse default implementation...
- * well, 
- *  
- * @author Andrea Gazzarini
- */
-public class WSDMAdapterIsolationLayer extends MiniIsolationLayer 
-{
-	/**
-	 * Builds a new isolation layer with the given application context.
-	 * 
-	 * @param initialContext the application context.
-	 */
-	public WSDMAdapterIsolationLayer(ServletContext initialContext) 
-	{
-		super(null, initialContext);
-	}
-
-	/**
-	 * WSDMAdapterEnvironment factory method.
-	 * 
-	 *  @return the environment.
-	 */
-	protected Environment createEnvironment() 
-	{
-		return new WSDMAdapterEnvironment(getInitialContext());
-	}
-}
\ No newline at end of file
+package org.apache.qpid.management.wsdm.muse.engine;
+/*
+ * 
+ * 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.
+ * 
+ */
+
+
+import javax.servlet.ServletContext;
+
+import org.apache.muse.core.Environment;
+import org.apache.muse.core.platform.mini.MiniIsolationLayer;
+
+/**
+ * QMan specific implementation of the Apache Muse isolation layer.
+ * If you are a Muse expert you were wondering why don't we use the muse default implementation...
+ * well, 
+ *  
+ * @author Andrea Gazzarini
+ */
+public class WSDMAdapterIsolationLayer extends MiniIsolationLayer 
+{
+	/**
+	 * Builds a new isolation layer with the given application context.
+	 * 
+	 * @param initialContext the application context.
+	 */
+	public WSDMAdapterIsolationLayer(ServletContext initialContext) 
+	{
+		super(null, initialContext);
+	}
+
+	/**
+	 * WSDMAdapterEnvironment factory method.
+	 * 
+	 *  @return the environment.
+	 */
+	protected Environment createEnvironment() 
+	{
+		return new WSDMAdapterEnvironment(getInitialContext());
+	}
+}

Modified: qpid/branches/0.6-release/qpid/java/management/client/src/main/java/router-entries/adapter/resource-instance-1.xml
URL: http://svn.apache.org/viewvc/qpid/branches/0.6-release/qpid/java/management/client/src/main/java/router-entries/adapter/resource-instance-1.xml?rev=909229&r1=909228&r2=909229&view=diff
==============================================================================
--- qpid/branches/0.6-release/qpid/java/management/client/src/main/java/router-entries/adapter/resource-instance-1.xml (original)
+++ qpid/branches/0.6-release/qpid/java/management/client/src/main/java/router-entries/adapter/resource-instance-1.xml Fri Feb 12 04:38:52 2010
@@ -1,2 +1,23 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+ 
+ 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.
+ 
+-->
+
 <wsa:ReferenceParameters xmlns:wsa="http://www.w3.org/2005/08/addressing"/>

Modified: qpid/branches/0.6-release/qpid/java/management/client/src/main/java/router-entries/consumer/resource-instance-1.xml
URL: http://svn.apache.org/viewvc/qpid/branches/0.6-release/qpid/java/management/client/src/main/java/router-entries/consumer/resource-instance-1.xml?rev=909229&r1=909228&r2=909229&view=diff
==============================================================================
--- qpid/branches/0.6-release/qpid/java/management/client/src/main/java/router-entries/consumer/resource-instance-1.xml (original)
+++ qpid/branches/0.6-release/qpid/java/management/client/src/main/java/router-entries/consumer/resource-instance-1.xml Fri Feb 12 04:38:52 2010
@@ -1,2 +1,23 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<wsa:ReferenceParameters xmlns:wsa="http://www.w3.org/2005/08/addressing"/>
\ No newline at end of file
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+ 
+ 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.
+ 
+-->
+
+<wsa:ReferenceParameters xmlns:wsa="http://www.w3.org/2005/08/addressing"/>

Modified: qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/SOAP-Envelope-1_2.xsd
URL: http://svn.apache.org/viewvc/qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/SOAP-Envelope-1_2.xsd?rev=909229&r1=909228&r2=909229&view=diff
==============================================================================
--- qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/SOAP-Envelope-1_2.xsd (original)
+++ qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/SOAP-Envelope-1_2.xsd Fri Feb 12 04:38:52 2010
@@ -1,160 +1,181 @@
-<?xml version="1.0"?>
-
-<!-- Schema defined in the SOAP Version 1.2 Part 1 specification
-     Proposed Recommendation:
-     http://www.w3.org/TR/2003/PR-soap12-part1-20030507/
-     $Id: SOAP-Envelope-1_2.xsd,v 1.1 2006/05/07 19:09:15 danjemiolo Exp $
-
-     Copyright (C)2003 W3C(R) (MIT, ERCIM, Keio), All Rights Reserved.
-     W3C viability, trademark, document use and software licensing rules
-     apply.
-     http://www.w3.org/Consortium/Legal/
-
-     This document is governed by the W3C Software License [1] as
-     described in the FAQ [2].
-
-     [1] http://www.w3.org/Consortium/Legal/copyright-software-19980720
-     [2] http://www.w3.org/Consortium/Legal/IPR-FAQ-20000620.html#DTD
--->
-
-<xs:schema xmlns:xs="http://www.w3.org/2001/XMLSchema"
-  xmlns:tns="http://www.w3.org/2003/05/soap-envelope"
-  targetNamespace="http://www.w3.org/2003/05/soap-envelope"
-  elementFormDefault="qualified">
-
-  <xs:import namespace="http://www.w3.org/XML/1998/namespace" 
-             schemaLocation="XML-Namespace-1998.xsd"/>
-
-  <!-- Envelope, header and body -->
-  <xs:element name="Envelope" type="tns:Envelope"/>
-  <xs:complexType name="Envelope">
-    <xs:sequence>
-      <xs:element ref="tns:Header" minOccurs="0"/>
-      <xs:element ref="tns:Body" minOccurs="1"/>
-    </xs:sequence>
-    <xs:anyAttribute namespace="##other" processContents="lax"/>
-  </xs:complexType>
-
-  <xs:element name="Header" type="tns:Header"/>
-  <xs:complexType name="Header">
-    <xs:annotation>
-      <xs:documentation>
-	  Elements replacing the wildcard MUST be namespace qualified, but can be in the targetNamespace
-      </xs:documentation>
-    </xs:annotation>
-    <xs:sequence>
-      <xs:any namespace="##any" processContents="lax" minOccurs="0" maxOccurs="unbounded"/>
-    </xs:sequence>
-    <xs:anyAttribute namespace="##other" processContents="lax"/>
-  </xs:complexType>
-
-  <xs:element name="Body" type="tns:Body"/>
-  <xs:complexType name="Body">
-    <xs:sequence>
-      <xs:any namespace="##any" processContents="lax" minOccurs="0" maxOccurs="unbounded"/>
-    </xs:sequence>
-    <xs:anyAttribute namespace="##other" processContents="lax"/>
-  </xs:complexType>
-
-  <!-- Global Attributes.  The following attributes are intended to be
-  usable via qualified attribute names on any complex type referencing
-  them.  -->
-  <xs:attribute name="mustUnderstand" type="xs:boolean" default="0"/>
-  <xs:attribute name="relay" type="xs:boolean" default="0"/>
-  <xs:attribute name="role" type="xs:anyURI"/>
-
-  <!-- 'encodingStyle' indicates any canonicalization conventions
-  followed in the contents of the containing element.  For example, the
-  value 'http://www.w3.org/2003/05/soap-encoding' indicates the pattern
-  described in the last call working draft of SOAP Version 1.2 Part 2:
-  Adjuncts -->
-
-  <xs:attribute name="encodingStyle" type="xs:anyURI"/>
-
-  <xs:element name="Fault" type="tns:Fault"/>
-  <xs:complexType name="Fault" final="extension">
-    <xs:annotation>
-      <xs:documentation>
-	    Fault reporting structure
-      </xs:documentation>
-    </xs:annotation>
-    <xs:sequence>
-      <xs:element name="Code" type="tns:faultcode"/>
-      <xs:element name="Reason" type="tns:faultreason"/>
-      <xs:element name="Node" type="xs:anyURI" minOccurs="0"/>
-      <xs:element name="Role" type="xs:anyURI" minOccurs="0"/>
-      <xs:element name="Detail" type="tns:detail" minOccurs="0"/>
-    </xs:sequence>
-  </xs:complexType>
-
-  <xs:complexType name="faultreason">
-    <xs:sequence>
-      <xs:element name="Text" type="tns:reasontext"
-        minOccurs="1" maxOccurs="unbounded"/>
-    </xs:sequence>
-  </xs:complexType>
-
-  <xs:complexType name="reasontext">
-    <xs:simpleContent>
-      <xs:extension base="xs:string">
-        <xs:attribute ref="xml:lang" use="required"/>
-      </xs:extension>
-    </xs:simpleContent>
-  </xs:complexType>
-
-  <xs:complexType name="faultcode">
-    <xs:sequence>
-      <xs:element name="Value"
-        type="tns:faultcodeEnum"/>
-      <xs:element name="Subcode"
-        type="tns:subcode"
-        minOccurs="0"/>
-    </xs:sequence>
-  </xs:complexType>
-
-  <xs:simpleType name="faultcodeEnum">
-    <xs:restriction base="xs:QName">
-      <xs:enumeration value="tns:DataEncodingUnknown"/>
-      <xs:enumeration value="tns:MustUnderstand"/>
-      <xs:enumeration value="tns:Receiver"/>
-      <xs:enumeration value="tns:Sender"/>
-      <xs:enumeration value="tns:VersionMismatch"/>
-    </xs:restriction>
-  </xs:simpleType>
-
-  <xs:complexType name="subcode">
-    <xs:sequence>
-      <xs:element name="Value"
-        type="xs:QName"/>
-      <xs:element name="Subcode"
-        type="tns:subcode"
-        minOccurs="0"/>
-    </xs:sequence>
-  </xs:complexType>
-
-  <xs:complexType name="detail">
-    <xs:sequence>
-      <xs:any namespace="##any" processContents="lax" minOccurs="0" maxOccurs="unbounded"/>
-    </xs:sequence>
-    <xs:anyAttribute namespace="##other" processContents="lax"/>
-  </xs:complexType>
-
-  <!-- Global element declaration and complex type definition for header entry returned due to a mustUnderstand fault -->
-  <xs:element name="NotUnderstood" type="tns:NotUnderstoodType"/>
-  <xs:complexType name="NotUnderstoodType">
-    <xs:attribute name="qname" type="xs:QName" use="required"/>
-  </xs:complexType>
-
-  <!-- Global element and associated types for managing version transition as described in Appendix A of the SOAP Version 1.2 Part 1 Last Call Working Draft -->
-  <xs:complexType name="SupportedEnvType">
-    <xs:attribute name="qname" type="xs:QName" use="required"/>
-  </xs:complexType>
-
-  <xs:element name="Upgrade" type="tns:UpgradeType"/>
-  <xs:complexType name="UpgradeType">
-    <xs:sequence>
-      <xs:element name="SupportedEnvelope" type="tns:SupportedEnvType" minOccurs="1" maxOccurs="unbounded"/>
-    </xs:sequence>
-  </xs:complexType>
-
-</xs:schema>
+<?xml version="1.0"?>
+<!--
+ 
+ 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.
+ 
+-->
+
+
+<!-- Schema defined in the SOAP Version 1.2 Part 1 specification
+     Proposed Recommendation:
+     http://www.w3.org/TR/2003/PR-soap12-part1-20030507/
+     $Id: SOAP-Envelope-1_2.xsd,v 1.1 2006/05/07 19:09:15 danjemiolo Exp $
+
+     Copyright (C)2003 W3C(R) (MIT, ERCIM, Keio), All Rights Reserved.
+     W3C viability, trademark, document use and software licensing rules
+     apply.
+     http://www.w3.org/Consortium/Legal/
+
+     This document is governed by the W3C Software License [1] as
+     described in the FAQ [2].
+
+     [1] http://www.w3.org/Consortium/Legal/copyright-software-19980720
+     [2] http://www.w3.org/Consortium/Legal/IPR-FAQ-20000620.html#DTD
+-->
+
+<xs:schema xmlns:xs="http://www.w3.org/2001/XMLSchema"
+  xmlns:tns="http://www.w3.org/2003/05/soap-envelope"
+  targetNamespace="http://www.w3.org/2003/05/soap-envelope"
+  elementFormDefault="qualified">
+
+  <xs:import namespace="http://www.w3.org/XML/1998/namespace" 
+             schemaLocation="XML-Namespace-1998.xsd"/>
+
+  <!-- Envelope, header and body -->
+  <xs:element name="Envelope" type="tns:Envelope"/>
+  <xs:complexType name="Envelope">
+    <xs:sequence>
+      <xs:element ref="tns:Header" minOccurs="0"/>
+      <xs:element ref="tns:Body" minOccurs="1"/>
+    </xs:sequence>
+    <xs:anyAttribute namespace="##other" processContents="lax"/>
+  </xs:complexType>
+
+  <xs:element name="Header" type="tns:Header"/>
+  <xs:complexType name="Header">
+    <xs:annotation>
+      <xs:documentation>
+	  Elements replacing the wildcard MUST be namespace qualified, but can be in the targetNamespace
+      </xs:documentation>
+    </xs:annotation>
+    <xs:sequence>
+      <xs:any namespace="##any" processContents="lax" minOccurs="0" maxOccurs="unbounded"/>
+    </xs:sequence>
+    <xs:anyAttribute namespace="##other" processContents="lax"/>
+  </xs:complexType>
+
+  <xs:element name="Body" type="tns:Body"/>
+  <xs:complexType name="Body">
+    <xs:sequence>
+      <xs:any namespace="##any" processContents="lax" minOccurs="0" maxOccurs="unbounded"/>
+    </xs:sequence>
+    <xs:anyAttribute namespace="##other" processContents="lax"/>
+  </xs:complexType>
+
+  <!-- Global Attributes.  The following attributes are intended to be
+  usable via qualified attribute names on any complex type referencing
+  them.  -->
+  <xs:attribute name="mustUnderstand" type="xs:boolean" default="0"/>
+  <xs:attribute name="relay" type="xs:boolean" default="0"/>
+  <xs:attribute name="role" type="xs:anyURI"/>
+
+  <!-- 'encodingStyle' indicates any canonicalization conventions
+  followed in the contents of the containing element.  For example, the
+  value 'http://www.w3.org/2003/05/soap-encoding' indicates the pattern
+  described in the last call working draft of SOAP Version 1.2 Part 2:
+  Adjuncts -->
+
+  <xs:attribute name="encodingStyle" type="xs:anyURI"/>
+
+  <xs:element name="Fault" type="tns:Fault"/>
+  <xs:complexType name="Fault" final="extension">
+    <xs:annotation>
+      <xs:documentation>
+	    Fault reporting structure
+      </xs:documentation>
+    </xs:annotation>
+    <xs:sequence>
+      <xs:element name="Code" type="tns:faultcode"/>
+      <xs:element name="Reason" type="tns:faultreason"/>
+      <xs:element name="Node" type="xs:anyURI" minOccurs="0"/>
+      <xs:element name="Role" type="xs:anyURI" minOccurs="0"/>
+      <xs:element name="Detail" type="tns:detail" minOccurs="0"/>
+    </xs:sequence>
+  </xs:complexType>
+
+  <xs:complexType name="faultreason">
+    <xs:sequence>
+      <xs:element name="Text" type="tns:reasontext"
+        minOccurs="1" maxOccurs="unbounded"/>
+    </xs:sequence>
+  </xs:complexType>
+
+  <xs:complexType name="reasontext">
+    <xs:simpleContent>
+      <xs:extension base="xs:string">
+        <xs:attribute ref="xml:lang" use="required"/>
+      </xs:extension>
+    </xs:simpleContent>
+  </xs:complexType>
+
+  <xs:complexType name="faultcode">
+    <xs:sequence>
+      <xs:element name="Value"
+        type="tns:faultcodeEnum"/>
+      <xs:element name="Subcode"
+        type="tns:subcode"
+        minOccurs="0"/>
+    </xs:sequence>
+  </xs:complexType>
+
+  <xs:simpleType name="faultcodeEnum">
+    <xs:restriction base="xs:QName">
+      <xs:enumeration value="tns:DataEncodingUnknown"/>
+      <xs:enumeration value="tns:MustUnderstand"/>
+      <xs:enumeration value="tns:Receiver"/>
+      <xs:enumeration value="tns:Sender"/>
+      <xs:enumeration value="tns:VersionMismatch"/>
+    </xs:restriction>
+  </xs:simpleType>
+
+  <xs:complexType name="subcode">
+    <xs:sequence>
+      <xs:element name="Value"
+        type="xs:QName"/>
+      <xs:element name="Subcode"
+        type="tns:subcode"
+        minOccurs="0"/>
+    </xs:sequence>
+  </xs:complexType>
+
+  <xs:complexType name="detail">
+    <xs:sequence>
+      <xs:any namespace="##any" processContents="lax" minOccurs="0" maxOccurs="unbounded"/>
+    </xs:sequence>
+    <xs:anyAttribute namespace="##other" processContents="lax"/>
+  </xs:complexType>
+
+  <!-- Global element declaration and complex type definition for header entry returned due to a mustUnderstand fault -->
+  <xs:element name="NotUnderstood" type="tns:NotUnderstoodType"/>
+  <xs:complexType name="NotUnderstoodType">
+    <xs:attribute name="qname" type="xs:QName" use="required"/>
+  </xs:complexType>
+
+  <!-- Global element and associated types for managing version transition as described in Appendix A of the SOAP Version 1.2 Part 1 Last Call Working Draft -->
+  <xs:complexType name="SupportedEnvType">
+    <xs:attribute name="qname" type="xs:QName" use="required"/>
+  </xs:complexType>
+
+  <xs:element name="Upgrade" type="tns:UpgradeType"/>
+  <xs:complexType name="UpgradeType">
+    <xs:sequence>
+      <xs:element name="SupportedEnvelope" type="tns:SupportedEnvType" minOccurs="1" maxOccurs="unbounded"/>
+    </xs:sequence>
+  </xs:complexType>
+
+</xs:schema>

Modified: qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/WS-Addressing-2005_08.xsd
URL: http://svn.apache.org/viewvc/qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/WS-Addressing-2005_08.xsd?rev=909229&r1=909228&r2=909229&view=diff
==============================================================================
--- qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/WS-Addressing-2005_08.xsd (original)
+++ qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/WS-Addressing-2005_08.xsd Fri Feb 12 04:38:52 2010
@@ -1,22 +1,43 @@
 <?xml version="1.0" encoding="utf-8"?>
-<xs:schema 
-	targetNamespace="http://www.w3.org/2005/08/addressing" 
-	xmlns:xs="http://www.w3.org/2001/XMLSchema"
-	xmlns:tns="http://www.w3.org/2005/08/addressing" 
-	elementFormDefault="qualified" 
+<!--
+ 
+ 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.
+ 
+-->
+
+<xs:schema 
+	targetNamespace="http://www.w3.org/2005/08/addressing" 
+	xmlns:xs="http://www.w3.org/2001/XMLSchema"
+	xmlns:tns="http://www.w3.org/2005/08/addressing" 
+	elementFormDefault="qualified" 
 	attributeFormDefault="unqualified">
 
 	<!-- Constructs from the WS-Addressing Core -->
 
-	<xs:element name="EndpointReference"
+	<xs:element name="EndpointReference"
 		type="tns:EndpointReferenceType" />
 	<xs:complexType name="EndpointReferenceType" mixed="false">
 		<xs:sequence>
 			<xs:element name="Address" type="tns:AttributedURIType" />
-			<xs:element name="ReferenceParameters"
+			<xs:element name="ReferenceParameters"
 				type="tns:ReferenceParametersType" minOccurs="0" />
 			<xs:element ref="tns:Metadata" minOccurs="0" />
-			<xs:any namespace="##other" processContents="lax"
+			<xs:any namespace="##other" processContents="lax"
 				minOccurs="0" maxOccurs="unbounded" />
 		</xs:sequence>
 		<xs:anyAttribute namespace="##other" processContents="lax" />
@@ -24,7 +45,7 @@
 
 	<xs:complexType name="ReferenceParametersType" mixed="false">
 		<xs:sequence>
-			<xs:any namespace="##any" processContents="lax"
+			<xs:any namespace="##any" processContents="lax"
 				minOccurs="0" maxOccurs="unbounded" />
 		</xs:sequence>
 		<xs:anyAttribute namespace="##other" processContents="lax" />
@@ -33,7 +54,7 @@
 	<xs:element name="Metadata" type="tns:MetadataType" />
 	<xs:complexType name="MetadataType" mixed="false">
 		<xs:sequence>
-			<xs:any namespace="##any" processContents="lax"
+			<xs:any namespace="##any" processContents="lax"
 				minOccurs="0" maxOccurs="unbounded" />
 		</xs:sequence>
 		<xs:anyAttribute namespace="##other" processContents="lax" />
@@ -44,10 +65,10 @@
 	<xs:complexType name="RelatesToType" mixed="false">
 		<xs:simpleContent>
 			<xs:extension base="xs:anyURI">
-				<xs:attribute name="RelationshipType"
-					type="tns:RelationshipTypeOpenEnum" use="optional"
+				<xs:attribute name="RelationshipType"
+					type="tns:RelationshipTypeOpenEnum" use="optional"
 					default="http://www.w3.org/2005/08/addressing/reply" />
-				<xs:anyAttribute namespace="##other"
+				<xs:anyAttribute namespace="##other"
 					processContents="lax" />
 			</xs:extension>
 		</xs:simpleContent>
@@ -59,7 +80,7 @@
 
 	<xs:simpleType name="RelationshipType">
 		<xs:restriction base="xs:anyURI">
-			<xs:enumeration
+			<xs:enumeration
 				value="http://www.w3.org/2005/08/addressing/reply" />
 		</xs:restriction>
 	</xs:simpleType>
@@ -73,7 +94,7 @@
 	<xs:complexType name="AttributedURIType" mixed="false">
 		<xs:simpleContent>
 			<xs:extension base="xs:anyURI">
-				<xs:anyAttribute namespace="##other"
+				<xs:anyAttribute namespace="##other"
 					processContents="lax" />
 			</xs:extension>
 		</xs:simpleContent>
@@ -107,18 +128,18 @@
 	<xs:complexType name="AttributedUnsignedLongType" mixed="false">
 		<xs:simpleContent>
 			<xs:extension base="xs:unsignedLong">
-				<xs:anyAttribute namespace="##other"
+				<xs:anyAttribute namespace="##other"
 					processContents="lax" />
 			</xs:extension>
 		</xs:simpleContent>
 	</xs:complexType>
 
-	<xs:element name="ProblemHeaderQName"
+	<xs:element name="ProblemHeaderQName"
 		type="tns:AttributedQNameType" />
 	<xs:complexType name="AttributedQNameType" mixed="false">
 		<xs:simpleContent>
 			<xs:extension base="xs:QName">
-				<xs:anyAttribute namespace="##other"
+				<xs:anyAttribute namespace="##other"
 					processContents="lax" />
 			</xs:extension>
 		</xs:simpleContent>
@@ -127,7 +148,7 @@
 	<xs:element name="ProblemHeader" type="tns:AttributedAnyType" />
 	<xs:complexType name="AttributedAnyType" mixed="false">
 		<xs:sequence>
-			<xs:any namespace="##any" processContents="lax"
+			<xs:any namespace="##any" processContents="lax"
 				minOccurs="1" maxOccurs="1" />
 		</xs:sequence>
 		<xs:anyAttribute namespace="##other" processContents="lax" />
@@ -139,7 +160,7 @@
 	<xs:complexType name="ProblemActionType" mixed="false">
 		<xs:sequence>
 			<xs:element ref="tns:Action" minOccurs="0" />
-			<xs:element name="SoapAction" minOccurs="0"
+			<xs:element name="SoapAction" minOccurs="0"
 				type="xs:anyURI" />
 		</xs:sequence>
 		<xs:anyAttribute namespace="##other" processContents="lax" />

Modified: qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/WS-MetadataExchange-2004_09.xsd
URL: http://svn.apache.org/viewvc/qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/WS-MetadataExchange-2004_09.xsd?rev=909229&r1=909228&r2=909229&view=diff
==============================================================================
--- qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/WS-MetadataExchange-2004_09.xsd (original)
+++ qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/WS-MetadataExchange-2004_09.xsd Fri Feb 12 04:38:52 2010
@@ -1,113 +1,134 @@
-<?xml version='1.0' encoding='UTF-8' ?>
-<!--
-(c) 2004 BEA Systems Inc., Computer Associates International, Inc.,
-International Business Machines Corporation, Microsoft Corporation,
-Inc., SAP AG, Sun Microsystems, and webMethods. All rights reserved. 
-
-Permission to copy and display the WS-MetadataExchange Specification
-(the "Specification"), in any medium without fee or royalty is hereby
-granted, provided that you include the following on ALL copies of the
-Specification that you make:
-
-1.	A link or URL to the Specification at this location.
-2.	The copyright notice as shown in the Specification.
-
-BEA Systems, Computer Associates, IBM, Microsoft, SAP, Sun, and
-webMethods (collectively, the "Authors") each agree to grant you a
-license, under royalty-free and otherwise reasonable,
-non-discriminatory terms and conditions, to their respective essential
-patent claims that they deem necessary to implement the
-WS-MetadataExchange Specification.
-
-THE SPECIFICATION IS PROVIDED "AS IS," AND THE AUTHORS MAKE NO
-REPRESENTATIONS OR WARRANTIES, EXPRESS OR IMPLIED, INCLUDING, BUT NOT
-LIMITED TO, WARRANTIES OF MERCHANTABILITY, FITNESS FOR A PARTICULAR
-PURPOSE, NON-INFRINGEMENT, OR TITLE; THAT THE CONTENTS OF THE
-SPECIFICATION ARE SUITABLE FOR ANY PURPOSE; NOR THAT THE
-IMPLEMENTATION OF SUCH CONTENTS WILL NOT INFRINGE ANY THIRD PARTY
-PATENTS, COPYRIGHTS, TRADEMARKS OR OTHER RIGHTS.
-
-THE AUTHORS WILL NOT BE LIABLE FOR ANY DIRECT, INDIRECT, SPECIAL,
-INCIDENTAL OR CONSEQUENTIAL DAMAGES ARISING OUT OF OR RELATING TO ANY
-USE OR DISTRIBUTION OF THE SPECIFICATIONS.
-
-The name and trademarks of the Authors may NOT be used in any manner,
-including advertising or publicity pertaining to the Specifications or
-their contents without specific, written prior permission. Title to
-copyright in the Specifications will at all times remain with the
-Authors.
-
-No other rights are granted by implication, estoppel or otherwise.
--->
-
-<xs:schema
-    targetNamespace="http://schemas.xmlsoap.org/ws/2004/09/mex" 
-    xmlns:tns="http://schemas.xmlsoap.org/ws/2004/09/mex" 
-    xmlns:wsa="http://www.w3.org/2005/08/addressing" 
-    xmlns:xs="http://www.w3.org/2001/XMLSchema" 
-    elementFormDefault="qualified" >
-
-  <xs:import
-      namespace="http://www.w3.org/2005/08/addressing" 
-      schemaLocation="WS-Addressing-2005_08.xsd" />
-
-  <!-- Get Metadata request -->
-  <xs:element name='GetMetadata' >
-    <xs:complexType>
-      <xs:sequence>
-        <xs:element ref='tns:Dialect' minOccurs='0' />
-        <xs:element ref='tns:Identifier' minOccurs='0' />
-      </xs:sequence>
-      <xs:anyAttribute namespace='##other' processContents='lax' />
-    </xs:complexType>
-  </xs:element>
-
-  <xs:element name='Dialect' type='xs:anyURI' />
-  <xs:element name='Identifier' type='xs:anyURI' />
-
-  <!-- Get Metadata response -->
-  <xs:element name='Metadata' >
-    <xs:complexType>
-      <xs:sequence>
-        <xs:element ref='tns:MetadataSection'
-                    minOccurs='0'
-                    maxOccurs='unbounded' />
-      </xs:sequence>
-      <xs:anyAttribute namespace='##other' processContents='lax' />
-    </xs:complexType>
-  </xs:element>
-
-  <xs:element name='MetadataSection' >
-    <xs:complexType>
-      <xs:choice>
-        <xs:any namespace='##other'
-                processContents='lax'
-                minOccurs='0'
-                maxOccurs='unbounded' />
-        <xs:element ref='tns:MetadataReference' />
-        <xs:element ref='tns:Location' />
-      </xs:choice>
-      <xs:attribute name='Dialect' type='xs:anyURI' use='required' />
-      <xs:attribute name='Identifier' type='xs:anyURI' />
-      <xs:anyAttribute namespace='##other' processContents='lax' />
-    </xs:complexType>
-  </xs:element>
-
-  <xs:element name='MetadataReference'
-              type='wsa:EndpointReferenceType' />
-
-  <xs:element name='Location'
-              type='xs:anyURI' />
-
-  <!-- count(/s:Envelope/s:Body/*) = 0 for Get request -->
-
-  <!-- Get Response returns xs:any -->
-
-  <xs:complexType name='AnyXmlType' >
-    <xs:sequence>
-      <xs:any namespace='##any' processContents='lax' />
-    </xs:sequence>
-    <xs:anyAttribute namespace='##any' processContents='lax' />
-  </xs:complexType>
-
-</xs:schema>
+<?xml version='1.0' encoding='UTF-8' ?>
+<!--
+ 
+ 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.
+ 
+-->
+
+<!--
+(c) 2004 BEA Systems Inc., Computer Associates International, Inc.,
+International Business Machines Corporation, Microsoft Corporation,
+Inc., SAP AG, Sun Microsystems, and webMethods. All rights reserved. 
+
+Permission to copy and display the WS-MetadataExchange Specification
+(the "Specification"), in any medium without fee or royalty is hereby
+granted, provided that you include the following on ALL copies of the
+Specification that you make:
+
+1.	A link or URL to the Specification at this location.
+2.	The copyright notice as shown in the Specification.
+
+BEA Systems, Computer Associates, IBM, Microsoft, SAP, Sun, and
+webMethods (collectively, the "Authors") each agree to grant you a
+license, under royalty-free and otherwise reasonable,
+non-discriminatory terms and conditions, to their respective essential
+patent claims that they deem necessary to implement the
+WS-MetadataExchange Specification.
+
+THE SPECIFICATION IS PROVIDED "AS IS," AND THE AUTHORS MAKE NO
+REPRESENTATIONS OR WARRANTIES, EXPRESS OR IMPLIED, INCLUDING, BUT NOT
+LIMITED TO, WARRANTIES OF MERCHANTABILITY, FITNESS FOR A PARTICULAR
+PURPOSE, NON-INFRINGEMENT, OR TITLE; THAT THE CONTENTS OF THE
+SPECIFICATION ARE SUITABLE FOR ANY PURPOSE; NOR THAT THE
+IMPLEMENTATION OF SUCH CONTENTS WILL NOT INFRINGE ANY THIRD PARTY
+PATENTS, COPYRIGHTS, TRADEMARKS OR OTHER RIGHTS.
+
+THE AUTHORS WILL NOT BE LIABLE FOR ANY DIRECT, INDIRECT, SPECIAL,
+INCIDENTAL OR CONSEQUENTIAL DAMAGES ARISING OUT OF OR RELATING TO ANY
+USE OR DISTRIBUTION OF THE SPECIFICATIONS.
+
+The name and trademarks of the Authors may NOT be used in any manner,
+including advertising or publicity pertaining to the Specifications or
+their contents without specific, written prior permission. Title to
+copyright in the Specifications will at all times remain with the
+Authors.
+
+No other rights are granted by implication, estoppel or otherwise.
+-->
+
+<xs:schema
+    targetNamespace="http://schemas.xmlsoap.org/ws/2004/09/mex" 
+    xmlns:tns="http://schemas.xmlsoap.org/ws/2004/09/mex" 
+    xmlns:wsa="http://www.w3.org/2005/08/addressing" 
+    xmlns:xs="http://www.w3.org/2001/XMLSchema" 
+    elementFormDefault="qualified" >
+
+  <xs:import
+      namespace="http://www.w3.org/2005/08/addressing" 
+      schemaLocation="WS-Addressing-2005_08.xsd" />
+
+  <!-- Get Metadata request -->
+  <xs:element name='GetMetadata' >
+    <xs:complexType>
+      <xs:sequence>
+        <xs:element ref='tns:Dialect' minOccurs='0' />
+        <xs:element ref='tns:Identifier' minOccurs='0' />
+      </xs:sequence>
+      <xs:anyAttribute namespace='##other' processContents='lax' />
+    </xs:complexType>
+  </xs:element>
+
+  <xs:element name='Dialect' type='xs:anyURI' />
+  <xs:element name='Identifier' type='xs:anyURI' />
+
+  <!-- Get Metadata response -->
+  <xs:element name='Metadata' >
+    <xs:complexType>
+      <xs:sequence>
+        <xs:element ref='tns:MetadataSection'
+                    minOccurs='0'
+                    maxOccurs='unbounded' />
+      </xs:sequence>
+      <xs:anyAttribute namespace='##other' processContents='lax' />
+    </xs:complexType>
+  </xs:element>
+
+  <xs:element name='MetadataSection' >
+    <xs:complexType>
+      <xs:choice>
+        <xs:any namespace='##other'
+                processContents='lax'
+                minOccurs='0'
+                maxOccurs='unbounded' />
+        <xs:element ref='tns:MetadataReference' />
+        <xs:element ref='tns:Location' />
+      </xs:choice>
+      <xs:attribute name='Dialect' type='xs:anyURI' use='required' />
+      <xs:attribute name='Identifier' type='xs:anyURI' />
+      <xs:anyAttribute namespace='##other' processContents='lax' />
+    </xs:complexType>
+  </xs:element>
+
+  <xs:element name='MetadataReference'
+              type='wsa:EndpointReferenceType' />
+
+  <xs:element name='Location'
+              type='xs:anyURI' />
+
+  <!-- count(/s:Envelope/s:Body/*) = 0 for Get request -->
+
+  <!-- Get Response returns xs:any -->
+
+  <xs:complexType name='AnyXmlType' >
+    <xs:sequence>
+      <xs:any namespace='##any' processContents='lax' />
+    </xs:sequence>
+    <xs:anyAttribute namespace='##any' processContents='lax' />
+  </xs:complexType>
+
+</xs:schema>

Modified: qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/WSDM-MUWS-Part1-1_1.xsd
URL: http://svn.apache.org/viewvc/qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/WSDM-MUWS-Part1-1_1.xsd?rev=909229&r1=909228&r2=909229&view=diff
==============================================================================
--- qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/WSDM-MUWS-Part1-1_1.xsd (original)
+++ qpid/branches/0.6-release/qpid/java/management/client/src/main/java/wsdl/WSDM-MUWS-Part1-1_1.xsd Fri Feb 12 04:38:52 2010
@@ -1,93 +1,114 @@
-<?xml version="1.0" encoding="utf-8"?>
-<xs:schema
-    targetNamespace="http://docs.oasis-open.org/wsdm/muws1-2.xsd"	
-    xmlns:muws1="http://docs.oasis-open.org/wsdm/muws1-2.xsd"
-    xmlns:wsa="http://www.w3.org/2005/08/addressing"
-    xmlns:xs="http://www.w3.org/2001/XMLSchema"
-    elementFormDefault="qualified" attributeFormDefault="unqualified">
-
-    <xs:import namespace="http://www.w3.org/2005/08/addressing"
-             schemaLocation="WS-Addressing-2005_08.xsd"/>
-
-
-  <xs:element name="ResourceId" type="xs:anyURI"/>
-  <xs:element name="ManageabilityCapability" type="xs:anyURI"/>
-
-
-  <xs:complexType name="CorrelatablePropertiesType">
-    <xs:sequence>
-      <xs:any minOccurs="0" maxOccurs="unbounded"
-              namespace="##other" processContents="lax"/>
-    </xs:sequence>
-    <xs:attribute name="Dialect" type="xs:anyURI"/>
-    <xs:attribute name="NegativeAssertionPossible" type="xs:boolean"/>
-    <xs:anyAttribute namespace="##other"/>
-  </xs:complexType>
-
-  <xs:element name="CorrelatableProperties"
-              type="muws1:CorrelatablePropertiesType"/>
-
- 
-  <xs:complexType name="ComponentAddressType">
-    <xs:sequence>
-      <xs:any namespace="##any" processContents="lax"/>
-    </xs:sequence>
-  </xs:complexType>
-
-  <xs:complexType name="ComponentType">
-    <xs:sequence>
-      <xs:element name="ResourceId" type="xs:anyURI"
-                  minOccurs="0"/>
-      <xs:element name="ComponentAddress"
-                  type="muws1:ComponentAddressType"
-                  minOccurs="0" maxOccurs="unbounded"/>
-      <xs:any minOccurs="0" maxOccurs="unbounded"
-              namespace="##other" processContents="lax"/>
-    </xs:sequence>
-    <xs:anyAttribute namespace="##other"/>
-  </xs:complexType>
-
-   
-  <xs:complexType name="ManagementEventType">
-    <xs:sequence>
-      <xs:element name="EventId" type="xs:anyURI"/>
-      <xs:element name="SourceComponent" type="muws1:ComponentType"/>
-      <xs:element name="ReporterComponent" type="muws1:ComponentType"
-                  minOccurs="0"/>
-      <xs:any minOccurs="0" maxOccurs="unbounded"
-              namespace="##other" processContents="lax"/>
-    </xs:sequence>
-    <xs:attribute name="ReportTime" type="xs:dateTime" use="optional"/>
-    <xs:anyAttribute namespace="##other"/>
-  </xs:complexType>
-
-  <xs:element name="ManagementEvent" 
-              type="muws1:ManagementEventType"/>
-
-  <xs:element name="ManageabilityEndpointReference"
-              type="wsa:EndpointReferenceType"/>
-
-
-<!--   
-                                       SCHEMA COPY Material
-Copy and paste element references below into the schema of a resource properties document.
-These references are provide to insure that the correct minOccurs/maxOccurs attributes are specified in a resource property document schema.
-
-NOTE: You must import the MUWS Part 1 schema namespace (MUWS1).
-
-        **    Identity Properties    **
-          <xs:element ref="muws1:ResourceId"/>
-
-
-        **    ManageabilityCharacteristics Properties    **
-          <xs:element ref="muws1:ManageabilityCapability"
-                      minOccurs="0" maxOccurs="unbounded"/>
-
-        **    Correlatable Properties    **
-          <xs:element ref="muws1:CorrelatableProperties"
-                      minOccurs="0" maxOccurs="unbounded"/>
-
--->
-
-</xs:schema>
-
+<?xml version="1.0" encoding="utf-8"?>
+<!--
+ 
+ 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.
+ 
+-->
+
+<xs:schema
+    targetNamespace="http://docs.oasis-open.org/wsdm/muws1-2.xsd"	
+    xmlns:muws1="http://docs.oasis-open.org/wsdm/muws1-2.xsd"
+    xmlns:wsa="http://www.w3.org/2005/08/addressing"
+    xmlns:xs="http://www.w3.org/2001/XMLSchema"
+    elementFormDefault="qualified" attributeFormDefault="unqualified">
+
+    <xs:import namespace="http://www.w3.org/2005/08/addressing"
+             schemaLocation="WS-Addressing-2005_08.xsd"/>
+
+
+  <xs:element name="ResourceId" type="xs:anyURI"/>
+  <xs:element name="ManageabilityCapability" type="xs:anyURI"/>
+
+
+  <xs:complexType name="CorrelatablePropertiesType">
+    <xs:sequence>
+      <xs:any minOccurs="0" maxOccurs="unbounded"
+              namespace="##other" processContents="lax"/>
+    </xs:sequence>
+    <xs:attribute name="Dialect" type="xs:anyURI"/>
+    <xs:attribute name="NegativeAssertionPossible" type="xs:boolean"/>
+    <xs:anyAttribute namespace="##other"/>
+  </xs:complexType>
+
+  <xs:element name="CorrelatableProperties"
+              type="muws1:CorrelatablePropertiesType"/>
+
+ 
+  <xs:complexType name="ComponentAddressType">
+    <xs:sequence>
+      <xs:any namespace="##any" processContents="lax"/>
+    </xs:sequence>
+  </xs:complexType>
+
+  <xs:complexType name="ComponentType">
+    <xs:sequence>
+      <xs:element name="ResourceId" type="xs:anyURI"
+                  minOccurs="0"/>
+      <xs:element name="ComponentAddress"
+                  type="muws1:ComponentAddressType"
+                  minOccurs="0" maxOccurs="unbounded"/>
+      <xs:any minOccurs="0" maxOccurs="unbounded"
+              namespace="##other" processContents="lax"/>
+    </xs:sequence>
+    <xs:anyAttribute namespace="##other"/>
+  </xs:complexType>
+
+   
+  <xs:complexType name="ManagementEventType">
+    <xs:sequence>
+      <xs:element name="EventId" type="xs:anyURI"/>
+      <xs:element name="SourceComponent" type="muws1:ComponentType"/>
+      <xs:element name="ReporterComponent" type="muws1:ComponentType"
+                  minOccurs="0"/>
+      <xs:any minOccurs="0" maxOccurs="unbounded"
+              namespace="##other" processContents="lax"/>
+    </xs:sequence>
+    <xs:attribute name="ReportTime" type="xs:dateTime" use="optional"/>
+    <xs:anyAttribute namespace="##other"/>
+  </xs:complexType>
+
+  <xs:element name="ManagementEvent" 
+              type="muws1:ManagementEventType"/>
+
+  <xs:element name="ManageabilityEndpointReference"
+              type="wsa:EndpointReferenceType"/>
+
+
+<!--   
+                                       SCHEMA COPY Material
+Copy and paste element references below into the schema of a resource properties document.
+These references are provide to insure that the correct minOccurs/maxOccurs attributes are specified in a resource property document schema.
+
+NOTE: You must import the MUWS Part 1 schema namespace (MUWS1).
+
+        **    Identity Properties    **
+          <xs:element ref="muws1:ResourceId"/>
+
+
+        **    ManageabilityCharacteristics Properties    **
+          <xs:element ref="muws1:ManageabilityCapability"
+                      minOccurs="0" maxOccurs="unbounded"/>
+
+        **    Correlatable Properties    **
+          <xs:element ref="muws1:CorrelatableProperties"
+                      minOccurs="0" maxOccurs="unbounded"/>
+
+-->
+
+</xs:schema>
+



---------------------------------------------------------------------
Apache Qpid - AMQP Messaging Implementation
Project:      http://qpid.apache.org
Use/Interact: mailto:commits-subscribe@qpid.apache.org