You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@aries.apache.org by cs...@apache.org on 2016/03/11 20:43:41 UTC

[42/50] [abbrv] aries-rsa git commit: Switching to aries package names

http://git-wip-us.apache.org/repos/asf/aries-rsa/blob/5f4c6604/topology-manager/src/test/java/org/apache/aries/rsa/topologymanager/importer/TopologyManagerImportTest.java
----------------------------------------------------------------------
diff --git a/topology-manager/src/test/java/org/apache/aries/rsa/topologymanager/importer/TopologyManagerImportTest.java b/topology-manager/src/test/java/org/apache/aries/rsa/topologymanager/importer/TopologyManagerImportTest.java
new file mode 100644
index 0000000..dc17486
--- /dev/null
+++ b/topology-manager/src/test/java/org/apache/aries/rsa/topologymanager/importer/TopologyManagerImportTest.java
@@ -0,0 +1,88 @@
+/**
+ * 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.aries.rsa.topologymanager.importer;
+
+import java.util.Dictionary;
+import java.util.concurrent.Semaphore;
+import java.util.concurrent.TimeUnit;
+
+import org.apache.aries.rsa.topologymanager.importer.TopologyManagerImport;
+import org.easymock.EasyMock;
+import org.easymock.IAnswer;
+import org.easymock.IMocksControl;
+import org.junit.Test;
+import org.osgi.framework.BundleContext;
+import org.osgi.framework.Constants;
+import org.osgi.framework.ServiceRegistration;
+import org.osgi.service.remoteserviceadmin.EndpointDescription;
+import org.osgi.service.remoteserviceadmin.ImportReference;
+import org.osgi.service.remoteserviceadmin.ImportRegistration;
+import org.osgi.service.remoteserviceadmin.RemoteServiceAdmin;
+
+import static org.junit.Assert.assertTrue;
+
+public class TopologyManagerImportTest {
+
+    @SuppressWarnings({
+     "rawtypes", "unchecked"
+    })
+    @Test
+    public void testImportForNewlyAddedRSA() throws InterruptedException {
+        IMocksControl c = EasyMock.createControl();
+
+        c.makeThreadSafe(true);
+
+        final Semaphore sema = new Semaphore(0);
+
+        ServiceRegistration sreg = c.createMock(ServiceRegistration.class);
+        sreg.unregister();
+        EasyMock.expectLastCall().once();
+        
+        BundleContext bc = c.createMock(BundleContext.class);
+        EasyMock.expect(bc.registerService(EasyMock.anyObject(Class.class),
+                                           EasyMock.anyObject(),
+                                           (Dictionary)EasyMock.anyObject())).andReturn(sreg).anyTimes();
+        EasyMock.expect(bc.getProperty(Constants.FRAMEWORK_UUID)).andReturn("myid");
+
+        EndpointDescription endpoint = c.createMock(EndpointDescription.class);
+        RemoteServiceAdmin rsa = c.createMock(RemoteServiceAdmin.class);
+        final ImportRegistration ireg = c.createMock(ImportRegistration.class);
+        EasyMock.expect(ireg.getException()).andReturn(null).anyTimes();
+        ImportReference iref = c.createMock(ImportReference.class);
+        EasyMock.expect(ireg.getImportReference()).andReturn(iref).anyTimes();
+        EasyMock.expect(iref.getImportedEndpoint()).andReturn(endpoint).anyTimes();
+
+        EasyMock.expect(rsa.importService(EasyMock.eq(endpoint))).andAnswer(new IAnswer<ImportRegistration>() {
+            public ImportRegistration answer() throws Throwable {
+                sema.release();
+                return ireg;
+            }
+        }).once();
+        c.replay();
+
+        TopologyManagerImport tm = new TopologyManagerImport(bc);
+        tm.start();
+        tm.endpointAdded(endpoint, "myFilter");
+        tm.add(rsa);
+        assertTrue("rsa.ImportService should have been called",
+                   sema.tryAcquire(100, TimeUnit.SECONDS));
+        tm.stop();
+        c.verify();
+    }
+}

http://git-wip-us.apache.org/repos/asf/aries-rsa/blob/5f4c6604/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/ActivatorTest.java
----------------------------------------------------------------------
diff --git a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/ActivatorTest.java b/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/ActivatorTest.java
deleted file mode 100644
index 100e3a3..0000000
--- a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/ActivatorTest.java
+++ /dev/null
@@ -1,68 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.cxf.dosgi.topologymanager;
-
-import org.apache.cxf.dosgi.topologymanager.exporter.DefaultExportPolicy;
-import org.apache.cxf.dosgi.topologymanager.exporter.TopologyManagerExport;
-import org.easymock.Capture;
-import org.easymock.EasyMock;
-import org.easymock.IAnswer;
-import org.easymock.IMocksControl;
-import org.junit.Test;
-import org.osgi.framework.Bundle;
-import org.osgi.framework.BundleContext;
-import org.osgi.framework.Constants;
-import org.osgi.framework.Filter;
-import org.osgi.framework.FrameworkUtil;
-import org.osgi.framework.ServiceReference;
-
-public class ActivatorTest {
-
-    @Test
-    public void testStart() throws Exception {
-        IMocksControl c = EasyMock.createNiceControl();
-        BundleContext context = c.createMock(BundleContext.class);
-        EasyMock.expect(context.getProperty(Constants.FRAMEWORK_UUID)).andReturn("myid");
-        context.addServiceListener(EasyMock.isA(TopologyManagerExport.class));
-        EasyMock.expectLastCall();
-        final Capture<String> filter = EasyMock.newCapture();
-        EasyMock.expect(context.createFilter(EasyMock.capture(filter)))
-            .andAnswer(new IAnswer<Filter>() {
-                public Filter answer() throws Throwable {
-                    return FrameworkUtil.createFilter(filter.getValue());
-                }
-            }).times(2);
-        ServiceReference<?> sref = c.createMock(ServiceReference.class);
-        Bundle bundle = c.createMock(Bundle.class);
-        EasyMock.expect(sref.getBundle()).andReturn(bundle).anyTimes();
-        EasyMock.expect(context.getServiceReferences((String)null, Activator.DOSGI_SERVICES))
-            .andReturn(new ServiceReference[]{sref});
-
-        c.replay();
-        Activator activator = new Activator();
-        activator.doStart(context, new DefaultExportPolicy());
-        c.verify();
-        
-        c.reset();
-        c.replay();
-        activator.doStop(context);
-        c.verify();
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/aries-rsa/blob/5f4c6604/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/exporter/EndpointListenerNotifierTest.java
----------------------------------------------------------------------
diff --git a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/exporter/EndpointListenerNotifierTest.java b/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/exporter/EndpointListenerNotifierTest.java
deleted file mode 100644
index 04bd017..0000000
--- a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/exporter/EndpointListenerNotifierTest.java
+++ /dev/null
@@ -1,160 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.cxf.dosgi.topologymanager.exporter;
-
-import java.util.Arrays;
-import java.util.Collection;
-import java.util.Dictionary;
-import java.util.HashSet;
-import java.util.Hashtable;
-import java.util.Iterator;
-import java.util.Map;
-import java.util.Set;
-
-import org.easymock.EasyMock;
-import org.junit.Assert;
-import org.junit.Test;
-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.RemoteConstants;
-
-import static org.hamcrest.core.Is.is;
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertThat;
-
-@SuppressWarnings({
-    "rawtypes", "unchecked"
-   })
-public class EndpointListenerNotifierTest {
-
-    @Test
-    public void testNotifyListener() throws InvalidSyntaxException {
-        EndpointDescription endpoint1 = createEndpoint("myClass");
-        EndpointDescription endpoint2 = createEndpoint("notMyClass");
-
-        // Expect listener to be called for endpoint1 but not for endpoint2 
-        EndpointListener epl = listenerExpects(endpoint1, "(objectClass=myClass)");
-
-        EndpointRepository exportRepository = new EndpointRepository();
-        EndpointListenerNotifier tm = new EndpointListenerNotifier(exportRepository);
-
-        EasyMock.replay(epl);
-        Set<Filter> filters = new HashSet<Filter>();
-        filters.add(FrameworkUtil.createFilter("(objectClass=myClass)"));
-        tm.add(epl, filters);
-        tm.endpointAdded(endpoint1, null);
-        tm.endpointAdded(endpoint2, null);
-        tm.endpointRemoved(endpoint1, null);
-        tm.endpointRemoved(endpoint2, null);
-        EasyMock.verify(epl);
-    }
-
-    private EndpointListener listenerExpects(EndpointDescription endpoint, String filter) {
-        EndpointListener epl = EasyMock.createStrictMock(EndpointListener.class);
-        epl.endpointAdded(EasyMock.eq(endpoint), EasyMock.eq(filter));
-        EasyMock.expectLastCall().once();
-        epl.endpointRemoved(EasyMock.eq(endpoint), EasyMock.eq(filter));
-        EasyMock.expectLastCall().once();
-        return epl;
-    }
-    
-    @Test
-    public void testNotifyListeners() throws InvalidSyntaxException {
-        EndpointDescription endpoint1 = createEndpoint("myClass");
-        
-        EndpointListener epl = EasyMock.createStrictMock(EndpointListener.class);
-        epl.endpointAdded(EasyMock.eq(endpoint1), EasyMock.eq("(objectClass=myClass)"));
-        EasyMock.expectLastCall().once();
-        epl.endpointRemoved(EasyMock.eq(endpoint1), EasyMock.eq("(objectClass=myClass)"));
-        EasyMock.expectLastCall().once();
-
-        EndpointRepository exportRepository = new EndpointRepository();
-        EndpointListenerNotifier tm = new EndpointListenerNotifier(exportRepository);
-
-        EasyMock.replay(epl);
-        Set<Filter> filters = new HashSet<Filter>();
-        filters.add(FrameworkUtil.createFilter("(objectClass=myClass)"));
-        tm.add(epl, filters);
-        tm.endpointAdded(endpoint1, null);
-        tm.endpointRemoved(endpoint1, null);
-        tm.remove(epl);
-        EasyMock.verify(epl);
-    }
-    
-    public EndpointDescription createEndpoint(String iface) {
-        Map<String, Object> props = new Hashtable<String, Object>(); 
-        props.put("objectClass", new String[]{iface});
-        props.put(RemoteConstants.ENDPOINT_ID, iface);
-        props.put(RemoteConstants.SERVICE_IMPORTED_CONFIGS, "any");
-        return new EndpointDescription(props);
-    }
-
-    @Test
-    public void testNormalizeScopeForSingleString() {
-        ServiceReference sr = createListenerServiceWithFilter("(myProp=A)");
-        Set<Filter> res = EndpointListenerNotifier.getFiltersFromEndpointListenerScope(sr);
-        assertEquals(1, res.size());
-        Filter filter = res.iterator().next();
-        filterMatches(filter);
-    }
-
-    @Test
-    public void testNormalizeScopeForStringArray() {
-        String[] filters = {"(myProp=A)", "(otherProp=B)"};
-        ServiceReference sr = createListenerServiceWithFilter(filters); 
-        Set<Filter> res = EndpointListenerNotifier.getFiltersFromEndpointListenerScope(sr);
-        assertEquals(filters.length, res.size());
-        Iterator<Filter> it = res.iterator();
-        Filter filter1 = it.next();
-        Filter filter2 = it.next();
-        Dictionary<String, String> props = new Hashtable();
-        props.put("myProp", "A");
-        assertThat(filter1.match(props) || filter2.match(props), is(true));
-    }
-
-    @Test
-    public void testNormalizeScopeForCollection() {
-        Collection<String> collection = Arrays.asList("(myProp=A)", "(otherProp=B)");
-        ServiceReference sr = createListenerServiceWithFilter(collection);
-        Set<Filter> res = EndpointListenerNotifier.getFiltersFromEndpointListenerScope(sr);
-        Iterator<Filter> it = res.iterator();
-        Filter filter1 = it.next();
-        Filter filter2 = it.next();
-        Dictionary<String, String> props = new Hashtable();
-        props.put("myProp", "A");
-        Assert.assertThat(filter1.match(props) || filter2.match(props), is(true));
-    }
-    
-    private void filterMatches(Filter filter) {
-        Dictionary<String, String> props = new Hashtable();
-        props.put("myProp", "A");
-        Assert.assertTrue("Filter should match", filter.match(props));
-    }
-
-    private ServiceReference createListenerServiceWithFilter(Object filters) {
-        ServiceReference sr = EasyMock.createMock(ServiceReference.class);
-        EasyMock.expect(sr.getProperty(EndpointListener.ENDPOINT_LISTENER_SCOPE)).andReturn(filters);
-        EasyMock.replay(sr);
-        return sr;
-    }
-}

http://git-wip-us.apache.org/repos/asf/aries-rsa/blob/5f4c6604/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/exporter/EndpointRepositoryTest.java
----------------------------------------------------------------------
diff --git a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/exporter/EndpointRepositoryTest.java b/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/exporter/EndpointRepositoryTest.java
deleted file mode 100644
index cb07f43..0000000
--- a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/exporter/EndpointRepositoryTest.java
+++ /dev/null
@@ -1,82 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.cxf.dosgi.topologymanager.exporter;
-
-import java.util.Arrays;
-import java.util.Hashtable;
-import java.util.List;
-import java.util.Map;
-
-import org.easymock.EasyMock;
-import org.easymock.IMocksControl;
-import org.junit.Test;
-import org.osgi.framework.Bundle;
-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.RemoteConstants;
-import org.osgi.service.remoteserviceadmin.RemoteServiceAdmin;
-
-public class EndpointRepositoryTest {
-
-    @Test
-    public void testAddRemove() throws InvalidSyntaxException {
-        EndpointDescription ep1 = createEndpoint("my");
-        
-        IMocksControl c = EasyMock.createControl();
-        ServiceReference<?> sref = createService(c);
-        RemoteServiceAdmin rsa = c.createMock(RemoteServiceAdmin.class);
-        EndpointListener notifier = c.createMock(EndpointListener.class);
-        
-        notifier.endpointAdded(ep1, null);
-        EasyMock.expectLastCall();
-        
-        c.replay();
-        EndpointRepository repo = new EndpointRepository();
-        repo.setNotifier(notifier);
-        List<EndpointDescription> endpoints = Arrays.asList(ep1);
-        repo.addEndpoints(sref, rsa, endpoints);
-        c.verify();
-
-        c.reset();
-        notifier.endpointRemoved(ep1, null);
-        EasyMock.expectLastCall();
-
-        c.replay();
-        repo.removeRemoteServiceAdmin(rsa);
-        c.verify();
-    }
-
-    private ServiceReference<?> createService(IMocksControl c) {
-        ServiceReference<?> sref = c.createMock(ServiceReference.class);
-        Bundle bundle = c.createMock(Bundle.class);
-        EasyMock.expect(bundle.getSymbolicName()).andReturn("myBundle");
-        EasyMock.expect(sref.getBundle()).andReturn(bundle);
-        return sref;
-    }
-
-    public EndpointDescription createEndpoint(String iface) {
-        Map<String, Object> props = new Hashtable<String, Object>(); 
-        props.put("objectClass", new String[]{iface});
-        props.put(RemoteConstants.ENDPOINT_ID, iface);
-        props.put(RemoteConstants.SERVICE_IMPORTED_CONFIGS, "any");
-        return new EndpointDescription(props);
-    }
-}

http://git-wip-us.apache.org/repos/asf/aries-rsa/blob/5f4c6604/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/exporter/TopologyManagerExportTest.java
----------------------------------------------------------------------
diff --git a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/exporter/TopologyManagerExportTest.java b/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/exporter/TopologyManagerExportTest.java
deleted file mode 100644
index 0eda150..0000000
--- a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/exporter/TopologyManagerExportTest.java
+++ /dev/null
@@ -1,153 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.cxf.dosgi.topologymanager.exporter;
-
-import java.util.Collections;
-import java.util.HashMap;
-import java.util.Map;
-import java.util.concurrent.Executor;
-
-import org.apache.cxf.dosgi.dsw.api.ExportPolicy;
-import org.easymock.EasyMock;
-import org.easymock.IMocksControl;
-import org.junit.Test;
-import org.osgi.framework.Bundle;
-import org.osgi.framework.Constants;
-import org.osgi.framework.ServiceEvent;
-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 static org.easymock.EasyMock.expectLastCall;
-
-@SuppressWarnings({"rawtypes", "unchecked"})
-public class TopologyManagerExportTest {
-
-    /**
-     * This tests if the topology manager handles a service marked to be exported correctly by exporting it to
-     * an available RemoteServiceAdmin and notifying an EndpointListener afterwards.
-     *
-     * @throws Exception
-     */
-    @Test
-    public void testServiceExportUnexport() throws Exception {
-        IMocksControl c = EasyMock.createControl();
-        RemoteServiceAdmin rsa = c.createMock(RemoteServiceAdmin.class);
-        final EndpointListener notifier = c.createMock(EndpointListener.class);
-        final ServiceReference sref = createUserService(c);
-        EndpointDescription epd = createEndpoint();
-        expectServiceExported(c, rsa, notifier, sref, epd);
-        
-        c.replay();
-        EndpointRepository endpointRepo = new EndpointRepository();
-        endpointRepo.setNotifier(notifier);
-        Executor executor = syncExecutor();
-        ExportPolicy policy = new DefaultExportPolicy();
-        TopologyManagerExport exportManager = new TopologyManagerExport(endpointRepo, executor, policy);
-        exportManager.add(rsa);
-        exportManager.serviceChanged(new ServiceEvent(ServiceEvent.REGISTERED, sref));
-        c.verify();
-        
-        c.reset();
-        notifier.endpointRemoved(epd, null);
-        expectLastCall().once();
-        c.replay();
-        exportManager.serviceChanged(new ServiceEvent(ServiceEvent.UNREGISTERING, sref));
-        c.verify();
-        
-        c.reset();
-        c.replay();
-        exportManager.serviceChanged(new ServiceEvent(ServiceEvent.MODIFIED, sref));
-        c.verify();
-        
-        c.reset();
-        c.replay();
-        exportManager.remove(rsa);
-        c.verify();
-    }
-
-    @Test
-    public void testExportExisting() throws Exception {
-        IMocksControl c = EasyMock.createControl();
-        RemoteServiceAdmin rsa = c.createMock(RemoteServiceAdmin.class);
-        final EndpointListenerNotifier mockEpListenerNotifier = c.createMock(EndpointListenerNotifier.class);
-        final ServiceReference sref = createUserService(c);
-        expectServiceExported(c, rsa, mockEpListenerNotifier, sref, createEndpoint());
-        c.replay();
-
-        EndpointRepository endpointRepo = new EndpointRepository();
-        endpointRepo.setNotifier(mockEpListenerNotifier);
-        ExportPolicy policy = new DefaultExportPolicy();
-        TopologyManagerExport exportManager = new TopologyManagerExport(endpointRepo, syncExecutor(), policy);
-        exportManager.serviceChanged(new ServiceEvent(ServiceEvent.REGISTERED, sref));
-        exportManager.add(rsa);
-        c.verify();
-    }
-
-    private void expectServiceExported(IMocksControl c, RemoteServiceAdmin rsa,
-                                       final EndpointListener listener,
-                                       final ServiceReference sref, EndpointDescription epd) {
-        ExportRegistration exportRegistration = createExportRegistration(c, epd);
-        EasyMock.expect(rsa.exportService(EasyMock.same(sref), (Map<String, Object>)EasyMock.anyObject()))
-            .andReturn(Collections.singletonList(exportRegistration)).once();
-        listener.endpointAdded(epd, null); 
-        EasyMock.expectLastCall().once();
-    }
-
-    private Executor syncExecutor() {
-        return new Executor() {
-            @Override
-            public void execute(Runnable command) {
-                command.run();
-            }
-        };
-    }
-
-    private ExportRegistration createExportRegistration(IMocksControl c, EndpointDescription endpoint) {
-        ExportRegistration exportRegistration = c.createMock(ExportRegistration.class);
-        ExportReference exportReference = c.createMock(ExportReference.class);
-        EasyMock.expect(exportRegistration.getExportReference()).andReturn(exportReference).anyTimes();
-        EasyMock.expect(exportRegistration.getException()).andReturn(null).anyTimes();
-        EasyMock.expect(exportReference.getExportedEndpoint()).andReturn(endpoint).anyTimes();
-        return exportRegistration;
-    }
-
-    private EndpointDescription createEndpoint() {
-        Map<String, Object> props = new HashMap<String, Object>();
-        props.put(RemoteConstants.ENDPOINT_ID, "1");
-        props.put(Constants.OBJECTCLASS, new String[] {"abc"});
-        props.put(RemoteConstants.SERVICE_IMPORTED_CONFIGS, "cxf");
-        return new EndpointDescription(props);
-    }
-
-    private ServiceReference createUserService(IMocksControl c) {
-        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).atLeastOnce();
-        EasyMock.expect(sref.getProperty("objectClass")).andReturn("org.My").anyTimes();
-        EasyMock.expect(srefBundle.getSymbolicName()).andReturn("serviceBundleName").atLeastOnce();
-        return sref;
-    }
-}

