You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cxf.apache.org by an...@apache.org on 2006/10/18 11:12:36 UTC

svn commit: r465181 - in /incubator/cxf/trunk: rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/ rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/ systests/

Author: andreasmyth
Date: Wed Oct 18 02:12:34 2006
New Revision: 465181

URL: http://svn.apache.org/viewvc?view=rev&rev=465181
Log:
Increased test coverage for rm logical interceptor.
Re-enabled org.apache.systest.provider.ProviderClientServerTest.

Added:
    incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/TestUtils.java   (with props)
Modified:
    incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/Proxy.java
    incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/RMInterceptor.java
    incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/SourceSequenceImpl.java
    incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/ProxyTest.java
    incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/RMInterceptorTest.java
    incubator/cxf/trunk/systests/pom.xml

Modified: incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/Proxy.java
URL: http://svn.apache.org/viewvc/incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/Proxy.java?view=diff&rev=465181&r1=465180&r2=465181
==============================================================================
--- incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/Proxy.java (original)
+++ incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/Proxy.java Wed Oct 18 02:12:34 2006
@@ -46,7 +46,9 @@
     
     Proxy(Bus bus, RMEndpoint rme) {
         reliableEndpoint = rme;
-        buildService(bus);
+        if (null != bus) {
+            buildService(bus);
+        }
     }
    
     RMEndpoint getReliableEndpoint() {

Modified: incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/RMInterceptor.java
URL: http://svn.apache.org/viewvc/incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/RMInterceptor.java?view=diff&rev=465181&r1=465180&r2=465181
==============================================================================
--- incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/RMInterceptor.java (original)
+++ incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/RMInterceptor.java Wed Oct 18 02:12:34 2006
@@ -41,6 +41,7 @@
 import org.apache.cxf.phase.Phase;
 import org.apache.cxf.phase.PhaseInterceptor;
 import org.apache.cxf.ws.addressing.AddressingProperties;
+import org.apache.cxf.ws.addressing.AddressingPropertiesImpl;
 import org.apache.cxf.ws.addressing.MAPAggregator;
 import org.apache.cxf.ws.addressing.RelatesToType;
 import org.apache.cxf.ws.addressing.VersionTransformer;
@@ -173,11 +174,14 @@
         }
 
         boolean isApplicationMessage = isAplicationMessage(action);
+        System.out.println("isApplicationMessage: " + isApplicationMessage);
         
         RMPropertiesImpl rmpsOut = (RMPropertiesImpl)RMContextUtils.retrieveRMProperties(message, true);
         if (null == rmpsOut) {
             rmpsOut = new RMPropertiesImpl();
             RMContextUtils.storeRMProperties(message, rmpsOut, true);
+        } else {
+            System.out.println("Got existing RMPropertiesImpl");
         }
         
         RMPropertiesImpl rmpsIn = null;
@@ -214,38 +218,8 @@
             if (seq.isLastMessage()) {
                 source.setCurrent(null);
             }
-            
-            /*
-            if (!(isServerSide() && BindingContextUtils.isOnewayTransport(context))) {
-
-                if (!ContextUtils.isRequestor(message)) {
-                    assert null != inSeqId;
-                }
-                
-                // get the current sequence, requesting the creation of a new one if necessary
-                
-                SourceSequence seq = getSequence(inSeqId, context, maps);
-                assert null != seq;
-
-                // increase message number and store a sequence type object in
-                // context
-
-                seq.nextMessageNumber(inSeqId, inMessageNumber);
-                rmpsOut.setSequence(seq);
-
-                // if this was the last message in the sequence, reset the
-                // current sequence so that a new one will be created next 
-                // time the handler is invoked
-
-                if (seq.isLastMessage()) {
-                    source.setCurrent(null);
-                }
-            }
-            */
         }
         
-        System.out.println(inMessageNumber);
-        
         // add Acknowledgements (to application messages or explicitly 
         // created Acknowledgement messages only)
 
