You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cxf.apache.org by da...@apache.org on 2009/12/17 12:28:41 UTC

svn commit: r891650 [10/10] - in /cxf/dosgi/trunk: ./ discovery/distributed/cxf-discovery/ discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/ discovery/distributed/cxf-discovery/src/main/java/org/osgi/service/di...

Added: cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/ExportServiceTest.java
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/ExportServiceTest.java?rev=891650&view=auto
==============================================================================
--- cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/ExportServiceTest.java (added)
+++ cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/ExportServiceTest.java Thu Dec 17 11:28:30 2009
@@ -0,0 +1,193 @@
+/** 
+  * 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.dosgi.topologymanager;
+
+import java.util.ArrayList;
+import java.util.HashMap;
+import java.util.List;
+import java.util.Map;
+
+import org.easymock.IAnswer;
+import org.easymock.IMocksControl;
+import org.easymock.classextension.EasyMock;
+import org.osgi.framework.Bundle;
+import org.osgi.framework.BundleContext;
+import org.osgi.framework.FrameworkUtil;
+import org.osgi.framework.ServiceEvent;
+import org.osgi.framework.ServiceListener;
+import org.osgi.framework.ServiceReference;
+import org.osgi.service.remoteserviceadmin.EndpointDescription;
+import org.osgi.service.remoteserviceadmin.EndpointListener;
+import org.osgi.service.remoteserviceadmin.ExportReference;
+import org.osgi.service.remoteserviceadmin.ExportRegistration;
+import org.osgi.service.remoteserviceadmin.RemoteConstants;
+import org.osgi.service.remoteserviceadmin.RemoteServiceAdmin;
+
+import org.junit.Test;
+
+public class ExportServiceTest {
+
+    
+    /**
+     * This tests if the topology manager handles a service marked to be exported correctly by exporting it to
+     * an available RemoteServiceAdmin and by notifying an EndpointListener Afterwards
+     * @throws Exception 
+     */
+    @SuppressWarnings("unchecked")
+    @Test
+    public void testServiceExport() throws Exception {
+
+        String scope = "(objectClass=abc)";
+     
+        IMocksControl c = EasyMock.createNiceControl();
+          
+        BundleContext bctx = c.createMock(BundleContext.class);
+
+        Bundle topMgrBundle = c.createMock(Bundle.class);
+        
+        RemoteServiceAdmin rsa = c.createMock(RemoteServiceAdmin.class);
+        final ServiceReference rsaSref = c.createMock(ServiceReference.class);
+        EndpointListener epl = c.createMock(EndpointListener.class);
+        final ServiceReference eplSref = c.createMock(ServiceReference.class);
+        EasyMock.expect(eplSref.getProperty(EasyMock.same(EndpointListener.ENDPOINT_LISTENER_SCOPE)))
+            .andReturn(scope).anyTimes();
+        EasyMock.expect(eplSref.getBundle()).andReturn(topMgrBundle).anyTimes();
+
+        final ServiceReference sref = c.createMock(ServiceReference.class);
+        EasyMock.expect(sref.getProperty(EasyMock.same(RemoteConstants.SERVICE_EXPORTED_INTERFACES)))
+            .andReturn("*").anyTimes();
+        Bundle srefBundle = c.createMock(Bundle.class);
+        EasyMock.expect(sref.getBundle()).andReturn(srefBundle).anyTimes();
+        
+        
+        EndpointDescription endpoint = c.createMock(EndpointDescription.class);
+        {
+            Map props = new HashMap();
+            String[] objs = new String[1];
+            objs[0] = "abc";
+            props.put("objectClass", objs);
+            EasyMock.expect(endpoint.getProperties()).andReturn(props).anyTimes();
+        }
+
+        ExportRegistration exportRegistration = c.createMock(ExportRegistration.class);
+        ExportReference exportReference = c.createMock(ExportReference.class);
+
+        EasyMock.expect(exportRegistration.getExportReference()).andReturn(exportReference).anyTimes();
+        EasyMock.expect(exportReference.getExportedEndpoint()).andReturn(endpoint).anyTimes();
+        {
+            List ret = new ArrayList();
+            ret.add(exportRegistration);
+            EasyMock.expect(rsa.exportService(EasyMock.same(sref), (Map)EasyMock.anyObject())).andReturn(ret)
+                .once();
+        }
+
+        epl.endpointAdded((EndpointDescription)EasyMock.anyObject(), (String)EasyMock.anyObject());
+        EasyMock.expectLastCall().andAnswer(new IAnswer<Object>() {
+
+            public Object answer() throws Throwable {
+                System.out.println("Call made !!!");
+                return null;
+            }
+            
+        }).once();
+
+        {/* BCTX */
+
+            bctx.addServiceListener((ServiceListener)EasyMock.anyObject(), (String)EasyMock.anyObject());
+            EasyMock.expectLastCall().andAnswer(new IAnswer<Object>() {
+
+                public Object answer() throws Throwable {
+                    // TODO Auto-generated method stub
+
+                    System.out.println("->   addServiceListener: "
+                                       + EasyMock.getCurrentArguments()[1]);
+                    ServiceListener sl = (ServiceListener)EasyMock.getCurrentArguments()[0];
+
+                    if ("(objectClass=org.osgi.service.remoteserviceadmin.RemoteServiceAdmin)"
+                        .equals(EasyMock.getCurrentArguments()[1])) {
+                        ServiceEvent se = new ServiceEvent(ServiceEvent.REGISTERED, rsaSref);
+                        sl.serviceChanged(se);
+                    } else if ("(objectClass=org.osgi.service.remoteserviceadmin.EndpointListener)"
+                        .equals(EasyMock.getCurrentArguments()[1])) {
+                        ServiceEvent se = new ServiceEvent(ServiceEvent.REGISTERED, eplSref);
+                        sl.serviceChanged(se);
+                    }
+
+                    return null;
+                }
+            }).anyTimes();
+
+            bctx.addServiceListener((ServiceListener)EasyMock.anyObject());
+            EasyMock.expectLastCall().andAnswer(new IAnswer<Object>() {
+
+                public Object answer() throws Throwable {
+                    // TODO Auto-generated method stub
+
+                    System.out.println("->   addServiceListener ");
+
+                    ServiceListener sl = (ServiceListener)EasyMock.getCurrentArguments()[0];
+
+                    ServiceEvent se = new ServiceEvent(ServiceEvent.REGISTERED, sref);
+                    sl.serviceChanged(se);
+                    se = new ServiceEvent(ServiceEvent.REGISTERED, eplSref);
+                    sl.serviceChanged(se);
+                    se = new ServiceEvent(ServiceEvent.REGISTERED, rsaSref);
+                    sl.serviceChanged(se);
+
+                    return null;
+                }
+            }).anyTimes();
+
+            EasyMock.expect(bctx.getService(EasyMock.same(rsaSref))).andReturn(rsa).anyTimes();
+            EasyMock.expect(bctx.getService(EasyMock.same(eplSref))).andReturn(epl).atLeastOnce();
+
+            {
+                ServiceReference[] refs = new ServiceReference[1];
+                refs[0] = eplSref;
+                EasyMock
+                    .expect(
+                            bctx.getServiceReferences(EasyMock.same(EndpointListener.class.getName()),
+                                                      EasyMock
+                                                          .same("("
+                                                                + EndpointListener.ENDPOINT_LISTENER_SCOPE
+                                                                + "=*)"))).andReturn(refs).anyTimes();
+            }
+            
+            EasyMock.expect(bctx.createFilter(EasyMock.same(scope))).andReturn(FrameworkUtil.createFilter(scope)).anyTimes();
+
+        }
+
+
+        c.replay();
+
+//        TopologyManager tm = new TopologyManager(bctx);
+//        tm.start();
+
+        Activator a = new Activator();
+        a.start(bctx);
+        
+        try {
+            Thread.sleep(100);
+        } catch (InterruptedException e) {}
+        
+        c.verify();
+
+    }
+
+}