http://git-wip-us.apache.org/repos/asf/aries-rsa/blob/5f4c6604/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/EndpointListenerImplTest.java
----------------------------------------------------------------------
diff --git a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/EndpointListenerImplTest.java b/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/EndpointListenerImplTest.java
deleted file mode 100644
index c736197..0000000
--- a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/EndpointListenerImplTest.java
+++ /dev/null
@@ -1,111 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.cxf.dosgi.topologymanager.importer;
-
-import java.util.Dictionary;
-import java.util.List;
-
-import org.easymock.EasyMock;
-import org.easymock.IAnswer;
-import org.easymock.IMocksControl;
-import org.junit.Assert;
-import org.junit.Test;
-import org.osgi.framework.BundleContext;
-import org.osgi.framework.ServiceRegistration;
-import org.osgi.service.remoteserviceadmin.EndpointListener;
-
-public class EndpointListenerImplTest extends Assert {
-
-    int testCase;
-
-    @SuppressWarnings({
-     "rawtypes", "unchecked"
-    })
-    @Test
-    public void testScopeChange() {
-        IMocksControl c = EasyMock.createNiceControl();
-        BundleContext bc = c.createMock(BundleContext.class);
-        TopologyManagerImport tm = c.createMock(TopologyManagerImport.class);
-        ServiceRegistration sr = c.createMock(ServiceRegistration.class);
-
-        // expect Listener registration
-        EasyMock.expect(bc.registerService(EasyMock.anyObject(Class.class),
-                                           EasyMock.anyObject(),
-                                           (Dictionary)EasyMock.anyObject())).andReturn(sr).atLeastOnce();
-
-        sr.setProperties((Dictionary)EasyMock.anyObject());
-
-        // expect property changes based on later calls
-        EasyMock.expectLastCall().andAnswer(new IAnswer<Object>() {
-
-            public Object answer() throws Throwable {
-                Object[] args = EasyMock.getCurrentArguments();
-                Dictionary props = (Dictionary)args[0];
-                List<String> scope = (List<String>)props.get(EndpointListener.ENDPOINT_LISTENER_SCOPE);
-                switch (testCase) {
-                case 1:
-                    assertEquals(1, scope.size());
-                    assertEquals("(a=b)", scope.get(0));
-                    break;
-                case 2:
-                    assertEquals(0, scope.size());
-                    break;
-                case 3:
-                    assertEquals("adding entry to empty list failed", 1, scope.size());
-                    assertEquals("(a=b)", scope.get(0));
-                    break;
-                case 4:
-                    assertEquals("adding second entry failed", 2, scope.size());
-                    assertNotNull(scope.contains("(a=b)"));
-                    assertNotNull(scope.contains("(c=d)"));
-                    break;
-                case 5:
-                    assertEquals("remove failed", 1, scope.size());
-                    assertEquals("(c=d)", scope.get(0));
-                    break;
-                default:
-                    assertTrue("This should not happen!", false);
-                }
-                return null;
-            }
-        }).atLeastOnce();
-
-        c.replay();
-
-        EndpointListenerManager endpointListener = new EndpointListenerManager(bc, tm);
-
-        endpointListener.start();
-
-        testCase = 1;
-        endpointListener.extendScope("(a=b)");
-        testCase = 2;
-        endpointListener.reduceScope("(a=b)");
-
-        testCase = 3;
-        endpointListener.extendScope("(a=b)");
-        testCase = 4;
-        endpointListener.extendScope("(c=d)");
-        testCase = 5;
-        endpointListener.reduceScope("(a=b)");
-
-        endpointListener.stop();
-
-        c.verify();
-    }
-}