@@ -375,20 +349,18 @@
                 EndpointReferenceType acksTo = null;
                 RelatesToType relatesTo = null;
                 if (ContextUtils.isServerSide(message)) {
-                    /*
-                     * AddressingPropertiesImpl inMaps = ContextUtils
-                     * .retrieveMAPs(message, false, false);
-                     * inMaps.exposeAs(VersionTransformer.Names200408.WSA_NAMESPACE_NAME);
-                     * acksTo =
-                     * RMUtils.createReference(inMaps.getTo().getValue()); to =
-                     * inMaps.getReplyTo();
-                     * getServant().setUnattachedIdentifier(inSeqId); relatesTo =
-                     * ContextUtils.WSA_OBJECT_FACTORY.createRelatesToType();
-                     * DestinationSequence inSeq =
-                     * getDestination().getSequence(inSeqId);
-                     * relatesTo.setValue(inSeq != null ?
-                     * inSeq.getCorrelationID() : null);
-                     */
+
+                    
+                    AddressingPropertiesImpl inMaps = ContextUtils.retrieveMAPs(message, false, false);
+                    inMaps.exposeAs(VersionTransformer.Names200408.WSA_NAMESPACE_NAME);
+                    acksTo = RMUtils.createReference(inMaps.getTo().getValue());
+                    to = inMaps.getReplyTo();
+                    // getServant().setUnattachedIdentifier(inSeqId);
+                    relatesTo = (new org.apache.cxf.ws.addressing.ObjectFactory()).createRelatesToType();
+                    Destination destination = getDestination(message);
+                    DestinationSequenceImpl inSeq = destination.getSequenceImpl(inSeqId);
+                    relatesTo.setValue(inSeq != null ? inSeq.getCorrelationID() : null);
+
                 } else {
                     acksTo = VersionTransformer.convert(maps.getReplyTo());
                     // for oneways
@@ -396,7 +368,7 @@
                         acksTo = RMUtils.createReference(Names.WSA_ANONYMOUS_ADDRESS);
                     }
                 }
-
+                
                 source.getProxy().createSequence(to, acksTo, relatesTo);
             } catch (IOException ex) {
                 ex.printStackTrace();

Modified: incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/SourceSequenceImpl.java
URL: http://svn.apache.org/viewvc/incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/SourceSequenceImpl.java?view=diff&rev=465181&r1=465180&r2=465181
==============================================================================
--- incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/SourceSequenceImpl.java (original)
+++ incubator/cxf/trunk/rt/ws/rm/src/main/java/org/apache/cxf/ws/rm/impl/SourceSequenceImpl.java Wed Oct 18 02:12:34 2006
@@ -197,7 +197,6 @@
      * @return the next message number.
      */
     BigInteger nextMessageNumber(Identifier inSeqId, BigInteger inMsgNumber) {
-
         assert !lastMessage;
         
         BigInteger result = null;

Modified: incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/ProxyTest.java
URL: http://svn.apache.org/viewvc/incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/ProxyTest.java?view=diff&rev=465181&r1=465180&r2=465181
==============================================================================
--- incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/ProxyTest.java (original)
+++ incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/ProxyTest.java Wed Oct 18 02:12:34 2006
@@ -57,7 +57,5 @@
         
         List<MessagePartInfo> messageParts = opi.getInput().getMessageParts();
         assertEquals(1, messageParts.size());
-        MessagePartInfo mpi = messageParts.get(0);
-        System.out.println("name of first part of input message: " + mpi.getName().getLocalPart());
     }
 }

Modified: incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/RMInterceptorTest.java
URL: http://svn.apache.org/viewvc/incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/RMInterceptorTest.java?view=diff&rev=465181&r1=465180&r2=465181
==============================================================================
--- incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/RMInterceptorTest.java (original)
+++ incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/RMInterceptorTest.java Wed Oct 18 02:12:34 2006
@@ -19,6 +19,8 @@
 
 package org.apache.cxf.ws.rm.impl;
 
