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:18:56 UTC

svn commit: r522022 [1/3] - in /webservices/muse/trunk/modules: muse-wsn-api/src/org/apache/muse/ws/notification/ muse-wsn-api/src/org/apache/muse/ws/notification/faults/ muse-wsn-api/src/org/apache/muse/ws/notification/topics/ muse-wsn-impl/src/org/ap...

Author: danj
Date: Sat Mar 24 06:18:52 2007
New Revision: 522022

URL: http://svn.apache.org/viewvc?view=rev&rev=522022
Log:
Updating all source files to have new license header as mandated by ASF policy.

Modified:
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/Filter.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationConsumer.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationMessage.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationMessageListener.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationProducer.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationProducerPersistence.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/Policy.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPoint.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPointCreation.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPointDataStore.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/SubscriptionManager.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/TopicListener.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/WsnConstants.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidFilterFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidMessageContentExpressionFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidProducerPropertiesExpressionFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidTopicExpressionFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/MultipleTopicsSpecifiedFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/NoCurrentMessageOnTopicFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/NotifyMessageNotSupportedFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/PauseFailedFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/ResumeFailedFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/SubscribeCreationFailedFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/TopicExpressionDialectUnknownFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/TopicNotSupportedFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnableToCreatePullPointFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnableToGetMessagesFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnacceptableInitialTerminationTimeFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnrecognizedPolicyRequestFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnsupportedPolicyRequestFault.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/Topic.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/TopicNamespace.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/TopicPathExpression.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/TopicSet.java
    webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/WstConstants.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/FilterCollection.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/FilterFactory.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/FilterFactoryHandler.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/FilterSerializer.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/GetCurrentMessage.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/GetCurrentMessageHandler.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/GetCurrentMessageResponse.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/MessagePatternFilter.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/MessagePatternFilterHandler.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/NotificationMessageSerializer.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/NotificationProducerFilePersistence.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/NotifyHandler.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/ProducerPropertiesFilter.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/ProducerPropertiesFilterHandler.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/PublishAllMessagesFilter.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/SimpleNotificationConsumer.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/SimpleNotificationMessage.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/SimpleNotificationProducer.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/SimplePullPoint.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/SimplePullPointCreation.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/SimplePullPointDataStore.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/SimpleSubscriptionManager.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/Subscribe.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/SubscribeHandler.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/SubscribeResponse.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/TopicFilter.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/impl/TopicFilterHandler.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/properties/ChangeNotificationListener.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/properties/ChangeNotificationListenerFactory.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/properties/ResourcePropertyChangeEvent.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/properties/WsrpNotificationListenerFactory.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/remote/NotificationConsumerClient.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/remote/NotificationProducerClient.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/remote/SubscriptionClient.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/topics/impl/ConcretePathExpression.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/topics/impl/SimpleTopic.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/topics/impl/SimpleTopicNamespace.java
    webservices/muse/trunk/modules/muse-wsn-impl/src/org/apache/muse/ws/notification/topics/impl/SimpleTopicSet.java
    webservices/muse/trunk/modules/muse-wsx-api/src/org/apache/muse/ws/metadata/MetadataExchange.java
    webservices/muse/trunk/modules/muse-wsx-api/src/org/apache/muse/ws/metadata/WsxConstants.java
    webservices/muse/trunk/modules/muse-wsx-impl/src/org/apache/muse/ws/metadata/impl/GetMetadataHandler.java
    webservices/muse/trunk/modules/muse-wsx-impl/src/org/apache/muse/ws/metadata/impl/GetMetadataRequest.java
    webservices/muse/trunk/modules/muse-wsx-impl/src/org/apache/muse/ws/metadata/impl/GetMetadataResponse.java
    webservices/muse/trunk/modules/muse-wsx-impl/src/org/apache/muse/ws/metadata/impl/SimpleMetadataExchange.java
    webservices/muse/trunk/modules/muse-wsx-impl/src/org/apache/muse/ws/metadata/remote/MetadataExchangeClient.java

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/Filter.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/Filter.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/Filter.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/Filter.java Sat Mar 24 06:18:52 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.ws.notification;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationConsumer.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationConsumer.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationConsumer.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationConsumer.java Sat Mar 24 06:18:52 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.ws.notification;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationMessage.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationMessage.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationMessage.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationMessage.java Sat Mar 24 06:18:52 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.ws.notification;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationMessageListener.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationMessageListener.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationMessageListener.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationMessageListener.java Sat Mar 24 06:18:52 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.ws.notification;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationProducer.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationProducer.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationProducer.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationProducer.java Sat Mar 24 06:18:52 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.ws.notification;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationProducerPersistence.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationProducerPersistence.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationProducerPersistence.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/NotificationProducerPersistence.java Sat Mar 24 06:18:52 2007
@@ -1,39 +1,43 @@
-/*=============================================================================*
- *  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.ws.notification;
-
-import org.apache.muse.core.Persistence;
-import org.apache.muse.core.ResourceManagerListener;
-
-/**
- * 
- * NotificationProducerPersistence is an extension of the basic 
- * {@linkplain Persistence Persistence API} to provide a link to the 
- * {@linkplain NotificationProducer NotificationProducer API} and resource 
- * lifecycle events. Implementations of the NotificationProducer capability 
- * should use instances of this interface for persistence of subscription data.
- *
- * @author Dan Jemiolo (danj)
- *
- */
-
-public interface NotificationProducerPersistence extends Persistence, ResourceManagerListener
-{
-    NotificationProducer getNotificationProducer();
-    
-    void setNotificationProducer(NotificationProducer producer);
-}
+/* 
+ * 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.ws.notification;
+
+import org.apache.muse.core.Persistence;
+import org.apache.muse.core.ResourceManagerListener;
+
+/**
+ * 
+ * NotificationProducerPersistence is an extension of the basic 
+ * {@linkplain Persistence Persistence API} to provide a link to the 
+ * {@linkplain NotificationProducer NotificationProducer API} and resource 
+ * lifecycle events. Implementations of the NotificationProducer capability 
+ * should use instances of this interface for persistence of subscription data.
+ *
+ * @author Dan Jemiolo (danj)
+ *
+ */
+
+public interface NotificationProducerPersistence extends Persistence, ResourceManagerListener
+{
+    NotificationProducer getNotificationProducer();
+    
+    void setNotificationProducer(NotificationProducer producer);
+}

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/Policy.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/Policy.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/Policy.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/Policy.java Sat Mar 24 06:18:52 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.ws.notification;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPoint.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPoint.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPoint.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPoint.java Sat Mar 24 06:18:52 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.ws.notification;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPointCreation.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPointCreation.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPointCreation.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPointCreation.java Sat Mar 24 06:18:52 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.ws.notification;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPointDataStore.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPointDataStore.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPointDataStore.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/PullPointDataStore.java Sat Mar 24 06:18:52 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.ws.notification;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/SubscriptionManager.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/SubscriptionManager.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/SubscriptionManager.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/SubscriptionManager.java Sat Mar 24 06:18:52 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.ws.notification;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/TopicListener.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/TopicListener.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/TopicListener.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/TopicListener.java Sat Mar 24 06:18:52 2007
@@ -1,34 +1,38 @@
-/*=============================================================================*
- *  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.ws.notification;
-
-import javax.xml.namespace.QName;
-
-/**
- *
- * TopicListener is a NotificationMessageListener that only listens on a 
- * certain WS-N Topic. It adds on getter method to allow users to discover 
- * the topic of interest.
- *
- * @author Dan Jemiolo (danj)
- *
- */
-
-public interface TopicListener extends NotificationMessageListener
-{
-    QName getTopic();
-}
+/* 
+ * 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.ws.notification;
+
+import javax.xml.namespace.QName;
+
+/**
+ *
+ * TopicListener is a NotificationMessageListener that only listens on a 
+ * certain WS-N Topic. It adds on getter method to allow users to discover 
+ * the topic of interest.
+ *
+ * @author Dan Jemiolo (danj)
+ *
+ */
+
+public interface TopicListener extends NotificationMessageListener
+{
+    QName getTopic();
+}

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/WsnConstants.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/WsnConstants.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/WsnConstants.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/WsnConstants.java Sat Mar 24 06:18:52 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.ws.notification;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidFilterFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidFilterFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidFilterFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidFilterFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidMessageContentExpressionFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidMessageContentExpressionFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidMessageContentExpressionFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidMessageContentExpressionFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidProducerPropertiesExpressionFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidProducerPropertiesExpressionFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidProducerPropertiesExpressionFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidProducerPropertiesExpressionFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidTopicExpressionFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidTopicExpressionFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidTopicExpressionFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/InvalidTopicExpressionFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/MultipleTopicsSpecifiedFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/MultipleTopicsSpecifiedFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/MultipleTopicsSpecifiedFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/MultipleTopicsSpecifiedFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/NoCurrentMessageOnTopicFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/NoCurrentMessageOnTopicFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/NoCurrentMessageOnTopicFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/NoCurrentMessageOnTopicFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/NotifyMessageNotSupportedFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/NotifyMessageNotSupportedFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/NotifyMessageNotSupportedFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/NotifyMessageNotSupportedFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/PauseFailedFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/PauseFailedFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/PauseFailedFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/PauseFailedFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/ResumeFailedFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/ResumeFailedFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/ResumeFailedFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/ResumeFailedFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/SubscribeCreationFailedFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/SubscribeCreationFailedFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/SubscribeCreationFailedFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/SubscribeCreationFailedFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/TopicExpressionDialectUnknownFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/TopicExpressionDialectUnknownFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/TopicExpressionDialectUnknownFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/TopicExpressionDialectUnknownFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/TopicNotSupportedFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/TopicNotSupportedFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/TopicNotSupportedFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/TopicNotSupportedFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnableToCreatePullPointFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnableToCreatePullPointFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnableToCreatePullPointFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnableToCreatePullPointFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnableToGetMessagesFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnableToGetMessagesFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnableToGetMessagesFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnableToGetMessagesFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnacceptableInitialTerminationTimeFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnacceptableInitialTerminationTimeFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnacceptableInitialTerminationTimeFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnacceptableInitialTerminationTimeFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnrecognizedPolicyRequestFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnrecognizedPolicyRequestFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnrecognizedPolicyRequestFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnrecognizedPolicyRequestFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnsupportedPolicyRequestFault.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnsupportedPolicyRequestFault.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnsupportedPolicyRequestFault.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/faults/UnsupportedPolicyRequestFault.java Sat Mar 24 06:18:52 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.ws.notification.faults;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/Topic.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/Topic.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/Topic.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/Topic.java Sat Mar 24 06:18:52 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.ws.notification.topics;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/TopicNamespace.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/TopicNamespace.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/TopicNamespace.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/TopicNamespace.java Sat Mar 24 06:18:52 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.ws.notification.topics;
 

Modified: webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/TopicPathExpression.java
URL: http://svn.apache.org/viewvc/webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/TopicPathExpression.java?view=diff&rev=522022&r1=522021&r2=522022
==============================================================================
--- webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/TopicPathExpression.java (original)
+++ webservices/muse/trunk/modules/muse-wsn-api/src/org/apache/muse/ws/notification/topics/TopicPathExpression.java Sat Mar 24 06:18:52 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.ws.notification.topics;
 



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