http://git-wip-us.apache.org/repos/asf/aries-rsa/blob/5f4c6604/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/ListenerHookImplTest.java
----------------------------------------------------------------------
diff --git a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/ListenerHookImplTest.java b/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/ListenerHookImplTest.java
deleted file mode 100644
index 1e2f90c..0000000
--- a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/ListenerHookImplTest.java
+++ /dev/null
@@ -1,89 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.cxf.dosgi.topologymanager.importer;
-
-import java.util.Collection;
-import java.util.Collections;
-import java.util.Dictionary;
-import java.util.Hashtable;
-
-import org.easymock.EasyMock;
-import org.easymock.IMocksControl;
-import org.junit.Test;
-import org.osgi.framework.BundleContext;
-import org.osgi.framework.Filter;
-import org.osgi.framework.FrameworkUtil;
-import org.osgi.framework.InvalidSyntaxException;
-import org.osgi.framework.hooks.service.ListenerHook.ListenerInfo;
-import org.osgi.service.remoteserviceadmin.RemoteConstants;
-
-import static org.junit.Assert.assertFalse;
-import static org.junit.Assert.assertTrue;
-
-public class ListenerHookImplTest {
-
-    @Test
-    public void testExtendFilter() throws InvalidSyntaxException {
-        String filter = "(a=b)";
-        BundleContext bc = createBundleContext();
-        filter = new ListenerHookImpl(bc, null).extendFilter(filter);
-
-        Filter f = FrameworkUtil.createFilter(filter);
-
-        Dictionary<String, String> m = new Hashtable<String, String>();
-        m.put("a", "b");
-        assertTrue(filter + " filter must match as uuid is missing", f.match(m));
-        m.put(RemoteConstants.ENDPOINT_FRAMEWORK_UUID, "MyUUID");
-        assertFalse(filter + " filter must NOT match as uuid is the local one", f.match(m));
-    }
-    
-    @Test
-    public void testAddedRemoved() throws InvalidSyntaxException {
-        IMocksControl c = EasyMock.createControl();
-        String filter = "(objectClass=My)";
-        BundleContext bc = createBundleContext();
-        BundleContext listenerBc = createBundleContext();
-        ServiceInterestListener serviceInterestListener = c.createMock(ServiceInterestListener.class);
-        ListenerHookImpl listenerHook = new ListenerHookImpl(bc, serviceInterestListener);
-
-        ListenerInfo listener = c.createMock(ListenerInfo.class);
-        EasyMock.expect(listener.getBundleContext()).andReturn(listenerBc);
-        EasyMock.expect(listener.getFilter()).andReturn(filter).atLeastOnce();
-        
-        // Main assertions
-        serviceInterestListener.addServiceInterest(listenerHook.extendFilter(filter));
-        EasyMock.expectLastCall();
-        serviceInterestListener.removeServiceInterest(listenerHook.extendFilter(filter));
-        EasyMock.expectLastCall();
-
-        Collection<ListenerInfo> listeners = Collections.singletonList(listener);
-        
-        c.replay();
-        listenerHook.added(listeners);
-        listenerHook.removed(listeners);
-        c.verify();
-    }
-
-    private BundleContext createBundleContext() {
-        BundleContext bc = EasyMock.createNiceMock(BundleContext.class);
-        EasyMock.expect(bc.getProperty(EasyMock.eq("org.osgi.framework.uuid"))).andReturn("MyUUID").atLeastOnce();
-        EasyMock.replay(bc);
-        return bc;
-    }
-}