+import java.io.IOException;
+import java.lang.reflect.Method;
 import java.math.BigInteger;
 
 import java.util.Collections;
@@ -27,10 +29,24 @@
 
 import junit.framework.TestCase;
 
+import org.apache.cxf.Bus;
+import org.apache.cxf.endpoint.Endpoint;
+import org.apache.cxf.message.Exchange;
+import org.apache.cxf.message.Message;
 import org.apache.cxf.phase.Phase;
 import org.apache.cxf.phase.PhaseInterceptorChain;
+import org.apache.cxf.ws.addressing.AddressingProperties;
+import org.apache.cxf.ws.addressing.AddressingPropertiesImpl;
+import org.apache.cxf.ws.addressing.AttributedURIType;
+import org.apache.cxf.ws.addressing.EndpointReferenceType;
+import org.apache.cxf.ws.addressing.JAXWSAConstants;
 import org.apache.cxf.ws.addressing.MAPAggregator;
+import org.apache.cxf.ws.addressing.RelatesToType;
+import org.apache.cxf.ws.addressing.v200408.AttributedURI;
+import org.apache.cxf.ws.rm.Identifier;
+import org.apache.cxf.ws.rm.RMMessageConstants;
 import org.apache.cxf.ws.rm.RetransmissionQueue;
+import org.apache.cxf.ws.rm.SequenceFault;
 import org.apache.cxf.ws.rm.interceptor.SequenceTerminationPolicyType;
 import org.apache.cxf.ws.rm.interceptor.SourcePolicyType;
 import org.apache.cxf.ws.rm.persistence.RMStore;
