You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@sling.apache.org by ro...@apache.org on 2017/11/07 09:23:04 UTC

[sling-org-apache-sling-commons-osgi] 04/38: Remove adapter stuff from osgi/commons

This is an automated email from the ASF dual-hosted git repository.

rombert pushed a commit to annotated tag org.apache.sling.commons.osgi-2.0.2-incubator
in repository https://gitbox.apache.org/repos/asf/sling-org-apache-sling-commons-osgi.git

commit d93b1e07607fd939ce7f0e307c9778f9d856e7f1
Author: Felix Meschberger <fm...@apache.org>
AuthorDate: Thu Jan 17 15:53:48 2008 +0000

    Remove adapter stuff from osgi/commons
    
    git-svn-id: https://svn.apache.org/repos/asf/incubator/sling/whiteboard/fmeschbe/resource/osgi/commons@612850 13f79535-47bb-0310-9956-ffa450edef68
---
 pom.xml                                            |   3 -
 .../apache/sling/osgi/commons/AdapterFactory.java  |  80 ----
 .../apache/sling/osgi/commons/AdapterManager.java  |  52 ---
 .../apache/sling/osgi/commons/SlingAdaptable.java  |  40 --
 .../commons/internal/AdapterFactoryDescriptor.java |  47 ---
 .../internal/AdapterFactoryDescriptorKey.java      |  88 -----
 .../internal/AdapterFactoryDescriptorMap.java      |  39 --
 .../osgi/commons/internal/AdapterManagerImpl.java  | 427 ---------------------
 .../osgi/commons/internal/AdapterManagerTest.java  | 245 ------------
 .../osgi/commons/mock/MockAdapterFactory.java      |  53 ---
 .../apache/sling/osgi/commons/mock/MockBundle.java | 122 ------
 .../osgi/commons/mock/MockComponentContext.java    |  79 ----
 .../osgi/commons/mock/MockServiceReference.java    |  62 ---
 13 files changed, 1337 deletions(-)

diff --git a/pom.xml b/pom.xml
index 4cb2d06..1a60e69 100644
--- a/pom.xml
+++ b/pom.xml
@@ -62,9 +62,6 @@
                         <Export-Package>
                             org.apache.sling.osgi.commons;version=${pom.version}
                         </Export-Package>
-                        <Private-Package>
-                            org.apache.sling.osgi.commons.internal
-                        </Private-Package>
                     </instructions>
                 </configuration>
             </plugin>