http://git-wip-us.apache.org/repos/asf/aries-rsa/blob/5f4c6604/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/ReferenceCounterTest.java
----------------------------------------------------------------------
diff --git a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/ReferenceCounterTest.java b/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/ReferenceCounterTest.java
deleted file mode 100644
index 3ab78db..0000000
--- a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/ReferenceCounterTest.java
+++ /dev/null
@@ -1,42 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.cxf.dosgi.topologymanager.importer;
-
-import org.junit.Test;
-
-import static org.junit.Assert.assertEquals;
-
-public class ReferenceCounterTest {
-
-    @Test
-    public void testCounter() {
-        ReferenceCounter<String> counter = new ReferenceCounter<String>();
-        assertEquals(-1, counter.remove("a"));
-        assertEquals(-1, counter.remove("a"));
-        assertEquals(1, counter.add("a"));
-        assertEquals(2, counter.add("a"));
-        assertEquals(3, counter.add("a"));
-        assertEquals(2, counter.remove("a"));
-        assertEquals(1, counter.remove("a"));
-        assertEquals(2, counter.add("a"));
-        assertEquals(1, counter.remove("a"));
-        assertEquals(0, counter.remove("a"));
-        assertEquals(-1, counter.remove("a"));
-    }
-}

http://git-wip-us.apache.org/repos/asf/aries-rsa/blob/5f4c6604/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/TopologyManagerImportTest.java
----------------------------------------------------------------------
diff --git a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/TopologyManagerImportTest.java b/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/TopologyManagerImportTest.java
deleted file mode 100644
index 00be969..0000000
--- a/topology-manager/src/test/java/org/apache/cxf/dosgi/topologymanager/importer/TopologyManagerImportTest.java
+++ /dev/null
@@ -1,87 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.cxf.dosgi.topologymanager.importer;
-
-import java.util.Dictionary;
-import java.util.concurrent.Semaphore;
-import java.util.concurrent.TimeUnit;
-
-import org.easymock.EasyMock;
-import org.easymock.IAnswer;
-import org.easymock.IMocksControl;
-import org.junit.Test;
-import org.osgi.framework.BundleContext;
-import org.osgi.framework.Constants;
-import org.osgi.framework.ServiceRegistration;
-import org.osgi.service.remoteserviceadmin.EndpointDescription;
-import org.osgi.service.remoteserviceadmin.ImportReference;
-import org.osgi.service.remoteserviceadmin.ImportRegistration;
-import org.osgi.service.remoteserviceadmin.RemoteServiceAdmin;
-
-import static org.junit.Assert.assertTrue;
-
-public class TopologyManagerImportTest {
-
-    @SuppressWarnings({
-     "rawtypes", "unchecked"
-    })
-    @Test
-    public void testImportForNewlyAddedRSA() throws InterruptedException {
-        IMocksControl c = EasyMock.createControl();
-
-        c.makeThreadSafe(true);
-
-        final Semaphore sema = new Semaphore(0);
-
-        ServiceRegistration sreg = c.createMock(ServiceRegistration.class);
-        sreg.unregister();
-        EasyMock.expectLastCall().once();
-        
-        BundleContext bc = c.createMock(BundleContext.class);
-        EasyMock.expect(bc.registerService(EasyMock.anyObject(Class.class),
-                                           EasyMock.anyObject(),
-                                           (Dictionary)EasyMock.anyObject())).andReturn(sreg).anyTimes();
-        EasyMock.expect(bc.getProperty(Constants.FRAMEWORK_UUID)).andReturn("myid");
-
-        EndpointDescription endpoint = c.createMock(EndpointDescription.class);
-        RemoteServiceAdmin rsa = c.createMock(RemoteServiceAdmin.class);
-        final ImportRegistration ireg = c.createMock(ImportRegistration.class);
-        EasyMock.expect(ireg.getException()).andReturn(null).anyTimes();
-        ImportReference iref = c.createMock(ImportReference.class);
-        EasyMock.expect(ireg.getImportReference()).andReturn(iref).anyTimes();
-        EasyMock.expect(iref.getImportedEndpoint()).andReturn(endpoint).anyTimes();
-
-        EasyMock.expect(rsa.importService(EasyMock.eq(endpoint))).andAnswer(new IAnswer<ImportRegistration>() {
-            public ImportRegistration answer() throws Throwable {
-                sema.release();
-                return ireg;
-            }
-        }).once();
-        c.replay();
-
-        TopologyManagerImport tm = new TopologyManagerImport(bc);
-        tm.start();
-        tm.endpointAdded(endpoint, "myFilter");
-        tm.add(rsa);
-        assertTrue("rsa.ImportService should have been called",
-                   sema.tryAcquire(100, TimeUnit.SECONDS));
-        tm.stop();
-        c.verify();
-    }
-}