@@ -39,6 +55,12 @@
 import org.easymock.classextension.IMocksControl;
 
 public class RMInterceptorTest extends TestCase {
+    
+    private IMocksControl control;
+    
+    public void setUp() {
+        control = EasyMock.createNiceControl();
+    }
    
     public void testAccessors() {
         RMInterceptor rmi = new RMInterceptor();
@@ -46,7 +68,6 @@
         assertNull(rmi.getRetransmissionQueue());
         assertNotNull(rmi.getTimer());
         
-        IMocksControl control = EasyMock.createNiceControl();
         RMStore store = control.createMock(RMStore.class);
         RetransmissionQueue queue = control.createMock(RetransmissionQueue.class);
         
@@ -54,8 +75,8 @@
         rmi.setRetransmissionQueue(queue);
         assertSame(store, rmi.getStore());
         assertSame(queue, rmi.getRetransmissionQueue());
-  
-        
+        control.replay();
+        control.verify();
         
     }
     
@@ -103,12 +124,172 @@
         Iterator it = chain.iterator();
         assertSame("Unexpected order.", map, it.next());
         assertSame("Unexpected order.", rmi, it.next());                      
-    }    
+    } 
+    
+    public void testGetReliableEndpoint() {
+        
+        RMInterceptor rmi = new RMInterceptor();
+        Bus bus = control.createMock(Bus.class);
+        rmi.setBus(bus);
+        Message message = control.createMock(Message.class);
+        EasyMock.expect(message.get(Message.REQUESTOR_ROLE)).andReturn(Boolean.TRUE).times(2);
+        Exchange exchange = control.createMock(Exchange.class);
+        EasyMock.expect(message.getExchange()).andReturn(exchange).times(2);
+        Endpoint endpoint = control.createMock(Endpoint.class);
+        EasyMock.expect(exchange.get(Endpoint.class)).andReturn(endpoint).times(2);
+        control.replay();
+        RMEndpoint reliableEndpoint = rmi.getReliableEndpoint(message);
+        assertSame(endpoint, reliableEndpoint.getEndpoint());
+        RMEndpoint rme = rmi.getReliableEndpoint(message);
+        assertSame(reliableEndpoint, rme); 
+        control.verify();
+    }
+    
+    public void testGetDestination() throws NoSuchMethodException {
+        Method  m = RMInterceptor.class
+            .getDeclaredMethod("getReliableEndpoint", new Class[] {Message.class});        
+        RMInterceptor rmi = control.createMock(RMInterceptor.class, new Method[] {m});
+        Message message = control.createMock(Message.class);
+        RMEndpoint rme = control.createMock(RMEndpoint.class);
+        EasyMock.expect(rmi.getReliableEndpoint(message)).andReturn(rme);    
+        Destination destination = control.createMock(Destination.class);
+        EasyMock.expect(rme.getDestination()).andReturn(destination);
+       
+        control.replay();
+        assertSame(destination, rmi.getDestination(message));
+        control.verify();
+        
+        control.reset();
+        EasyMock.expect(rmi.getReliableEndpoint(message)).andReturn(null);
+        control.replay();
+        assertNull(rmi.getDestination(message));
+        control.verify();        
+    }
+        
+    public void testGetSource() throws NoSuchMethodException {
+        Method m = RMInterceptor.class
+            .getDeclaredMethod("getReliableEndpoint", new Class[] {Message.class});
+        RMInterceptor rmi = control.createMock(RMInterceptor.class, new Method[] {m});
+        Message message = control.createMock(Message.class);
+        RMEndpoint rme = control.createMock(RMEndpoint.class);
+        EasyMock.expect(rmi.getReliableEndpoint(message)).andReturn(rme);
+        Source source = control.createMock(Source.class);
+        EasyMock.expect(rme.getSource()).andReturn(source);
+
+        control.replay();
+        assertSame(source, rmi.getSource(message));
+        control.verify();
+
+        control.reset();
+        EasyMock.expect(rmi.getReliableEndpoint(message)).andReturn(null);
+        control.replay();
+        assertNull(rmi.getSource(message));
+        control.verify();
+    }
+        
+    public void testGetExistingSequence() throws NoSuchMethodException, SequenceFault {
+        Method m = RMInterceptor.class
+           .getDeclaredMethod("getSource", new Class[] {Message.class});
+        RMInterceptor rmi = control.createMock(RMInterceptor.class, new Method[] {m});
+        Message message = control.createMock(Message.class);
+        Identifier inSid = control.createMock(Identifier.class);
+        
+        Source source = control.createMock(Source.class);
+        EasyMock.expect(rmi.getSource(message)).andReturn(source);
+        SourceSequenceImpl sseq = control.createMock(SourceSequenceImpl.class);
+        EasyMock.expect(source.getCurrent(inSid)).andReturn(sseq);
+        control.replay();
+        assertSame(sseq, rmi.getSequence(inSid, message, null));
+        control.verify();
+    }
+    
+    public void testGetNewSequence() throws NoSuchMethodException, SequenceFault, IOException {
+        Method m = RMInterceptor.class.getDeclaredMethod("getSource", new Class[] {Message.class});
+        RMInterceptor rmi = control.createMock(RMInterceptor.class, new Method[] {m});
+        Message message = control.createMock(Message.class);
+        Identifier inSid = control.createMock(Identifier.class);
+        AddressingProperties maps = control.createMock(AddressingProperties.class);
+        Source source = control.createMock(Source.class);
+        EasyMock.expect(rmi.getSource(message)).andReturn(source);
+        EasyMock.expect(source.getCurrent(inSid)).andReturn(null);
+        EndpointReferenceType epr = TestUtils.getNoneReference();
+        EasyMock.expect(maps.getReplyTo()).andReturn(epr);
+        Proxy proxy = control.createMock(Proxy.class);
+        EasyMock.expect(source.getProxy()).andReturn(proxy);
+        proxy.createSequence((EndpointReferenceType)EasyMock.isNull(),
+                             EasyMock.isA(org.apache.cxf.ws.addressing.v200408.EndpointReferenceType.class),
+                             (RelatesToType)EasyMock.isNull());
+        EasyMock.expectLastCall();
+        SourceSequenceImpl sseq = control.createMock(SourceSequenceImpl.class);
+        EasyMock.expect(source.awaitCurrent(inSid)).andReturn(sseq);
+        sseq.setTarget((EndpointReferenceType)EasyMock.isNull());
+        EasyMock.expectLastCall();
+        
+        control.replay();
+        assertSame(sseq, rmi.getSequence(inSid, message, maps));
+        control.verify();
+    }
+    
+    public void testHandleOutboundApplicationMessage() throws NoSuchMethodException, SequenceFault {
+        AddressingPropertiesImpl maps = createMAPs("greetMe", "localhost:9000/GreeterPort", 
+            org.apache.cxf.ws.addressing.Names.WSA_NONE_ADDRESS);
+        Method[] mocked = new Method[] {
+            RMInterceptor.class.getDeclaredMethod("getSource", new Class[] {Message.class}),
+            RMInterceptor.class.getDeclaredMethod("getDestination", new Class[] {Message.class}),
+            RMInterceptor.class.getDeclaredMethod("getSequence", 
+                new Class[] {Identifier.class, Message.class, AddressingProperties.class}),
+            RMInterceptor.class.getDeclaredMethod("addAcknowledgements",
+                new Class[] {Destination.class, RMPropertiesImpl.class, Identifier.class, 
+                             AttributedURI.class})            
+        };
+        RMInterceptor rmi = control.createMock(RMInterceptor.class, mocked);       
+        Message message = control.createMock(Message.class);
+        EasyMock.expect(message.get(Message.REQUESTOR_ROLE)).andReturn(Boolean.TRUE).anyTimes();        
+        EasyMock.expect(message.get(JAXWSAConstants.CLIENT_ADDRESSING_PROPERTIES_OUTBOUND))
+            .andReturn(maps).anyTimes();
+        RMPropertiesImpl rmpsOut = new RMPropertiesImpl();
+        EasyMock.expect(message.get(RMMessageConstants.RM_PROPERTIES_OUTBOUND)).andReturn(rmpsOut);
+        EasyMock.expect(message.get(RMMessageConstants.RM_PROPERTIES_INBOUND)).andReturn(null);        
+        Source source = control.createMock(Source.class);
+        EasyMock.expect(rmi.getSource(message)).andReturn(source);
+        Destination destination = control.createMock(Destination.class);
+        EasyMock.expect(rmi.getDestination(message)).andReturn(destination);
+        SourceSequenceImpl sseq = control.createMock(SourceSequenceImpl.class);
+        EasyMock.expect(rmi.getSequence((Identifier)EasyMock.isNull(), EasyMock.same(message), 
+                                        EasyMock.same(maps))).andReturn(sseq);
+        EasyMock.expect(sseq.nextMessageNumber((Identifier)EasyMock.isNull(), 
+            (BigInteger)EasyMock.isNull())).andReturn(BigInteger.TEN);
+        EasyMock.expect(sseq.isLastMessage()).andReturn(false).times(2);
+        rmi.addAcknowledgements(EasyMock.same(destination), EasyMock.same(rmpsOut), 
+            (Identifier)EasyMock.isNull(), EasyMock.isA(AttributedURI.class));
+        EasyMock.expectLastCall();
+        Identifier sid = control.createMock(Identifier.class);
+        EasyMock.expect(sseq.getIdentifier()).andReturn(sid);
+        EasyMock.expect(sseq.getCurrentMessageNr()).andReturn(BigInteger.TEN);
+
+        
+        control.replay();
+        rmi.handleOutbound(message, false);
+        assertSame(sid, rmpsOut.getSequence().getIdentifier());        
+        assertEquals(BigInteger.TEN, rmpsOut.getSequence().getMessageNumber());
+        assertNull(rmpsOut.getSequence().getLastMessage());
+        control.verify();
+    }
+    
     