diff --git a/src/main/java/org/apache/sling/osgi/commons/AdapterFactory.java b/src/main/java/org/apache/sling/osgi/commons/AdapterFactory.java
deleted file mode 100644
index beaabc2..0000000
--- a/src/main/java/org/apache/sling/osgi/commons/AdapterFactory.java
+++ /dev/null
@@ -1,80 +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.sling.osgi.commons;
-
-/**
- * The <code>AdapterFactory</code> interface defines the API for helpers which
- * may be provided to enhance the adaptability of adaptable objects.
- * <p>
- * Implementations of this interface are registered as OSGi services and are
- * used by the {@link AdapterManager} to adapt objects on demand. The
- * <code>AdapterFactory</code> services are not really intended to be used by
- * clients directly.
- */
-public interface AdapterFactory {
-
-    /**
-     * The service name to use when registering implementations of this
-     * interface as services (value is
-     * "org.apache.sling.osgi.commons.AdapterFactory").
-     */
-    static final String SERVICE_NAME = AdapterFactory.class.getName();
-
-    /**
-     * The service registration property listing the fully qualified names of
-     * classes which can be adapted by this adapter factory (value is
-     * "adaptables"). The "adaptable" parameters of the
-     * {@link #getAdapter(Object, Class)} method must be an instance of any of
-     * these classes for this factory to be able to adapt the object.
-     */
-    static final String ADAPTABLE_CLASSES = "adaptables";
-
-    /**
-     * The service registration property listing the fully qualified names of
-     * classes to which this factory can adapt adaptables (value is "adapters").
-     */
-    static final String ADAPTER_CLASSES = "adapters";
-
-    /**
-     * Adapt the given object to the adaptable type. The adaptable object is
-     * guaranteed to be an instance of one of the classes listed in the
-     * {@link #ADAPTABLE_CLASSES} services registration property. The type
-     * parameter is on of the classes listed in the {@link #ADAPTER_CLASSES}
-     * service registration properties.
-     * <p>
-     * This method may return <code>null</code> if the adaptable object may
-     * not be adapted to the adapter (target) type for any reason. In this case,
-     * the implementation should log a message to the log facility noting the
-     * cause for not being able to adapt.
-     * <p>
-     * Note that the <code>adaptable</code> object is not required to
-     * implement the <code>Adaptable</code> interface, though most of the time
-     * this method is called by means of calling the
-     * {@link SlingAdaptable#adaptTo(Class)} method.
-     * 
-     * @param <AdapterType> The generic type of the adapter (target) type.
-     * @param adaptable The object to adapt to the adapter type.
-     * @param type The type to which the object is to be adapted.
-     * @return The adapted object or <code>null</code> if this factory
-     *         instance cannot adapt the object.
-     */
-    <AdapterType> AdapterType getAdapter(Object adaptable,
-            Class<AdapterType> type);
-
-}
diff --git a/src/main/java/org/apache/sling/osgi/commons/AdapterManager.java b/src/main/java/org/apache/sling/osgi/commons/AdapterManager.java
deleted file mode 100644
index 0a142e9..0000000
--- a/src/main/java/org/apache/sling/osgi/commons/AdapterManager.java
+++ /dev/null
@@ -1,52 +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.sling.osgi.commons;
-
-/**
- * The <code>AdapterManager</code> defines the service interface for a manager
- * for object adaption. The adapter manager coordinates the registered
- * {@link AdapterFactory} services on behalf of clients wishing to adapt objects
- * to other types. One such client is the {@link SlingAdaptable} class, which
- * uses the implementation of this bundle to adapt "itself".
- * <p>
- * This interface is not intended to be implemented by clients. Rather it is
- * used to define the service API used by the implementation is this bundle.
- */
-public interface AdapterManager {
-
-    /**
-     * Returns an adapter object of the requested <code>AdapterType</code> for
-     * the given <code>adaptable</code> object.
-     * <p>
-     * The <code>adaptable</code> object may be any non-<code>null</code>
-     * object and is not required to implement the <code>Adaptable</code>
-     * interface.
-     * 
-     * @param <AdapterType> The generic type of the adapter (target) type.
-     * @param adaptable The object to adapt to the adapter type.
-     * @param type The type to which the object is to be adapted.
-     * @return The adapted object or <code>null</code> if no factory exists to
-     *         adapt the <code>adaptable</code> to the
-     *         <code>AdapterType</code> or if the <code>adaptable</code>
-     *         cannot be adapted for any other reason.
-     */
-    <AdapterType> AdapterType getAdapter(Object adaptable,
-            Class<AdapterType> type);
-
-}
\ No newline at end of file
diff --git a/src/main/java/org/apache/sling/osgi/commons/SlingAdaptable.java b/src/main/java/org/apache/sling/osgi/commons/SlingAdaptable.java
deleted file mode 100644
index 0705d9c..0000000
--- a/src/main/java/org/apache/sling/osgi/commons/SlingAdaptable.java
+++ /dev/null
@@ -1,40 +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.sling.osgi.commons;
-
-import org.apache.sling.api.adapter.Adaptable;
-import org.apache.sling.osgi.commons.internal.AdapterManagerImpl;
-
-/**
- * The <code>SlingAdaptable</code> class is an (abstract) default
- * implementation of the <code>Adaptable</code> interface. It just uses the
- * default {@link AdapterManager} implemented in this bundle to adapt the itself
- * to the requested type.
- * <p>
- * Extensions of this class may overwrite the {@link #adaptTo(Class)} method
- * using their own knowledge of adapters and may call this base class
- * implementation to fall back to an extended adapters.
- */
-public abstract class SlingAdaptable implements Adaptable {
-
-    public <AdapterType> AdapterType adaptTo(Class<AdapterType> type) {
-        return AdapterManagerImpl.getInstance().getAdapter(this, type);
-    }
-
-}
diff --git a/src/main/java/org/apache/sling/osgi/commons/internal/AdapterFactoryDescriptor.java b/src/main/java/org/apache/sling/osgi/commons/internal/AdapterFactoryDescriptor.java
deleted file mode 100644
index 1408fe5..0000000
--- a/src/main/java/org/apache/sling/osgi/commons/internal/AdapterFactoryDescriptor.java
+++ /dev/null
@@ -1,47 +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.sling.osgi.commons.internal;
-
-import org.apache.sling.osgi.commons.AdapterFactory;
-
-/**
- * The <code>AdapterFactoryDescriptor</code> is an entry in the
- * {@link AdapterFactoryDescriptorMap} conveying the list of adapter (target)
- * types and the respective {@link AdapterFactory}.
- */
-public class AdapterFactoryDescriptor {
-    
-    private AdapterFactory factory;
-
-    private String[] adapters;
-
-    public AdapterFactoryDescriptor(AdapterFactory factory, String[] adapters) {
-        this.factory = factory;
-        this.adapters = adapters;
-    }
-
-    public AdapterFactory getFactory() {
-        return factory;
-    }
-
-    public String[] getAdapters() {
-        return adapters;
-    }
-
-}
diff --git a/src/main/java/org/apache/sling/osgi/commons/internal/AdapterFactoryDescriptorKey.java b/src/main/java/org/apache/sling/osgi/commons/internal/AdapterFactoryDescriptorKey.java
deleted file mode 100644
index c9f5c64..0000000
--- a/src/main/java/org/apache/sling/osgi/commons/internal/AdapterFactoryDescriptorKey.java
+++ /dev/null
@@ -1,88 +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.sling.osgi.commons.internal;
-
-import org.apache.sling.osgi.commons.OsgiUtil;
-import org.osgi.framework.Constants;
-import org.osgi.framework.ServiceReference;
-
-/**
- * The <code>AdapterFactoryDescriptorKey</code> provides the indexing
- * functionality for the {@link AdapterFactoryDescriptorMap}. The key consists
- * of the OSGi <code>service.id</code> of the
- * {@link org.apache.sling.osgi.commons.AdapterFactory} service and the ID of
- * the the bundle providing the service.
- * <p>
- * Sort order among the keys is defined primarily by the bundle id and
- * secondarily by the service id.
- */
-public class AdapterFactoryDescriptorKey implements
-        Comparable<AdapterFactoryDescriptorKey> {
-
-    private long bundleId;
-
-    private long serviceId;
-
-    public AdapterFactoryDescriptorKey(ServiceReference ref) {
-        bundleId = ref.getBundle().getBundleId();
-        serviceId = OsgiUtil.toLong(ref.getProperty(Constants.SERVICE_ID), -1);
-    }
-
-    public int compareTo(AdapterFactoryDescriptorKey o) {
-        if (o.equals(this)) {
-            return 0;
-        }
-
-        // result for differing bundleId
-        if (bundleId < o.bundleId) {
-            return -1;
-        } else if (bundleId > o.bundleId) {
-            return 1;
-        }
-
-        // result for differing serviceId, we do not expect the two
-        // serviceId values to be equal because otherwise the equals
-        // test above would have yielded true
-        if (serviceId < o.serviceId) {
-            return -1;
-        }
-
-        // serviceId is larger than the other object's, we do not expect
-        // the two serviceId values to be equal because otherwise the equals
-        // test above would have yielded true
-        return 1;
-    }
-
-    @Override
-    public boolean equals(Object o) {
-        if (o == this) {
-            return true;
-        } else if (o instanceof AdapterFactoryDescriptorKey) {
-            AdapterFactoryDescriptorKey oKey = (AdapterFactoryDescriptorKey) o;
-            return bundleId == oKey.bundleId && serviceId == oKey.serviceId;
-        }
-
-        return false;
-    }
-
-    @Override
-    public int hashCode() {
-        return (int) (bundleId * 33 + serviceId);
-    }
-}
diff --git a/src/main/java/org/apache/sling/osgi/commons/internal/AdapterFactoryDescriptorMap.java b/src/main/java/org/apache/sling/osgi/commons/internal/AdapterFactoryDescriptorMap.java
deleted file mode 100644
index 747feee..0000000
--- a/src/main/java/org/apache/sling/osgi/commons/internal/AdapterFactoryDescriptorMap.java
+++ /dev/null
@@ -1,39 +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.sling.osgi.commons.internal;
-
-import java.util.TreeMap;
-
-/**
- * The <code>AdapterFactoryDescriptorMap</code> is a sorted map of
- * {@link AdapterFactoryDescriptor} instances indexed (and ordered) by their
- * {@link AdapterFactoryDescriptorKey}. This map is used to organize the
- * registered {@link org.apache.sling.osgi.commons.AdapterFactory} services for
- * a given adaptable type.
- * <p>
- * Each entry in the map is a {@link AdapterFactoryDescriptor} thus enabling the
- * registration of multiple factories for the same (adaptable, adapter) type
- * tuple. Of course only the first entry (this is the reason for having a sorted
- * map) for such a given tuple is actually being used. If that first instance is
- * removed the eventual second instance may actually be used instead.
- */
-public class AdapterFactoryDescriptorMap extends
-        TreeMap<AdapterFactoryDescriptorKey, AdapterFactoryDescriptor> {
-
-}
diff --git a/src/main/java/org/apache/sling/osgi/commons/internal/AdapterManagerImpl.java b/src/main/java/org/apache/sling/osgi/commons/internal/AdapterManagerImpl.java
deleted file mode 100644
index 8cd3a08..0000000
--- a/src/main/java/org/apache/sling/osgi/commons/internal/AdapterManagerImpl.java
+++ /dev/null
@@ -1,427 +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.sling.osgi.commons.internal;
-
-import static org.apache.sling.osgi.commons.AdapterFactory.ADAPTABLE_CLASSES;
-import static org.apache.sling.osgi.commons.AdapterFactory.ADAPTER_CLASSES;
-
-import java.util.HashMap;
-import java.util.LinkedList;
-import java.util.List;
-import java.util.Map;
-
-import org.apache.sling.osgi.commons.AdapterFactory;
-import org.apache.sling.osgi.commons.AdapterManager;
-import org.apache.sling.osgi.commons.OsgiUtil;
-import org.osgi.framework.ServiceReference;
-import org.osgi.service.component.ComponentContext;
-import org.osgi.service.log.LogService;
-
-/**
- * The <code>AdapterManagerImpl</code> class implements the
- * {@link AdapterManager} interface and is registered as a service for that
- * interface to be used by any clients.
- * 
- * @scr.component metatype="no"
- * @scr.property name="service.description" value="Sling Adapter Manager"
- * @scr.property name="service.vendor" value="The Apache Software Foundation"
- * @scr.service
- * @scr.reference name="AdapterFactory"
- *                interface="org.apache.sling.osgi.commons.AdapterFactory"
- *                cardinality="0..n" policy="dynamic"
- */
-public class AdapterManagerImpl implements AdapterManager {
-
-    /**
-     * The singleton instance of this manager. This field is set when the
-     * instance is {@link #activate(ComponentContext) activated} and cleared
-     * when the instance is {@link #deactivate(ComponentContext) deactivated}.
-     */
-    private static AdapterManager INSTANCE;
-
-    /**
-     * Returns the instance of this class or <code>null</code> if no activate
-     * yet.
-     */
-    public static AdapterManager getInstance() {
-        return INSTANCE;
-    }
-
-    /** @scr.reference cardinality="0..1" policy="dynamic" */
-    private LogService log;
-
-    /** Whether to debug this class or not */
-    private boolean debug = false;
-
-    /**
-     * The OSGi <code>ComponentContext</code> to retrieve
-     * {@link AdapterFactory} service instances.
-     */
-    private ComponentContext context;
-
-    /**
-     * A list of {@link AdapterFactory} services bound to this manager before
-     * the manager has been activated. These bound services will be accessed as
-     * soon as the manager is being activated.
-     */
-    private List<ServiceReference> boundAdapterFactories = new LinkedList<ServiceReference>();
-
-    /**
-     * A map of {@link AdapterFactoryDescriptorMap} instances. The map is
-     * indexed by the fully qualified class names listed in the
-     * {@link AdapterFactory#ADAPTABLE_CLASSES} property of the
-     * {@link AdapterFactory} services.
-     * 
-     * @see AdapterFactoryDescriptorMap
-     */
-    private Map<String, AdapterFactoryDescriptorMap> factories = new HashMap<String, AdapterFactoryDescriptorMap>();
-
-    /**
-     * Matrix of {@link AdapterFactory} instances primarily indexed by the fully
-     * qualified name of the class to be adapted and secondarily indexed by the
-     * fully qualified name of the class to adapt to (the target class).
-     * <p>
-     * This cache is built on demand by calling the
-     * {@link #getAdapterFactories(Class)} class. It is removed altogether
-     * whenever an adapter factory is registered on unregistered.
-     */
-    private Map<String, Map<String, AdapterFactory>> factoryCache;
-
-    // ---------- AdapterManager interface -------------------------------------
-
-    /**
-     * Returns the adapted <code>adaptable</code> or <code>null</code> if
-     * the object cannot be adapted.
-     */
-    public <AdapterType> AdapterType getAdapter(Object adaptable,
-            Class<AdapterType> type) {
-
-        // get the adapter factories for the type of adaptable object
-        Map<String, AdapterFactory> factories = getAdapterFactories(adaptable.getClass());
-
-        // get the factory for the target type
-        AdapterFactory factory = factories.get(type.getName());
-
-        // have the factory adapt the adaptable if the factory exists
-        if (factory != null) {
-            if (debug) {
-                log(LogService.LOG_DEBUG, "Using adapter factory " + factory
-                    + " to map " + adaptable + " to " + type, null);
-            }
-
-            return factory.getAdapter(adaptable, type);
-        }
-
-        // no factory has been found, so we cannot adapt
-        if (debug) {
-            log(LogService.LOG_DEBUG, "No adapter factory found to map "
-                + adaptable + " to " + type, null);
-        }
-
-        return null;
-    }
-
-    // ----------- SCR integration ---------------------------------------------
-
-    protected synchronized void activate(ComponentContext context) {
-        this.context = context;
-
-        // register all adapter factories bound before activation
-        for (ServiceReference reference : boundAdapterFactories) {
-            registerAdapterFactory(context, reference);
-        }
-        boundAdapterFactories.clear();
-
-        // final "enable" this manager by setting the instance
-        // do not overwrite the field if already set (this is unexpected
-        // actually)
-        if (AdapterManagerImpl.INSTANCE == null) {
-            AdapterManagerImpl.INSTANCE = this;
-        } else {
-            log(LogService.LOG_WARNING,
-                "Not setting Instance field: Set to another manager "
-                    + AdapterManagerImpl.INSTANCE, null);
-        }
-    }
-
-    /**
-     * @param context Not used
-     */
-    protected synchronized void deactivate(ComponentContext context) {
-        // "disable" the manager by clearing the instance
-        // do not clear the field if not set to this instance
-        if (AdapterManagerImpl.INSTANCE == this) {
-            AdapterManagerImpl.INSTANCE = null;
-        } else {
-            log(LogService.LOG_WARNING,
-                "Not clearing instance field: Set to another manager "
-                    + AdapterManagerImpl.INSTANCE, null);
-        }
-
-        this.context = null;
-    }
-
-    protected synchronized void bindAdapterFactory(ServiceReference reference) {
-        if (context == null) {
-            boundAdapterFactories.add(reference);
-        } else {
-            registerAdapterFactory(context, reference);
-        }
-    }
-
-    protected synchronized void unbindAdapterFactory(ServiceReference reference) {
-        unregisterAdapterFactory(reference);
-    }
-
-    // ---------- unit testing stuff only --------------------------------------
-
-    /**
-     * Returns the active adapter factories of this manager.
-     * <p>
-     * <strong><em>THIS METHOD IS FOR UNIT TESTING ONLY. IT MAY BE REMOVED OR
-     * MODIFIED WITHOUT NOTICE.</em></strong>
-     */
-    Map<String, AdapterFactoryDescriptorMap> getFactories() {
-        return factories;
-    }
-
-    /**
-     * Returns the current adapter factory cache.
-     * <p>
-     * <strong><em>THIS METHOD IS FOR UNIT TESTING ONLY. IT MAY BE REMOVED OR
-     * MODIFIED WITHOUT NOTICE.</em></strong>
-     */
-    Map<String, Map<String, AdapterFactory>> getFactoryCache() {
-        return factoryCache;
-    }
-
-    // ---------- internal -----------------------------------------------------
-
-    private void log(int level, String message, Throwable t) {
-        LogService logger = this.log;
-        if (logger != null) {
-            logger.log(level, message, t);
-        } else {
-            System.out.println(message);
-            if (t != null) {
-                t.printStackTrace(System.out);
-            }
-        }
-    }
-
-    /**
-     * Unregisters the {@link AdapterFactory} referred to by the service
-     * <code>reference</code> from the registry.
-     */
-    private void registerAdapterFactory(ComponentContext context,
-            ServiceReference reference) {
-        String[] adaptables = OsgiUtil.toStringArray(reference.getProperty(ADAPTABLE_CLASSES));
-        String[] adapters = OsgiUtil.toStringArray(reference.getProperty(ADAPTER_CLASSES));
-
-        if (adaptables == null || adaptables.length == 0 || adapters == null
-            || adapters.length == 0) {
-            return;
-        }
-
-        AdapterFactory factory = (AdapterFactory) context.locateService(
-            "AdapterFactory", reference);
-
-        AdapterFactoryDescriptorKey factoryKey = new AdapterFactoryDescriptorKey(
-            reference);
-        AdapterFactoryDescriptor factoryDesc = new AdapterFactoryDescriptor(
-            factory, adapters);
-
-        synchronized (factories) {
-            for (String adaptable : adaptables) {
-                AdapterFactoryDescriptorMap adfMap = factories.get(adaptable);
-                if (adfMap == null) {
-                    adfMap = new AdapterFactoryDescriptorMap();
-                    factories.put(adaptable, adfMap);
-                }
-                adfMap.put(factoryKey, factoryDesc);
-            }
-        }
-
-        // clear the factory cache to force rebuild on next access
-        factoryCache = null;
-    }
-
-    /**
-     * Unregisters the {@link AdapterFactory} referred to by the service
-     * <code>reference</code> from the registry.
-     */
-    private void unregisterAdapterFactory(ServiceReference reference) {
-        boundAdapterFactories.remove(reference);
-
-        String[] adaptables = OsgiUtil.toStringArray(reference.getProperty(ADAPTABLE_CLASSES));
-
-        if (adaptables == null || adaptables.length == 0) {
-            return;
-        }
-
-        AdapterFactoryDescriptorKey factoryKey = new AdapterFactoryDescriptorKey(
-            reference);
-
-        boolean factoriesModified = false;
-        synchronized (factories) {
-            for (String adaptable : adaptables) {
-                AdapterFactoryDescriptorMap adfMap = factories.get(adaptable);
-                if (adfMap != null) {
-                    factoriesModified |= (adfMap.remove(factoryKey) != null);
-                    if (adfMap.isEmpty()) {
-                        factories.remove(adaptable);
-                    }
-                }
-            }
-        }
-
-        // only remove cache if some adapter factories have actually been
-        // removed
-        if (factoriesModified) {
-            factoryCache = null;
-        }
-    }
-
-    /**
-     * Returns a map of {@link AdapterFactory} instances for the given class to
-     * be adapted. The returned map is indexed by the fully qualified name of
-     * the target classes (to adapt to) registered.
-     * 
-     * @param clazz The type of the object for which the registered adapter
-     *            factories are requested
-     * @return The map of adapter factories. If there is no adapter factory
-     *         registered for this type, the returned map is empty.
-     */
-    private Map<String, AdapterFactory> getAdapterFactories(Class<?> clazz) {
-        Map<String, Map<String, AdapterFactory>> cache = factoryCache;
-        if (cache == null) {
-            cache = new HashMap<String, Map<String, AdapterFactory>>();
-            factoryCache = cache;
-        }
-
-        synchronized (cache) {
-            return getAdapterFactories(clazz, cache);
-        }
-    }
-
-    /**
-     * Returns the map of adapter factories index by adapter (target) class name
-     * for the given adaptable <code>clazz</code>. If no adapter exists for
-     * the <code>clazz</code> and empty map is returned.
-     * 
-     * @param clazz The adaptable <code>Class</code> for which to return the
-     *            adapter factory map by target class name.
-     * @param cache The cache of already defined adapter factory mappings
-     * @return The map of adapter factories by target class name. The map may be
-     *         empty if there is no adapter factory for the adaptable
-     *         <code>clazz</code>.
-     */
-    private Map<String, AdapterFactory> getAdapterFactories(Class<?> clazz,
-            Map<String, Map<String, AdapterFactory>> cache) {
-
-        String className = clazz.getName();
-        Map<String, AdapterFactory> entry = cache.get(className);
-        if (entry == null) {
-            // create entry
-            entry = createAdapterFactoryMap(clazz, cache);
-            cache.put(className, entry);
-        }
-
-        return entry;
-    }
-
-    /**
-     * Creates a new target adapter factory map for the given <code>clazz</code>.
-     * First all factories defined to support the adaptable class by
-     * registration are taken. Next all factories for the implemented interfaces
-     * and finally all base class factories are copied. Later adapter factory
-     * entries do NOT overwrite earlier entries.
-     * 
-     * @param clazz The adaptable <code>Class</code> for which to build the
-     *            adapter factory map by target class name.
-     * @param cache The cache of already defined adapter factory mappings
-     * @return The map of adapter factories by target class name. The map may be
-     *         empty if there is no adapter factory for the adaptable
-     *         <code>clazz</code>.
-     */
-    private Map<String, AdapterFactory> createAdapterFactoryMap(Class<?> clazz,
-            Map<String, Map<String, AdapterFactory>> cache) {
-        Map<String, AdapterFactory> afm = new HashMap<String, AdapterFactory>();
-
-        // AdapterFactories for this class
-        AdapterFactoryDescriptorMap afdMap;
-        synchronized (factories) {
-            afdMap = factories.get(clazz.getName());
-        }
-        if (afdMap != null) {
-            for (AdapterFactoryDescriptor afd : afdMap.values()) {
-                String[] adapters = afd.getAdapters();
-                for (String adapter : adapters) {
-                    if (!afm.containsKey(adapter)) {
-                        afm.put(adapter, afd.getFactory());
-                    }
-                }
-            }
-        }
-
-        // AdapterFactories for the interfaces
-        Class<?>[] interfaces = clazz.getInterfaces();
-        for (Class<?> iFace : interfaces) {
-            copyAdapterFactories(afm, iFace, cache);
-        }
-
-        // AdapterFactories for the super class
-        Class<?> superClazz = clazz.getSuperclass();
-        if (superClazz != null) {
-            copyAdapterFactories(afm, superClazz, cache);
-        }
-
-        return afm;
-    }
-
-    /**
-     * Copies all adapter factories for the given <code>clazz</code> from the
-     * <code>cache</code> to the <code>dest</code> map except for those
-     * factories whose target class already exists in the <code>dest</code>
-     * map.
-     * 
-     * @param dest The map of target class name to adapter factory into which
-     *            additional factories are copied. Existing factories are not
-     *            replaced.
-     * @param clazz The adaptable class whose adapter factories are considered
-     *            for adding into <code>dest</code>.
-     * @param cache The adapter factory cache providing the adapter factories
-     *            for <code>clazz</code> to consider for copying into
-     *            <code>dest</code>.
-     */
-    private void copyAdapterFactories(Map<String, AdapterFactory> dest,
-            Class<?> clazz, Map<String, Map<String, AdapterFactory>> cache) {
-
-        // get the adapter factories for the adaptable clazz
-        Map<String, AdapterFactory> scMap = getAdapterFactories(clazz, cache);
-
-        // for each target class copy the entry to dest if dest does
-        // not contain the target class already
-        for (Map.Entry<String, AdapterFactory> entry : scMap.entrySet()) {
-            if (!dest.containsKey(entry.getKey())) {
-                dest.put(entry.getKey(), entry.getValue());
-            }
-        }
-    }
-}
diff --git a/src/test/java/org/apache/sling/osgi/commons/internal/AdapterManagerTest.java b/src/test/java/org/apache/sling/osgi/commons/internal/AdapterManagerTest.java
deleted file mode 100644
index 067ec16..0000000
--- a/src/test/java/org/apache/sling/osgi/commons/internal/AdapterManagerTest.java
+++ /dev/null
@@ -1,245 +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.sling.osgi.commons.internal;
-
-import java.util.Map;
-
-import junit.framework.TestCase;
-
-import org.apache.sling.osgi.commons.AdapterFactory;
-import org.apache.sling.osgi.commons.SlingAdaptable;
-import org.apache.sling.osgi.commons.mock.MockBundle;
-import org.apache.sling.osgi.commons.mock.MockComponentContext;
-import org.apache.sling.osgi.commons.mock.MockServiceReference;
-import org.osgi.framework.Bundle;
-import org.osgi.framework.Constants;
-import org.osgi.service.component.ComponentContext;
-
-public class AdapterManagerTest extends TestCase {
-
-    private AdapterManagerImpl am;
-    
-    @Override
-    protected void setUp() throws Exception {
-        super.setUp();
-        
-        am = new AdapterManagerImpl();
-    }
-    
-    @Override
-    protected void tearDown() throws Exception {
-        if (AdapterManagerImpl.getInstance() == am) {
-            am.deactivate(null); // not correct, but argument unused
-        }
-        
-        super.tearDown();
-    }
-    
-    public void testUnitialized() {
-        assertNotNull("AdapterFactoryDescriptors must not be null", am.getFactories());
-        assertTrue("AdapterFactoryDescriptors must be empty", am.getFactories().isEmpty());
-        assertNull("AdapterFactory cache must be null", am.getFactoryCache());
-    }
-
-    public void testInitialized() {
-        ComponentContext cc = new MockComponentContext();
-        am.activate(cc);
-
-        assertNotNull("AdapterFactoryDescriptors must not be null", am.getFactories());
-        assertTrue("AdapterFactoryDescriptors must be empty", am.getFactories().isEmpty());
-        assertNull("AdapterFactory cache must be null", am.getFactoryCache());
-    }
-
-    public void testBindBeforeActivate() {
-        Bundle bundle = new MockBundle(1L);
-        MockServiceReference ref = new MockServiceReference(bundle);
-        ref.setProperty(Constants.SERVICE_ID, 1L);
-        ref.setProperty(AdapterFactory.ADAPTABLE_CLASSES, new String[]{ TestSlingAdaptable.class.getName() });
-        ref.setProperty(AdapterFactory.ADAPTER_CLASSES, ITestAdapter.class.getName());
-        am.bindAdapterFactory(ref);
-
-        // no cache and no factories yet
-        assertNotNull("AdapterFactoryDescriptors must not be null", am.getFactories());
-        assertTrue("AdapterFactoryDescriptors must be empty", am.getFactories().isEmpty());
-        assertNull("AdapterFactory cache must be null", am.getFactoryCache());
-
-        // this should register the factory
-        ComponentContext cc = new MockComponentContext();
-        am.activate(cc);
-
-        // expect the factory, but cache is empty
-        assertNotNull("AdapterFactoryDescriptors must not be null", am.getFactories());
-        assertEquals("AdapterFactoryDescriptors must contain one entry", 1, am.getFactories().size());
-        assertNull("AdapterFactory cache must be null", am.getFactoryCache());
-    }
-
-    public void testBindAfterActivate() {
-        ComponentContext cc = new MockComponentContext();
-        am.activate(cc);
-
-        // no cache and no factories yet
-        assertNotNull("AdapterFactoryDescriptors must not be null", am.getFactories());
-        assertTrue("AdapterFactoryDescriptors must be empty", am.getFactories().isEmpty());
-        assertNull("AdapterFactory cache must be null", am.getFactoryCache());
-
-        Bundle bundle = new MockBundle(1L);
-        MockServiceReference ref = new MockServiceReference(bundle);
-        ref.setProperty(Constants.SERVICE_ID, 1L);
-        ref.setProperty(AdapterFactory.ADAPTABLE_CLASSES, new String[]{ TestSlingAdaptable.class.getName() });
-        ref.setProperty(AdapterFactory.ADAPTER_CLASSES, ITestAdapter.class.getName());
-        am.bindAdapterFactory(ref);
-
-        // expect the factory, but cache is empty
-        assertNotNull("AdapterFactoryDescriptors must not be null", am.getFactories());
-        assertEquals("AdapterFactoryDescriptors must contain one entry", 1, am.getFactories().size());
-        assertNull("AdapterFactory cache must be null", am.getFactoryCache());
-
-        Map<String, AdapterFactoryDescriptorMap> f = am.getFactories();
-        AdapterFactoryDescriptorMap afdm = f.get(TestSlingAdaptable.class.getName());
-        assertNotNull(afdm);
-
-        AdapterFactoryDescriptor afd = afdm.get(new AdapterFactoryDescriptorKey(ref));
-        assertNotNull(afd);
-        assertNotNull(afd.getFactory());
-        assertNotNull(afd.getAdapters());
-        assertEquals(1, afd.getAdapters().length);
-        assertEquals(ITestAdapter.class.getName(), afd.getAdapters()[0]);
-
-        assertNull(f.get(TestSlingAdaptable2.class.getName()));
-    }
-
-    public void testAdaptBase() {
-
-        ComponentContext cc = new MockComponentContext();
-        am.activate(cc);
-
-        TestSlingAdaptable data = new TestSlingAdaptable();
-        assertNull("Expect no adapter", am.getAdapter(data, ITestAdapter.class));
-
-        Bundle bundle = new MockBundle(1L);
-        MockServiceReference ref = new MockServiceReference(bundle);
-        ref.setProperty(Constants.SERVICE_ID, 1L);
-        ref.setProperty(AdapterFactory.ADAPTABLE_CLASSES, new String[]{ TestSlingAdaptable.class.getName() });
-        ref.setProperty(AdapterFactory.ADAPTER_CLASSES, ITestAdapter.class.getName());
-        am.bindAdapterFactory(ref);
-
-        Object adapter = am.getAdapter(data, ITestAdapter.class);
-        assertNotNull(adapter);
-        assertTrue(adapter instanceof ITestAdapter);
-    }
-
-    public void testAdaptExtended() {
-
-        ComponentContext cc = new MockComponentContext();
-        am.activate(cc);
-
-        TestSlingAdaptable2 data = new TestSlingAdaptable2();
-        assertNull("Expect no adapter", am.getAdapter(data, ITestAdapter.class));
-
-        Bundle bundle = new MockBundle(1L);
-        MockServiceReference ref = new MockServiceReference(bundle);
-        ref.setProperty(Constants.SERVICE_ID, 1L);
-        ref.setProperty(AdapterFactory.ADAPTABLE_CLASSES, new String[]{ TestSlingAdaptable.class.getName() });
-        ref.setProperty(AdapterFactory.ADAPTER_CLASSES, ITestAdapter.class.getName());
-        am.bindAdapterFactory(ref);
-
-        Object adapter = am.getAdapter(data, ITestAdapter.class);
-        assertNotNull(adapter);
-        assertTrue(adapter instanceof ITestAdapter);
-    }
-
-    public void testAdaptBase2() {
-
-        ComponentContext cc = new MockComponentContext();
-        am.activate(cc);
-
-        TestSlingAdaptable data = new TestSlingAdaptable();
-        assertNull("Expect no adapter", am.getAdapter(data, ITestAdapter.class));
-
-        Bundle bundle = new MockBundle(1L);
-        MockServiceReference ref = new MockServiceReference(bundle);
-        ref.setProperty(Constants.SERVICE_ID, 1L);
-        ref.setProperty(AdapterFactory.ADAPTABLE_CLASSES, new String[]{ TestSlingAdaptable.class.getName() });
-        ref.setProperty(AdapterFactory.ADAPTER_CLASSES, ITestAdapter.class.getName());
-        am.bindAdapterFactory(ref);
-
-        ref = new MockServiceReference(bundle);
-        ref.setProperty(Constants.SERVICE_ID, 2L);
-        ref.setProperty(AdapterFactory.ADAPTABLE_CLASSES, new String[]{ TestSlingAdaptable2.class.getName() });
-        ref.setProperty(AdapterFactory.ADAPTER_CLASSES, TestAdapter.class.getName());
-        am.bindAdapterFactory(ref);
-
-        Object adapter = am.getAdapter(data, ITestAdapter.class);
-        assertNotNull(adapter);
-        assertTrue(adapter instanceof ITestAdapter);
-    }
-
-    public void testAdaptExtended2() {
-
-        ComponentContext cc = new MockComponentContext();
-        am.activate(cc);
-
-        Bundle bundle = new MockBundle(1L);
-        MockServiceReference ref = new MockServiceReference(bundle);
-        ref.setProperty(Constants.SERVICE_ID, 1L);
-        ref.setProperty(AdapterFactory.ADAPTABLE_CLASSES, new String[]{ TestSlingAdaptable.class.getName() });
-        ref.setProperty(AdapterFactory.ADAPTER_CLASSES, ITestAdapter.class.getName());
-        am.bindAdapterFactory(ref);
-
-        ref = new MockServiceReference(bundle);
-        ref.setProperty(Constants.SERVICE_ID, 2L);
-        ref.setProperty(AdapterFactory.ADAPTABLE_CLASSES, new String[]{ TestSlingAdaptable2.class.getName() });
-        ref.setProperty(AdapterFactory.ADAPTER_CLASSES, TestAdapter.class.getName());
-        am.bindAdapterFactory(ref);
-
-        TestSlingAdaptable data = new TestSlingAdaptable();
-        Object adapter = am.getAdapter(data, ITestAdapter.class);
-        assertNotNull(adapter);
-        assertTrue(adapter instanceof ITestAdapter);
-        adapter = am.getAdapter(data, TestAdapter.class);
-        assertNull(adapter);
-
-        TestSlingAdaptable2 data2 = new TestSlingAdaptable2();
-        adapter = am.getAdapter(data2, ITestAdapter.class);
-        assertNotNull(adapter);
-        assertTrue(adapter instanceof ITestAdapter);
-        adapter = am.getAdapter(data2, TestAdapter.class);
-        assertNotNull(adapter);
-        assertTrue(adapter instanceof TestAdapter);
-    }
-
-    //---------- Test Adaptable and Adapter Classes ---------------------------
-
-    public static class TestSlingAdaptable extends SlingAdaptable {
-
-    }
-
-    public static class TestSlingAdaptable2 extends TestSlingAdaptable {
-
-    }
-
-    public static interface ITestAdapter {
-
-    }
-
-    public static class TestAdapter {
-
-    }
-
-}
diff --git a/src/test/java/org/apache/sling/osgi/commons/mock/MockAdapterFactory.java b/src/test/java/org/apache/sling/osgi/commons/mock/MockAdapterFactory.java
deleted file mode 100644
index e833c96..0000000
--- a/src/test/java/org/apache/sling/osgi/commons/mock/MockAdapterFactory.java
+++ /dev/null
@@ -1,53 +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.sling.osgi.commons.mock;
-
-import java.lang.reflect.InvocationHandler;
-import java.lang.reflect.Method;
-import java.lang.reflect.Proxy;
-
-import org.apache.sling.osgi.commons.AdapterFactory;
-
-public class MockAdapterFactory implements AdapterFactory {
-
-    private static final InvocationHandler NOP_INVOCATION_HANDLER = new InvocationHandler() {
-        public Object invoke(Object proxy, Method method, Object[] args)
-                throws Throwable {
-            return null;
-        }
-    };
-
-    @SuppressWarnings("unchecked")
-    public <AdapterType> AdapterType getAdapter(Object adaptable,
-            Class<AdapterType> type) {
-
-        try {
-            if (type.isInterface()) {
-                return (AdapterType) Proxy.newProxyInstance(type.getClassLoader(),
-                    new Class[] { type }, NOP_INVOCATION_HANDLER);
-            }
-
-            return type.newInstance();
-        } catch (Exception e) {
-            // ignore
-        }
-
-        return null;
-    }
-}
diff --git a/src/test/java/org/apache/sling/osgi/commons/mock/MockBundle.java b/src/test/java/org/apache/sling/osgi/commons/mock/MockBundle.java
deleted file mode 100644
index f6a3523..0000000
--- a/src/test/java/org/apache/sling/osgi/commons/mock/MockBundle.java
+++ /dev/null
@@ -1,122 +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.sling.osgi.commons.mock;
-
-import java.io.InputStream;
-import java.net.URL;
-import java.util.Dictionary;
-import java.util.Enumeration;
-
-import org.osgi.framework.Bundle;
-import org.osgi.framework.ServiceReference;
-
-public class MockBundle implements Bundle {
-
-    private long bundleId;
-
-    public MockBundle(long bundleId) {
-        this.bundleId = bundleId;
-    }
-
-    public long getBundleId() {
-        return bundleId;
-    }
-
-    public Enumeration<?> findEntries(String path, String filePattern,
-            boolean recurse) {
-        return null;
-    }
-
-    public URL getEntry(String name) {
-        return null;
-    }
-
-    public Enumeration<?> getEntryPaths(String path) {
-        return null;
-    }
-
-    public Dictionary<?, ?> getHeaders() {
-        return null;
-    }
-
-    public Dictionary<?, ?> getHeaders(String locale) {
-        return null;
-    }
-
-    public long getLastModified() {
-        return 0;
-    }
-
-    public String getLocation() {
-        return null;
-    }
-
-    public ServiceReference[] getRegisteredServices() {
-        return null;
-    }
-
-    public URL getResource(String name) {
-        return null;
-    }
-
-    public Enumeration<?> getResources(String name) {
-        return null;
-    }
-
-    public ServiceReference[] getServicesInUse() {
-        return null;
-    }
-
-    public int getState() {
-        return 0;
-    }
-
-    public String getSymbolicName() {
-        return null;
-    }
-
-    public boolean hasPermission(Object permission) {
-        return false;
-    }
-
-    public Class<?> loadClass(String name) throws ClassNotFoundException {
-        throw new ClassNotFoundException(name);
-    }
-
-    public void start() {
-
-    }
-
-    public void stop() {
-
-    }
-
-    public void uninstall() {
-
-    }
-
-    public void update() {
-
-    }
-
-    public void update(InputStream in) {
-
-    }
-
-}
diff --git a/src/test/java/org/apache/sling/osgi/commons/mock/MockComponentContext.java b/src/test/java/org/apache/sling/osgi/commons/mock/MockComponentContext.java
deleted file mode 100644
index 159fe44..0000000
--- a/src/test/java/org/apache/sling/osgi/commons/mock/MockComponentContext.java
+++ /dev/null
@@ -1,79 +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.sling.osgi.commons.mock;
-
-import java.util.Dictionary;
-import java.util.HashMap;
-import java.util.Map;
-
-import org.apache.sling.osgi.commons.AdapterFactory;
-import org.osgi.framework.Bundle;
-import org.osgi.framework.BundleContext;
-import org.osgi.framework.ServiceReference;
-import org.osgi.service.component.ComponentContext;
-import org.osgi.service.component.ComponentInstance;
-
-public class MockComponentContext implements ComponentContext {
-
-    private Map<ServiceReference, AdapterFactory> services = new HashMap<ServiceReference, AdapterFactory>();
-
-    public Object locateService(String name, ServiceReference reference) {
-        AdapterFactory af = services.get(reference);
-        if (af == null) {
-            af = new MockAdapterFactory();
-            services.put(reference, af);
-        }
-        return af;
-    }
-
-    public void disableComponent(String name) {
-    }
-
-    public void enableComponent(String name) {
-    }
-
-    public BundleContext getBundleContext() {
-        return null;
-    }
-
-    public ComponentInstance getComponentInstance() {
-        return null;
-    }
-
-    public Dictionary<?, ?> getProperties() {
-        return null;
-    }
-
-    public ServiceReference getServiceReference() {
-        return null;
-    }
-
-    public Bundle getUsingBundle() {
-        return null;
-    }
-
-    public Object locateService(String name) {
-        return null;
-    }
-
-    public Object[] locateServices(String name) {
-        return null;
-    }
-
-}
diff --git a/src/test/java/org/apache/sling/osgi/commons/mock/MockServiceReference.java b/src/test/java/org/apache/sling/osgi/commons/mock/MockServiceReference.java
deleted file mode 100644
index e503d96..0000000
--- a/src/test/java/org/apache/sling/osgi/commons/mock/MockServiceReference.java
+++ /dev/null
@@ -1,62 +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.sling.osgi.commons.mock;
-
-import java.util.Collections;
-import java.util.Dictionary;
-import java.util.Hashtable;
-
-import org.osgi.framework.Bundle;
-import org.osgi.framework.ServiceReference;
-
-public class MockServiceReference implements ServiceReference {
-
-    private Bundle bundle;
-    private Dictionary<String, Object> props;
-
-    public MockServiceReference(Bundle bundle) {
-        this.bundle = bundle;
-        this.props = new Hashtable<String, Object>();
-    }
-
-    public Bundle getBundle() {
-        return bundle;
-    }
-
-    public void setProperty(String key, Object value) {
-        props.put(key, value);
-    }
-
-    public Object getProperty(String key) {
-        return props.get(key);
-    }
-
-    public String[] getPropertyKeys() {
-        return Collections.list(props.keys()).toArray(new String[props.size()]);
-    }
-
-    public Bundle[] getUsingBundles() {
-        return null;
-    }
-
-    public boolean isAssignableTo(Bundle bundle, String className) {
-        return false;
-    }
-
-}

-- 
To stop receiving notification emails like this one, please contact
"commits@sling.apache.org" <co...@sling.apache.org>.