Propchange: cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/ExportServiceTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/ExportServiceTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/RemoteServiceAdminListTest.java
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/RemoteServiceAdminListTest.java?rev=891650&view=auto
==============================================================================
--- cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/RemoteServiceAdminListTest.java (added)
+++ cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/RemoteServiceAdminListTest.java Thu Dec 17 11:28:30 2009
@@ -0,0 +1,116 @@
+/** 
+  * 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.dosgi.topologymanager;
+
+import static org.junit.Assert.*;
+
+import org.easymock.IAnswer;
+import org.easymock.IMocksControl;
+import org.easymock.classextension.EasyMock;
+import org.osgi.framework.BundleContext;
+import org.osgi.framework.InvalidSyntaxException;
+import org.osgi.framework.ServiceEvent;
+import org.osgi.framework.ServiceListener;
+import org.osgi.framework.ServiceReference;
+import org.osgi.service.remoteserviceadmin.RemoteServiceAdmin;
+
+import org.junit.Test;
+
+public class RemoteServiceAdminListTest {
+
+    RemoteServiceAdminList rsal = null;
+    
+    @Test
+    public void testRemoteServiceAdminAddingAndRemoval() throws InvalidSyntaxException{
+        
+        IMocksControl control = EasyMock.createNiceControl();
+        
+        BundleContext bc = control.createMock(BundleContext.class);
+        TopologyManager tm = control.createMock(TopologyManager.class);
+        TopologyManagerImport tmi = control.createMock(TopologyManagerImport.class);
+        
+        
+        RemoteServiceAdmin rsa = control.createMock(RemoteServiceAdmin.class);
+        final ServiceReference rsaSref = control.createMock(ServiceReference.class);
+        
+        
+        tm.removeRemoteServiceAdmin(EasyMock.eq(rsa));
+        EasyMock.expectLastCall().once();
+        
+        tm.triggerExportImportForRemoteSericeAdmin(EasyMock.eq(rsa));
+        EasyMock.expectLastCall().once();
+        
+        tmi.triggerExportImportForRemoteSericeAdmin(EasyMock.eq(rsa));
+        EasyMock.expectLastCall().once();
+        
+        bc.addServiceListener((ServiceListener)EasyMock.anyObject(),(String)EasyMock.anyObject()); 
+        EasyMock.expectLastCall().andAnswer(new IAnswer<Object>() {
+
+            public Object answer() throws Throwable {
+
+                System.out.println("->   addServiceListener ");
+
+                ServiceListener sl = (ServiceListener)EasyMock.getCurrentArguments()[0];
+
+                ServiceEvent se = new ServiceEvent(ServiceEvent.REGISTERED, rsaSref);
+                sl.serviceChanged(se);
+
+                assertEquals(1,rsal.size());
+                
+                se = new ServiceEvent(ServiceEvent.UNREGISTERING, rsaSref);
+                sl.serviceChanged(se);
+                
+                assertEquals(0,rsal.size());
+                
+                return null;
+            }
+        }).anyTimes();
+
+        EasyMock.expect(bc.getService(EasyMock.same(rsaSref))).andReturn(rsa).anyTimes();
+
+        EasyMock.expect(bc.createFilter((String)EasyMock.anyObject())).andReturn(null).anyTimes();
+        
+        
+        
+       control.replay();
+        
+        
+        
+        
+       rsal  = new RemoteServiceAdminList(bc);
+        
+        
+        
+        
+        
+        rsal.setTopologyManager(tm);
+        rsal.setTopologyManagerImport(tmi);
+        
+        System.out.println("start");
+        rsal.start();
+        
+        
+        
+        control.verify();
+        
+        
+        
+    }
+    
+}

Propchange: cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/RemoteServiceAdminListTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/RemoteServiceAdminListTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/RemoteServiceAdminListenerTest.java
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/RemoteServiceAdminListenerTest.java?rev=891650&view=auto
==============================================================================
--- cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/RemoteServiceAdminListenerTest.java (added)
+++ cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/RemoteServiceAdminListenerTest.java Thu Dec 17 11:28:30 2009
@@ -0,0 +1,72 @@
+/** 
+  * 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.dosgi.topologymanager;
+
+import static org.junit.Assert.*;
+
+import org.easymock.classextension.EasyMock;
+import org.osgi.framework.BundleContext;
+import org.osgi.service.remoteserviceadmin.EndpointDescription;
+import org.osgi.service.remoteserviceadmin.ExportReference;
+import org.osgi.service.remoteserviceadmin.ExportRegistration;
+import org.osgi.service.remoteserviceadmin.ImportReference;
+import org.osgi.service.remoteserviceadmin.ImportRegistration;
+import org.osgi.service.remoteserviceadmin.RemoteServiceAdminEvent;
+
+import org.junit.Test;
+
+public class RemoteServiceAdminListenerTest {
+
+    @Test
+    public void testIncommingEvent() {
+
+        int type = 0;
+
+        for (; type < 100; ++type) {
+            System.out.println("Type is : " + type);
+            BundleContext bc = EasyMock.createNiceMock(BundleContext.class);
+            TopologyManager tm = EasyMock.createMock(TopologyManager.class);
+            TopologyManagerImport tmi = EasyMock.createMock(TopologyManagerImport.class);
+
+            RemoteServiceAdminEvent rsae = EasyMock.createNiceMock(RemoteServiceAdminEvent.class);
+
+            EasyMock.expect(rsae.getType()).andReturn(type).anyTimes();
+
+            // calls to the tm must only happen in these two cases:
+            if (type == RemoteServiceAdminEvent.EXPORT_UNREGISTRATION) {
+                tm.removeExportReference((ExportReference)EasyMock.anyObject());
+                EasyMock.expectLastCall().once();
+            } else if (type == RemoteServiceAdminEvent.IMPORT_UNREGISTRATION) {
+                tmi.removeImportReference((ImportReference)EasyMock.anyObject());
+                EasyMock.expectLastCall().once();
+            }
+
+            EasyMock.replay(bc);
+            EasyMock.replay(tm);
+            EasyMock.replay(tmi);
+            EasyMock.replay(rsae);
+
+            RemoteServiceAdminListenerImpl rsai = new RemoteServiceAdminListenerImpl(bc, tm,tmi);
+            rsai.remoteAdminEvent(rsae);
+
+            EasyMock.verify(tm);
+
+        }
+    }
+}

Propchange: cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/RemoteServiceAdminListenerTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/RemoteServiceAdminListenerTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Added: cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/TopologyManagerTest.java
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/TopologyManagerTest.java?rev=891650&view=auto
==============================================================================
--- cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/TopologyManagerTest.java (added)
+++ cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/TopologyManagerTest.java Thu Dec 17 11:28:30 2009
@@ -0,0 +1,109 @@
+/** 
+  * 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.dosgi.topologymanager;
+
+import java.util.ArrayList;
+import java.util.HashMap;
+import java.util.List;
+import java.util.Map;
+
+import org.easymock.IAnswer;
+import org.easymock.IMocksControl;
+import org.easymock.classextension.EasyMock;
+import org.osgi.framework.BundleContext;
+import org.osgi.framework.Filter;
+import org.osgi.framework.FrameworkUtil;
+import org.osgi.framework.InvalidSyntaxException;
+import org.osgi.framework.ServiceReference;
+import org.osgi.service.remoteserviceadmin.EndpointDescription;
+import org.osgi.service.remoteserviceadmin.EndpointListener;
+import org.osgi.service.remoteserviceadmin.ExportReference;
+import org.osgi.service.remoteserviceadmin.ExportRegistration;
+
+import org.junit.Test;
+
+public class TopologyManagerTest {
+
+    @Test
+    public void testNotifyListenersOfRemovalIfAppropriate() throws InvalidSyntaxException {
+
+        IMocksControl c = EasyMock.createNiceControl();
+
+        BundleContext bc = c.createMock(BundleContext.class);
+        ServiceReference sref = c.createMock(ServiceReference.class);
+        ExportRegistration exReg = c.createMock(ExportRegistration.class);
+        ExportRegistration exReg2 = c.createMock(ExportRegistration.class);
+        EndpointListener epl = EasyMock.createMock(EndpointListener.class);
+        EndpointDescription epd = c.createMock(EndpointDescription.class);
+        EndpointDescription epd2 = c.createMock(EndpointDescription.class);
+        ExportReference exRef = c.createMock(ExportReference.class);
+        ExportReference exRef2 = c.createMock(ExportReference.class);
+        
+        
+        Map props = new HashMap();
+        String[] oc = new String[1];
+        oc[0] = "myClass";
+        props.put("objectClass", oc);
+        
+        Map props2 = new HashMap();
+        oc = new String[1];
+        oc[0] = "notMyClass";
+        props2.put("objectClass", oc);
+        
+        
+        EasyMock.expect(bc.getService(EasyMock.eq(sref))).andReturn(epl).anyTimes();
+        EasyMock.expect(bc.createFilter((String)EasyMock.anyObject())).andAnswer(new IAnswer<Filter>() {
+            public Filter answer() throws Throwable {
+                return FrameworkUtil.createFilter((String)EasyMock.getCurrentArguments()[0]);
+            }
+        }).anyTimes();
+        EasyMock.expect(sref.getProperty(EasyMock.eq(EndpointListener.ENDPOINT_LISTENER_SCOPE)))
+            .andReturn("(objectClass=myClass)").anyTimes();
+
+        
+        EasyMock.expect(exReg.getExportReference()).andReturn(exRef).anyTimes();
+        EasyMock.expect(exRef.getExportedEndpoint()).andReturn(epd).anyTimes();
+        EasyMock.expect(epd.getProperties()).andReturn(props).anyTimes();
+        
+        EasyMock.expect(exReg2.getExportReference()).andReturn(exRef2).anyTimes();
+        EasyMock.expect(exRef2.getExportedEndpoint()).andReturn(epd2).anyTimes();
+        EasyMock.expect(epd2.getProperties()).andReturn(props2).anyTimes();
+        
+        // must only be called for the first EndpointDestription ! 
+        epl.endpointRemoved(EasyMock.eq(epd), EasyMock.eq("(objectClass=myClass)"));
+        EasyMock.expectLastCall().once();
+        
+        c.replay();
+        EasyMock.replay(epl);
+        
+        TopologyManager tm = new TopologyManager(bc, null);
+
+
+        List<ExportRegistration> exRegs = new ArrayList<ExportRegistration>();
+        exRegs.add(exReg);
+        exRegs.add(exReg2);
+
+        tm.notifyListenersOfRemovalIfAppropriate(sref, exRegs);
+
+        c.verify();
+        EasyMock.verify(epl);
+
+    }
+
+}

Propchange: cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/TopologyManagerTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: cxf/dosgi/trunk/dsw/cxf-topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/TopologyManagerTest.java
------------------------------------------------------------------------------
    svn:keywords = Rev Date

Modified: cxf/dosgi/trunk/dsw/pom.xml
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/dsw/pom.xml?rev=891650&r1=891649&r2=891650&view=diff
==============================================================================
--- cxf/dosgi/trunk/dsw/pom.xml (original)
+++ cxf/dosgi/trunk/dsw/pom.xml Thu Dec 17 11:28:30 2009
@@ -17,10 +17,12 @@
     </parent>
 
     <properties>
-        <topDirectoryLocation>..</topDirectoryLocation>
+      <topDirectoryLocation>..</topDirectoryLocation>
     </properties>
 
     <modules>
       <module>cxf-dsw</module>
+      <module>cxf-topology-manager</module>
+      <module>cxf-osgi-remote-service-admin-interfaces</module>
     </modules> 
 </project>

Modified: cxf/dosgi/trunk/parent/pom.xml
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/parent/pom.xml?rev=891650&r1=891649&r2=891650&view=diff
==============================================================================
--- cxf/dosgi/trunk/parent/pom.xml (original)
+++ cxf/dosgi/trunk/parent/pom.xml Thu Dec 17 11:28:30 2009
@@ -24,6 +24,8 @@
         <spring.osgi.version>1.2.0</spring.osgi.version>
         <zookeeper.version>3.2.1</zookeeper.version>
 
+        <remote.service.admin.interfaces.version>1.0.0</remote.service.admin.interfaces.version>
+
         <servicemix.specs.version>1.3.0</servicemix.specs.version>
 
         <log4j.version>1.2.15</log4j.version>

Modified: cxf/dosgi/trunk/pom.xml
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/pom.xml?rev=891650&r1=891649&r2=891650&view=diff
==============================================================================
--- cxf/dosgi/trunk/pom.xml (original)
+++ cxf/dosgi/trunk/pom.xml Thu Dec 17 11:28:30 2009
@@ -110,7 +110,7 @@
         <module>discovery</module>
         <module>samples</module>
         <module>distribution</module>
-        <module>systests</module>
+    <!--    <module>systests</module>-->
     </modules>
 
     <profiles>

Modified: cxf/dosgi/trunk/samples/discovery/impl/src/main/java/org/apache/cxf/dosgi/samples/discovery/impl/Activator.java
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/samples/discovery/impl/src/main/java/org/apache/cxf/dosgi/samples/discovery/impl/Activator.java?rev=891650&r1=891649&r2=891650&view=diff
==============================================================================
--- cxf/dosgi/trunk/samples/discovery/impl/src/main/java/org/apache/cxf/dosgi/samples/discovery/impl/Activator.java (original)
+++ cxf/dosgi/trunk/samples/discovery/impl/src/main/java/org/apache/cxf/dosgi/samples/discovery/impl/Activator.java Thu Dec 17 11:28:30 2009
@@ -41,7 +41,8 @@
         
         props.put("service.exported.interfaces", "*");
         props.put("service.exported.configs", "org.apache.cxf.ws");
-        props.put("org.apache.cxf.ws.address", getAddress(host, port));
+        props.put("org.apache.cxf.ws.address", getAddress(host, port)); // old obsolete value
+        props.put("endpoint.uri", getAddress(host, port));
 
         reg = bc.registerService(DisplayService.class.getName(), 
                 new DisplayServiceImpl(host + ":" + port), props);