-    public void testAddAcknowledgement() {
-        // MInterceptor rmi = new RMInterceptor();
-        IMocksControl control = EasyMock.createNiceControl();
-        control.createMock(Source.class);
-         
+    private AddressingPropertiesImpl createMAPs(String action, String to, String replyTo) {
+        AddressingPropertiesImpl maps = new AddressingPropertiesImpl();
+        org.apache.cxf.ws.addressing.ObjectFactory factory = 
+            new org.apache.cxf.ws.addressing.ObjectFactory();
+        AttributedURIType uri = factory.createAttributedURIType();
+        uri.setValue(action);
+        maps.setAction(uri);
+        uri = factory.createAttributedURIType();
+        uri.setValue(to);
+        maps.setTo(uri);
+        EndpointReferenceType epr = TestUtils.getReference(replyTo);
+        maps.setReplyTo(epr);
+        return maps;
+           
     }
 }

Added: incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/TestUtils.java
URL: http://svn.apache.org/viewvc/incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/TestUtils.java?view=auto&rev=465181
==============================================================================
--- incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/TestUtils.java (added)
+++ incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/TestUtils.java Wed Oct 18 02:12:34 2006
@@ -0,0 +1,73 @@
+/**
+ * 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.cxf.ws.rm.impl;
+
+import org.apache.cxf.ws.addressing.VersionTransformer;
+
+/**
+ * 
+ */
+public final class TestUtils {
+
+    /**
+     * Prevents construction.
+     */
+    private TestUtils() {
+        
+    }
+    
+    public static org.apache.cxf.ws.addressing.EndpointReferenceType getAnonymousReference() {
+        return getReference(org.apache.cxf.ws.addressing.Names.WSA_ANONYMOUS_ADDRESS);
+    }
+    
+    public static org.apache.cxf.ws.addressing.v200408.EndpointReferenceType getAnonymousReference2004() {
+        return VersionTransformer.convert(getAnonymousReference());
+    }
+    
+    public static org.apache.cxf.ws.addressing.EndpointReferenceType getNoneReference() {
+        return getReference(org.apache.cxf.ws.addressing.Names.WSA_NONE_ADDRESS);
+    }
+    
+    public static org.apache.cxf.ws.addressing.v200408.EndpointReferenceType getNoneReference2004() {
+        return VersionTransformer.convert(getNoneReference());
+    }
+    
+    public static org.apache.cxf.ws.addressing.EndpointReferenceType getReference(String address) {
+        org.apache.cxf.ws.addressing.ObjectFactory factory = 
+            new org.apache.cxf.ws.addressing.ObjectFactory();
+        org.apache.cxf.ws.addressing.EndpointReferenceType epr = factory.createEndpointReferenceType();
+        org.apache.cxf.ws.addressing.AttributedURIType uri = factory.createAttributedURIType();
+        uri.setValue(address);
+        epr.setAddress(uri);        
+        return epr;        
+    }
+    
+    public static org.apache.cxf.ws.addressing.v200408.EndpointReferenceType 
+    getReference2004(String address) {
+        org.apache.cxf.ws.addressing.v200408.ObjectFactory factory = 
+            new org.apache.cxf.ws.addressing.v200408.ObjectFactory();
+        org.apache.cxf.ws.addressing.v200408.EndpointReferenceType epr = 
+            factory.createEndpointReferenceType();
+        org.apache.cxf.ws.addressing.v200408.AttributedURI uri = factory.createAttributedURI();
+        uri.setValue(address);
+        epr.setAddress(uri);
+        return epr;
+    } 
+}

Propchange: incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/TestUtils.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/cxf/trunk/rt/ws/rm/src/test/java/org/apache/cxf/ws/rm/impl/TestUtils.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: incubator/cxf/trunk/systests/pom.xml
URL: http://svn.apache.org/viewvc/incubator/cxf/trunk/systests/pom.xml?view=diff&rev=465181&r1=465180&r2=465181
==============================================================================
--- incubator/cxf/trunk/systests/pom.xml (original)
+++ incubator/cxf/trunk/systests/pom.xml Wed Oct 18 02:12:34 2006
@@ -174,7 +174,9 @@
                         </systemProperties>
                         <excludes>
                             <exclude>**/*$*</exclude>
+                            <!--
                             <exclude>**/ProviderClientServer*</exclude>
+                            -->
                         </excludes>
                     </configuration>
                 </plugin>