You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@felix.apache.org by fm...@apache.org on 2007/04/11 20:12:35 UTC

svn commit: r527592 [2/2] - in /incubator/felix/trunk/configadmin: ./ src/ src/main/ src/main/java/ src/main/java/org/ src/main/java/org/apache/ src/main/java/org/apache/felix/ src/main/java/org/apache/felix/cm/ src/main/java/org/apache/felix/cm/file/ ...

Added: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/ConfigurationManager.java
URL: http://svn.apache.org/viewvc/incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/ConfigurationManager.java?view=auto&rev=527592
==============================================================================
--- incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/ConfigurationManager.java (added)
+++ incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/ConfigurationManager.java Wed Apr 11 11:12:33 2007
@@ -0,0 +1,1261 @@
+/* 
+ * 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.felix.cm.impl;
+
+
+import java.awt.image.ImagingOpException;
+import java.io.IOException;
+import java.security.SecureRandom;
+import java.util.ArrayList;
+import java.util.Comparator;
+import java.util.Dictionary;
+import java.util.Enumeration;
+import java.util.HashMap;
+import java.util.Hashtable;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
+import java.util.SortedSet;
+import java.util.TreeSet;
+
+import org.apache.felix.cm.PersistenceManager;
+import org.apache.felix.cm.file.FilePersistenceManager;
+import org.osgi.framework.BundleActivator;
+import org.osgi.framework.BundleContext;
+import org.osgi.framework.BundleEvent;
+import org.osgi.framework.BundleListener;
+import org.osgi.framework.Constants;
+import org.osgi.framework.Filter;
+import org.osgi.framework.InvalidSyntaxException;
+import org.osgi.framework.ServiceReference;
+import org.osgi.service.cm.ConfigurationAdmin;
+import org.osgi.service.cm.ConfigurationEvent;
+import org.osgi.service.cm.ConfigurationException;
+import org.osgi.service.cm.ConfigurationListener;
+import org.osgi.service.cm.ConfigurationPlugin;
+import org.osgi.service.cm.ManagedService;
+import org.osgi.service.cm.ManagedServiceFactory;
+import org.osgi.service.log.LogService;
+import org.osgi.util.tracker.ServiceTracker;
+
+
+/**
+ * The <code>ConfigurationManager</code> is the central class in this
+ * implementation of the Configuration Admin Service Specification. As such it
+ * has the following tasks:
+ * <ul>
+ * <li>It is a <code>BundleActivator</code> which is called when the bundle
+ * is started and stopped.
+ * <li>It is a <code>BundleListener</code> which gets informed when the
+ * states of bundles change. Mostly this is needed to unbind any bound
+ * configuration in case a bundle is uninstalled.
+ * <li>It is a <code>ServiceListener</code> which gets informed when
+ * <code>ManagedService</code> and <code>ManagedServiceFactory</code>
+ * services are registered and unregistered. This is used to provide
+ * configuration to these services. As a service listener it also listens for
+ * {@link PersistenceManager} instances being registered to support different
+ * configuration persistence layers.
+ * <li>A {@link ConfigurationAdminFactory} instance is registered as the
+ * <code>ConfigurationAdmin</code> service.
+ * <li>A {@link FilePersistenceManager} instance is registered as a default
+ * {@link PersistenceManager}.
+ * <li>Last but not least this instance manages all tasks laid out in the
+ * specification such as maintaining configuration, taking care of configuration
+ * events, etc.
+ * </ul>
+ * <p>
+ * The default {@link FilePersistenceManager} is configured with a configuration
+ * location taken from the <code>felix.cm.dir</code> framework property. If
+ * this property is not set the <code>config</code> directory in the current
+ * working directory as specified in the <code>user.dir</code> system property
+ * is used.
+ * 
+ * @author fmeschbe
+ */
+public class ConfigurationManager implements BundleActivator, BundleListener
+{
+
+    /**
+     * The name of the bundle context property defining the location for the
+     * configuration files (value is "felix.cm.dir").
+     * 
+     * @see #FilePersistenceManager(BundleContext)
+     */
+    public static final String CM_CONFIG_DIR = "felix.cm.dir";
+
+    // random number generator to create configuration PIDs for factory
+    // configurations
+    private static SecureRandom numberGenerator;
+
+    // comparator used to keep the ordered persistence manager map
+    private static final Comparator cmRankComp = new RankingComparator( true, ConfigurationPlugin.CM_RANKING );
+
+    // the BundleContext of the Configuration Admin Service bundle
+    private BundleContext bundleContext;
+
+    // the service reference to the ConfigurationAdmin service
+    private ServiceReference configurationAdminReference;
+
+    // the ServiceTracker to emit log services (see log(int, String, Throwable))
+    private ServiceTracker logTracker;
+
+    // the ConfigurationEvent listeners
+    private ServiceTracker configurationListenerTracker;
+
+    // service tracker for managed services
+    private ServiceTracker managedServiceTracker;
+
+    // service tracker for managed service factories
+    private ServiceTracker managedServiceFactoryTracker;
+
+    // PersistenceManager services
+    private ServiceTracker persistenceManagerTracker;
+
+    // the thread used to schedule tasks required to run asynchronously
+    private UpdateThread updateThread;
+
+    /**
+     * The actual list of {@link PersistenceManager persistence managers} to use
+     * when looking for configuration data. This list is built from the
+     * {@link #persistenceManagerMap}, which is ordered according to the
+     * {@link RankingComparator}.
+     */
+    private PersistenceManager[] persistenceManagers;
+
+    // the persistenceManagerTracker.getTrackingCount when the
+    // persistenceManagers were last got
+    private int pmtCount;
+
+    // the cache of Factory instances mapped by their factory PID
+    private Map factories;
+
+    // the cache of Configuration instances mapped by their PID
+    private Map configurations;
+
+
+    public void start( BundleContext bundleContext )
+    {
+        // track the log service using a ServiceTracker
+        logTracker = new ServiceTracker( bundleContext, LogService.class.getName(), null );
+        logTracker.open();
+
+        // set up some fields
+        this.bundleContext = bundleContext;
+        this.factories = new HashMap();
+        this.configurations = new HashMap();
+
+        // configurationlistener support
+        configurationListenerTracker = new ServiceTracker( bundleContext, ConfigurationListener.class.getName(), null );
+        configurationListenerTracker.open();
+
+        // initialize the asynchonous updater thread
+        this.updateThread = new UpdateThread( this );
+        this.updateThread.start();
+
+        // set up the location (might throw IllegalArgumentException)
+        try
+        {
+            FilePersistenceManager fpm = new FilePersistenceManager( bundleContext.getProperty( CM_CONFIG_DIR ) );
+            Hashtable props = new Hashtable();
+            props.put( Constants.SERVICE_PID, fpm.getClass().getName() );
+            props.put( Constants.SERVICE_DESCRIPTION, "Platform Filesystem Persistence Manager" );
+            props.put( Constants.SERVICE_VENDOR, "Apache Software Foundation" );
+            props.put( Constants.SERVICE_RANKING, new Integer( Integer.MIN_VALUE ) );
+            bundleContext.registerService( PersistenceManager.class.getName(), fpm, props );
+        }
+        catch ( IllegalArgumentException iae )
+        {
+            log( LogService.LOG_ERROR, "Cannot create the FilePersistenceManager", iae );
+        }
+
+        // register as bundle and service listener
+        bundleContext.addBundleListener( this );
+
+        // get all persistence managers to begin with
+        pmtCount = 1; // make sure to get the persistence managers at least
+        // once
+        persistenceManagerTracker = new ServiceTracker( bundleContext, PersistenceManager.class.getName(), null );
+        persistenceManagerTracker.open();
+
+        // create and register configuration admin - start after PM tracker ...
+        ConfigurationAdminFactory caf = new ConfigurationAdminFactory( this );
+        Hashtable props = new Hashtable();
+        props.put( Constants.SERVICE_PID, "org.apache.felix.cm.ConfigurationAdmin" );
+        props.put( Constants.SERVICE_DESCRIPTION, "Configuration Admin Service Specification 1.2 Implementation" );
+        props.put( Constants.SERVICE_VENDOR, "Apache Software Foundation" );
+        bundleContext.registerService( ConfigurationAdmin.class.getName(), caf, props );
+
+        // start handling ManagedService[Factory] services
+        managedServiceTracker = new ManagedServiceTracker();
+        managedServiceFactoryTracker = new ManagedServiceFactoryTracker();
+    }
+
+
+    public void stop( BundleContext bundleContext )
+    {
+        // stop handling ManagedService[Factory] services
+        managedServiceFactoryTracker.close();
+        managedServiceTracker.close();
+
+        // don't care for PersistenceManagers any more
+        persistenceManagerTracker.close();
+
+        // stop listening for events
+        bundleContext.removeBundleListener( this );
+
+        if ( configurationListenerTracker != null )
+        {
+            configurationListenerTracker.close();
+        }
+
+        if ( updateThread != null )
+        {
+            // terminate asynchrounous updates
+            updateThread.terminate();
+
+            // wait for all updates to terminate
+            try
+            {
+                updateThread.join();
+            }
+            catch ( InterruptedException ie )
+            {
+                // don't really care
+            }
+        }
+
+        if ( logTracker != null )
+        {
+            logTracker.close();
+        }
+
+        this.bundleContext = null;
+        this.configurations = null;
+    }
+
+
+    // ---------- Configuration caching support --------------------------------
+
+    ConfigurationImpl getCachedConfiguration( String pid )
+    {
+        synchronized ( configurations )
+        {
+            return ( ConfigurationImpl ) configurations.get( pid );
+        }
+    }
+
+
+    Iterator getCachedConfigurations()
+    {
+        synchronized ( configurations )
+        {
+            return configurations.values().iterator();
+        }
+    }
+
+
+    void cacheConfiguration( ConfigurationImpl configuration )
+    {
+        synchronized ( configurations )
+        {
+            configurations.put( configuration.getPid(), configuration );
+        }
+    }
+
+
+    void removeConfiguration( ConfigurationImpl configuration )
+    {
+        synchronized ( configurations )
+        {
+            configurations.remove( configuration.getPid() );
+        }
+    }
+
+
+    // ---------- ConfigurationAdminImpl support -------------------------------
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see org.osgi.service.cm.ConfigurationAdmin#createFactoryConfiguration(java.lang.String)
+     */
+    ConfigurationImpl createFactoryConfiguration( ConfigurationAdminImpl configurationAdmin, String factoryPid )
+        throws IOException
+    {
+        Factory factory = getFactory( factoryPid );
+
+        // check Persmission if factory is bound to another bundle
+        if ( factory.getBundleLocation() != null
+            && !factory.getBundleLocation().equals( configurationAdmin.getBundle().getLocation() ) )
+        {
+            configurationAdmin.checkPermission();
+        }
+
+        // create the configuration
+        String pid = createPid( factoryPid );
+        ConfigurationImpl config = createConfiguration( pid, factoryPid );
+        config.setBundleLocation( configurationAdmin.getBundle().getLocation() );
+
+        // add the configuration to the factory
+        factory.addPID( pid );
+        factory.store();
+
+        return config;
+    }
+
+
+    /*
+     * (non-Javadoc)
+     * 
+     * @see org.osgi.service.cm.ConfigurationAdmin#createFactoryConfiguration(java.lang.String,
+     *      java.lang.String)
+     */
+    ConfigurationImpl createFactoryConfiguration( String factoryPid, String location ) throws IOException
+    {
+        // create the configuration
+        String pid = createPid( factoryPid );
+        ConfigurationImpl config = createConfiguration( pid, factoryPid );
+        if ( location != null )
+        {
+            config.setBundleLocation( location );
+        }
+
+        // add the configuration to the factory
+        Factory factory = getFactory( factoryPid );
+        factory.addPID( pid );
+        factory.store();
+
+        return config;
+    }
+
+
+    ConfigurationImpl getConfiguration( String pid ) throws IOException
+    {
+        return getConfiguration( pid, true );
+    }
+
+
+    ConfigurationImpl getConfiguration( String pid, String bundleLocation ) throws IOException
+    {
+        ConfigurationImpl config = getConfiguration( pid, false );
+
+        if ( config == null )
+        {
+            config = createConfiguration( pid, null );
+            if ( bundleLocation != null )
+            {
+                config.setBundleLocation( bundleLocation );
+            }
+        }
+
+        return config;
+    }
+
+
+    ConfigurationImpl[] listConfigurations( ConfigurationAdminImpl configurationAdmin, String filterString )
+        throws IOException, InvalidSyntaxException
+    {
+        Filter filter = null;
+        if ( filterString != null )
+        {
+            filter = bundleContext.createFilter( filterString );
+        }
+
+        boolean unprivileged = configurationAdmin != null && !configurationAdmin.hasPermission();
+        String location = unprivileged ? configurationAdmin.getBundle().getLocation() : null;
+
+        List configList = new ArrayList();
+
+        PersistenceManager[] pmList = getPersistenceManagers();
+        for ( int i = 0; i < pmList.length; i++ )
+        {
+            Enumeration configs = pmList[i].getDictionaries();
+            while ( configs.hasMoreElements() )
+            {
+                Dictionary config = ( Dictionary ) configs.nextElement();
+
+                // ignore non-Configuration dictionaries
+                if ( config.get( Constants.SERVICE_PID ) == null )
+                {
+                    continue;
+                }
+
+                // ignore this config if not privileged and not bound to bundle
+                if ( unprivileged )
+                {
+                    Object boundLocation = config.get( ConfigurationAdmin.SERVICE_BUNDLELOCATION );
+                    if ( !location.equals( boundLocation ) )
+                    {
+                        continue;
+                    }
+                }
+
+                // check filter
+                if ( filter == null || filter.match( config ) )
+                {
+                    configList.add( new ConfigurationImpl( this, pmList[i], config ) );
+                }
+            }
+        }
+
+        return ( org.apache.felix.cm.impl.ConfigurationImpl[] ) configList.toArray( new ConfigurationImpl[configList
+            .size()] );
+    }
+
+
+    void deleted( ConfigurationImpl config )
+    {
+        // remove the configuration from the cache
+        removeConfiguration( config );
+        updateThread.schedule( new DeleteConfiguration( config ) );
+    }
+
+
+    void updated( ConfigurationImpl config )
+    {
+        updateThread.schedule( new UpdateConfiguration( config ) );
+    }
+
+
+    void fireConfigurationEvent( int type, ConfigurationImpl config )
+    {
+
+        updateThread.schedule( new FireConfigurationEvent( type, config ) );
+    }
+
+
+    // ---------- BundleListener -----------------------------------------------
+
+    public void bundleChanged( BundleEvent event )
+    {
+        if ( event.getType() == BundleEvent.UNINSTALLED )
+        {
+            String location = event.getBundle().getLocation();
+            String filter = "(service.bundleLocation=" + location + ")";
+
+            try
+            {
+                ConfigurationImpl[] configs = listConfigurations( null, filter );
+                if ( configs != null && configs.length > 0 )
+                {
+                    for ( int i = 0; i < configs.length; i++ )
+                    {
+                        configs[i].setBundleLocation( null );
+                        try
+                        {
+                            configs[i].store();
+                        }
+                        catch ( IOException ioe )
+                        {
+                            log( LogService.LOG_WARNING,
+                                "Problem storing unbound configuration " + configs[i].getPid(), ioe );
+                        }
+                    }
+                }
+            }
+            catch ( Exception e )
+            {
+                log( LogService.LOG_WARNING, "Problem unbinding configurations for bundle " + location, e );
+            }
+
+            // unbind cached configurations
+            Iterator configurations = getCachedConfigurations();
+            while ( configurations.hasNext() )
+            {
+                ConfigurationImpl cfg = ( ConfigurationImpl ) configurations.next();
+                if ( location.equals( cfg.getBundleLocation() ) )
+                {
+                    cfg.setBundleLocation( null );
+                }
+            }
+
+            // TODO: find factories to unbind !!
+        }
+    }
+
+
+    // ---------- internal -----------------------------------------------------
+
+    private PersistenceManager[] getPersistenceManagers()
+    {
+        if ( persistenceManagers == null || persistenceManagerTracker.getTrackingCount() > pmtCount )
+        {
+
+            ServiceReference[] refs = persistenceManagerTracker.getServiceReferences();
+            if ( refs == null || refs.length == 0 )
+            {
+                return new PersistenceManager[0];
+            }
+
+            SortedSet pms = new TreeSet( cmRankComp );
+            for ( int i = 0; i < refs.length; i++ )
+            {
+                pms.add( persistenceManagerTracker.getService( refs[i] ) );
+            }
+
+            persistenceManagers = ( PersistenceManager[] ) pms.toArray( new PersistenceManager[pms.size()] );
+        }
+
+        return persistenceManagers;
+    }
+
+
+    private void configure( ServiceReference sr, ManagedService service )
+    {
+        String pid = ( String ) sr.getProperty( Constants.SERVICE_PID );
+        if ( pid != null )
+        {
+            ManagedServiceUpdate update = new ManagedServiceUpdate( pid, sr, service );
+            updateThread.schedule( update );
+        }
+
+    }
+
+
+    private void configure( ServiceReference sr, ManagedServiceFactory service )
+    {
+        String pid = ( String ) sr.getProperty( Constants.SERVICE_PID );
+        if ( pid != null )
+        {
+            ManagedServiceFactoryUpdate update = new ManagedServiceFactoryUpdate( pid, sr, service );
+            updateThread.schedule( update );
+        }
+
+    }
+
+
+    ConfigurationImpl getConfiguration( String pid, boolean create ) throws IOException
+    {
+        ConfigurationImpl config = getCachedConfiguration( pid );
+        if ( config != null )
+        {
+            return config;
+        }
+
+        PersistenceManager[] pmList = getPersistenceManagers();
+        for ( int i = 0; i < pmList.length; i++ )
+        {
+            if ( pmList[i].exists( pid ) )
+            {
+                Dictionary props = pmList[i].load( pid );
+                config = new ConfigurationImpl( this, pmList[i], props );
+                cacheConfiguration( config );
+                return config;
+            }
+        }
+
+        // if getting here, there is no configuration yet, optionally create new
+        return ( create ) ? createConfiguration( pid, null ) : null;
+    }
+
+
+    ConfigurationImpl createConfiguration( String pid, String factoryPid ) throws IOException
+    {
+        ConfigurationImpl config = new ConfigurationImpl( this, getPersistenceManagers()[0], pid, factoryPid );
+
+        // immediately store the configuration, yet getProperties() must still
+        // return null
+        config.store();
+
+        cacheConfiguration( config );
+
+        return config;
+    }
+
+
+    Factory getFactory( String factoryPid ) throws IOException
+    {
+        Factory factory = ( Factory ) factories.get( factoryPid );
+        if ( factory != null )
+        {
+            return factory;
+        }
+
+        PersistenceManager[] pmList = getPersistenceManagers();
+        for ( int i = 0; i < pmList.length; i++ )
+        {
+            if ( Factory.exists( pmList[i], factoryPid ) )
+            {
+                factory = Factory.load( pmList[i], factoryPid );
+                factories.put( factoryPid, factory );
+                return factory;
+            }
+        }
+
+        // if getting here, there is no configuration yet, optionally create new
+        return createFactory( factoryPid );
+    }
+
+
+    Factory createFactory( String factoryPid )
+    {
+        Factory factory = new Factory( getPersistenceManagers()[0], factoryPid );
+        factories.put( factoryPid, factory );
+        return factory;
+    }
+
+
+    private Dictionary callPlugins( ServiceReference sr, ConfigurationImpl cfg )
+    {
+        Dictionary props = cfg.getProperties();
+
+        ServiceReference[] plugins = null;
+        try
+        {
+            String pid = ( String ) sr.getProperty( Constants.SERVICE_PID );
+            String filter = "(|(!(cm.target=*))(cm.target=" + pid + "))";
+            plugins = bundleContext.getServiceReferences( ConfigurationPlugin.class.getName(), filter );
+
+        }
+        catch ( InvalidSyntaxException ise )
+        {
+            // no filter, no exception ...
+        }
+
+        // abort early if there are no plugins
+        if ( plugins == null || plugins.length == 0 )
+        {
+            return props;
+        }
+
+        // sort the plugins by their service.cmRanking
+        SortedSet pluginSet = new TreeSet( cmRankComp );
+        for ( int i = 0; plugins != null && i < plugins.length; i++ )
+        {
+            pluginSet.add( plugins[i] );
+        }
+
+        // call the plugins in order
+        for ( Iterator pi = pluginSet.iterator(); pi.hasNext(); )
+        {
+            ServiceReference pluginRef = ( ServiceReference ) pi.next();
+            ConfigurationPlugin plugin = ( ConfigurationPlugin ) bundleContext.getService( pluginRef );
+            try
+            {
+                plugin.modifyConfiguration( sr, props );
+            }
+            catch ( Throwable t )
+            {
+                log( LogService.LOG_ERROR, "Unexpected problem calling" + " configuration plugin", t );
+            }
+            finally
+            {
+                // ensure ungetting the plugin
+                bundleContext.ungetService( pluginRef );
+            }
+            cfg.setAutoProperties( props, false );
+        }
+
+        return props;
+    }
+
+
+    /**
+     * Creates a PID for the given factoryPid
+     * 
+     * @param factoryPid
+     * @return
+     */
+    private static String createPid( String factoryPid )
+    {
+        SecureRandom ng = numberGenerator;
+        if ( ng == null )
+        {
+            numberGenerator = ng = new SecureRandom();
+        }
+
+        byte[] randomBytes = new byte[16];
+        ng.nextBytes( randomBytes );
+        randomBytes[6] &= 0x0f; /* clear version */
+        randomBytes[6] |= 0x40; /* set to version 4 */
+        randomBytes[8] &= 0x3f; /* clear variant */
+        randomBytes[8] |= 0x80; /* set to IETF variant */
+
+        StringBuffer buf = new StringBuffer( factoryPid.length() + 1 + 36 );
+
+        // prefix the new pid with the factory pid
+        buf.append( factoryPid ).append( "." );
+
+        // serialize the UUID into the buffer
+        for ( int i = 0; i < randomBytes.length; i++ )
+        {
+
+            if ( i == 4 || i == 6 || i == 8 || i == 10 )
+            {
+                buf.append( '-' );
+            }
+
+            int val = randomBytes[i] & 0xff;
+            buf.append( Integer.toHexString( val >> 4 ) );
+            buf.append( Integer.toHexString( val & 0xf ) );
+        }
+
+        return buf.toString();
+    }
+
+
+    void log( int level, String message, Throwable t )
+    {
+        LogService log = ( LogService ) logTracker.getService();
+        if ( log != null )
+        {
+            log.log( configurationAdminReference, level, message, t );
+            return;
+        }
+
+        String code;
+        switch ( level )
+        {
+            case LogService.LOG_INFO:
+                code = "*INFO *";
+                break;
+
+            case LogService.LOG_WARNING:
+                code = "*WARN *";
+                break;
+
+            case LogService.LOG_ERROR:
+                code = "*ERROR*";
+                break;
+
+            case LogService.LOG_DEBUG:
+            default:
+                code = "*DEBUG*";
+        }
+
+        System.err.println( code + " " + message );
+        if ( t != null )
+        {
+            t.printStackTrace( System.err );
+        }
+    }
+
+    // ---------- inner classes ------------------------------------------------
+
+    private class ManagedServiceUpdate implements Runnable
+    {
+        private String pid;
+
+        private ServiceReference sr;
+
+        private ManagedService service;
+
+
+        ManagedServiceUpdate( String pid, ServiceReference sr, ManagedService service )
+        {
+            this.pid = pid;
+            this.sr = sr;
+            this.service = service;
+        }
+
+
+        public void run()
+        {
+            ConfigurationImpl cfg;
+            try
+            {
+                cfg = getConfiguration( pid, sr.getBundle().getLocation() );
+            }
+            catch ( IOException ioe )
+            {
+                log( LogService.LOG_ERROR, "Error loading configuration for " + pid, ioe );
+                return;
+            }
+
+            // 104.3 Ignore duplicate PIDs from other bundles and report them to
+            // the log
+            // 104.4.1 No update call back for PID already bound to another
+            // bundle location
+            String bundleLocation = sr.getBundle().getLocation();
+            if ( cfg.getBundleLocation() != null && !bundleLocation.equals( cfg.getBundleLocation() ) )
+            {
+                log( LogService.LOG_ERROR, "Cannot use configuration for " + pid + " requested by bundle "
+                    + sr.getBundle().getLocation() + " but belongs to " + cfg.getBundleLocation(), null );
+                return;
+            }
+
+            // 104.3 Report an error in the log if more than one service with
+            // the same PID asks for the configuration
+            if ( cfg.getServiceReference() != null && !sr.equals( cfg.getServiceReference() ) )
+            {
+                log( LogService.LOG_ERROR, "Configuration for " + pid + " has already been used for service "
+                    + cfg.getServiceReference() + " and will now also be given to " + sr, null );
+            }
+            else
+            {
+                // assign the configuration to the service
+                cfg.setServiceReference( sr );
+            }
+
+            // prepare the configuration for the service (call plugins)
+            Dictionary dictionary = callPlugins( sr, cfg );
+
+            // update the service with the configuration
+            try
+            {
+                service.updated( dictionary );
+            }
+            catch ( ConfigurationException ce )
+            {
+                if ( ce.getProperty() != null )
+                {
+                    log( LogService.LOG_ERROR, sr + ": Updating configuration property " + ce.getProperty()
+                        + " caused a problem: " + ce.getReason(), ce );
+                }
+                else
+                {
+                    log( LogService.LOG_ERROR, sr + ": Updating configuration caused a problem: " + ce.getReason(), ce );
+
+                }
+            }
+            catch ( Throwable t )
+            {
+                log( LogService.LOG_ERROR, sr + ": Unexpected problem updating configuration", t );
+            }
+
+            // 104.5.3 CM_UPDATED is sent asynchronously to all
+            // ConfigurationListeners
+            fireConfigurationEvent( ConfigurationEvent.CM_UPDATED, cfg );
+        }
+    }
+
+    private class ManagedServiceFactoryUpdate implements Runnable
+    {
+        private String factoryPid;
+
+        private ServiceReference sr;
+
+        private ManagedServiceFactory service;
+
+
+        ManagedServiceFactoryUpdate( String factoryPid, ServiceReference sr, ManagedServiceFactory service )
+        {
+            this.factoryPid = factoryPid;
+            this.sr = sr;
+            this.service = service;
+        }
+
+
+        public void run()
+        {
+            Factory factory;
+            try
+            {
+                factory = getFactory( factoryPid );
+            }
+            catch ( IOException ioe )
+            {
+                log( LogService.LOG_ERROR, "Cannot get factory mapping for factory PID " + factoryPid, ioe );
+                return;
+            }
+
+            String bundleLocation = sr.getBundle().getLocation();
+            if ( factory.getBundleLocation() == null )
+            {
+                // bind to the location of the service if unbound
+                factory.setBundleLocation( bundleLocation );
+            }
+            else if ( !bundleLocation.equals( factory.getBundleLocation() ) )
+            {
+                // factory PID is bound to another bundle
+                log( LogService.LOG_ERROR, "Cannot use Factory configuration for " + factoryPid
+                    + " requested by bundle " + sr.getBundle().getLocation() + " but belongs to "
+                    + factory.getBundleLocation(), null );
+                return;
+            }
+
+            Set pids = factory.getPIDs();
+
+            for ( Iterator pi = pids.iterator(); pi.hasNext(); )
+            {
+                String pid = ( String ) pi.next();
+                ConfigurationImpl cfg;
+                try
+                {
+                    cfg = getConfiguration( pid, bundleLocation );
+                }
+                catch ( IOException ioe )
+                {
+                    log( LogService.LOG_ERROR, "Error loading configuration for " + pid, ioe );
+                    continue;
+                }
+
+                // sanity check on the configuration
+                if ( cfg == null )
+                {
+                    log( LogService.LOG_ERROR, "Configuration " + pid + " referred to by factory " + factoryPid
+                        + " does not exist", null );
+                    factory.removePID( pid );
+                    factory.storeSilently();
+                    continue;
+                }
+                else if ( !factoryPid.equals( cfg.getFactoryPid() ) )
+                {
+                    log( LogService.LOG_ERROR, "Configuration " + pid + " referred to by factory " + factoryPid
+                        + " does not exist seems to belong to factory " + cfg.getFactoryPid(), null );
+                    factory.removePID( pid );
+                    factory.storeSilently();
+                    continue;
+                }
+
+                // check bundle location of configuration
+                if ( cfg.getBundleLocation() == null )
+                {
+                    // bind to the location of the service if unbound
+                    cfg.setBundleLocation( bundleLocation );
+                }
+                else if ( !bundleLocation.equals( cfg.getBundleLocation() ) )
+                {
+                    // configuration is bound to another bundle
+                    log( LogService.LOG_ERROR, "Configuration " + pid + " (factory " + factoryPid
+                        + ") belongs to bundle " + cfg.getBundleLocation() + " but was requested for bundle "
+                        + bundleLocation, null );
+                    continue;
+                }
+
+                // prepare the configuration for the service (call plugins)
+                Dictionary dictionary = callPlugins( sr, cfg );
+
+                // update the service with the configuration
+                try
+                {
+                    service.updated( pid, dictionary );
+                }
+                catch ( ConfigurationException ce )
+                {
+                    if ( ce.getProperty() != null )
+                    {
+                        log( LogService.LOG_ERROR, sr + ": Updating configuration property " + ce.getProperty()
+                            + " caused a problem: " + ce.getReason(), ce );
+                    }
+                    else
+                    {
+                        log( LogService.LOG_ERROR, sr + ": Updating configuration caused a problem: " + ce.getReason(),
+                            ce );
+
+                    }
+                }
+                catch ( Throwable t )
+                {
+                    log( LogService.LOG_ERROR, sr + ": Unexpected problem updating configuration", t );
+                }
+            }
+        }
+    }
+
+    private class UpdateConfiguration implements Runnable
+    {
+
+        private ConfigurationImpl config;
+
+
+        UpdateConfiguration( ConfigurationImpl config )
+        {
+            this.config = config;
+        }
+
+
+        public void run()
+        {
+            try
+            {
+                if ( config.getFactoryPid() == null )
+                {
+                    ServiceReference[] sr = bundleContext.getServiceReferences( ManagedService.class.getName(), "("
+                        + Constants.SERVICE_PID + "=" + config.getPid() + ")" );
+                    if ( sr != null && sr.length > 0 )
+                    {
+                        ManagedService srv = ( ManagedService ) bundleContext.getService( sr[0] );
+                        try
+                        {
+                            // bind the configuration, fail if bound to another
+                            // bundle !!
+                            // check bundle location of configuration
+                            String bundleLocation = sr[0].getBundle().getLocation();
+                            if ( config.getBundleLocation() == null )
+                            {
+                                // bind to the location of the service if
+                                // unbound
+                                config.setBundleLocation( bundleLocation );
+                            }
+                            else if ( !bundleLocation.equals( config.getBundleLocation() ) )
+                            {
+                                // configuration is bound to another bundle
+                                log( LogService.LOG_ERROR, "Configuration " + config.getPid() + " belongs to bundle "
+                                    + config.getBundleLocation() + " but was requested for bundle " + bundleLocation,
+                                    null );
+                                return;
+                            }
+
+                            srv.updated( config.getProperties() );
+                        }
+                        finally
+                        {
+                            bundleContext.ungetService( sr[0] );
+                        }
+                    }
+                }
+                else
+                {
+                    ServiceReference[] sr = bundleContext.getServiceReferences( ManagedServiceFactory.class.getName(),
+                        "(" + Constants.SERVICE_PID + "=" + config.getFactoryPid() + ")" );
+                    if ( sr != null && sr.length > 0 )
+                    {
+                        ManagedServiceFactory srv = ( ManagedServiceFactory ) bundleContext.getService( sr[0] );
+                        try
+                        {
+                            // bind the configuration, fail if bound to another
+                            // bundle !!
+                            // check bundle location of configuration
+                            String bundleLocation = sr[0].getBundle().getLocation();
+                            if ( config.getBundleLocation() == null )
+                            {
+                                // bind to the location of the service if
+                                // unbound
+                                config.setBundleLocation( bundleLocation );
+                            }
+                            else if ( !bundleLocation.equals( config.getBundleLocation() ) )
+                            {
+                                // configuration is bound to another bundle
+                                log( LogService.LOG_ERROR, "Configuration " + config.getPid() + " (factory "
+                                    + config.getFactoryPid() + ") belongs to bundle " + config.getBundleLocation()
+                                    + " but was requested for bundle " + bundleLocation, null );
+                                return;
+                            }
+
+                            srv.updated( config.getPid(), config.getProperties() );
+                        }
+                        finally
+                        {
+                            bundleContext.ungetService( sr[0] );
+                        }
+                    }
+                }
+            }
+            catch ( ConfigurationException ce )
+            {
+                if ( ce.getProperty() != null )
+                {
+                    log( LogService.LOG_ERROR, "Updating configuration property " + ce.getProperty()
+                        + " caused a problem: " + ce.getReason(), ce );
+                }
+                else
+                {
+                    log( LogService.LOG_ERROR, "Updating configuration caused a problem: " + ce.getReason(), ce );
+
+                }
+            }
+            catch ( Throwable t )
+            {
+                log( LogService.LOG_ERROR, "Unexpected problem updating configuration", t );
+            }
+
+            fireConfigurationEvent( ConfigurationEvent.CM_UPDATED, config );
+        }
+    }
+
+    private class DeleteConfiguration implements Runnable
+    {
+        private ConfigurationImpl config;
+
+
+        DeleteConfiguration( ConfigurationImpl config )
+        {
+            this.config = config;
+        }
+
+
+        public void run()
+        {
+            try
+            {
+                if ( config.getFactoryPid() == null )
+                {
+                    ServiceReference[] sr = bundleContext.getServiceReferences( ManagedService.class.getName(), "("
+                        + Constants.SERVICE_PID + "=" + config.getPid() + ")" );
+                    if ( sr != null && sr.length > 0 )
+                    {
+                        ManagedService srv = ( ManagedService ) bundleContext.getService( sr[0] );
+                        try
+                        {
+                            srv.updated( null );
+                        }
+                        finally
+                        {
+                            bundleContext.ungetService( sr[0] );
+                        }
+                    }
+                }
+                else
+                {
+                    // remove the pid from the factory
+                    Factory factory = getFactory( config.getFactoryPid() );
+                    factory.removePID( config.getPid() );
+                    factory.store();
+
+                    ServiceReference[] sr = bundleContext.getServiceReferences( ManagedServiceFactory.class.getName(),
+                        "(" + Constants.SERVICE_PID + "=" + config.getFactoryPid() + ")" );
+                    if ( sr != null && sr.length > 0 )
+                    {
+                        ManagedServiceFactory srv = ( ManagedServiceFactory ) bundleContext.getService( sr[0] );
+                        try
+                        {
+                            srv.deleted( config.getPid() );
+                        }
+                        finally
+                        {
+                            bundleContext.ungetService( sr[0] );
+                        }
+                    }
+                }
+            }
+            catch ( ConfigurationException ce )
+            {
+                if ( ce.getProperty() != null )
+                {
+                    log( LogService.LOG_ERROR, "Updating configuration property " + ce.getProperty()
+                        + " caused a problem: " + ce.getReason(), ce );
+                }
+                else
+                {
+                    log( LogService.LOG_ERROR, "Updating configuration caused a problem: " + ce.getReason(), ce );
+
+                }
+            }
+            catch ( Throwable t )
+            {
+                log( LogService.LOG_ERROR, "Unexpected problem updating configuration", t );
+            }
+
+            fireConfigurationEvent( ConfigurationEvent.CM_DELETED, config );
+        }
+    }
+
+    private class FireConfigurationEvent implements Runnable
+    {
+        private int type;
+
+        private ConfigurationImpl config;
+
+
+        FireConfigurationEvent( int type, ConfigurationImpl config )
+        {
+            this.type = type;
+            this.config = config;
+        }
+
+
+        public void run()
+        {
+            // get the listeners
+            ServiceReference[] srs = configurationListenerTracker.getServiceReferences();
+            if ( srs == null || srs.length == 0 )
+            {
+                return;
+            }
+
+            ConfigurationEvent event = new ConfigurationEvent( configurationAdminReference, type, config
+                .getFactoryPid(), config.getPid() );
+
+            for ( int i = 0; i < srs.length; i++ )
+            {
+                ConfigurationListener cl = ( ConfigurationListener ) configurationListenerTracker.getService( srs[i] );
+                try
+                {
+                    cl.configurationEvent( event );
+                }
+                catch ( Throwable t )
+                {
+                    log( LogService.LOG_ERROR, "Unexpected problem delivery configuration event to " + srs[i], t );
+                }
+            }
+        }
+    }
+
+    private abstract class AbstractManagedServiceTracker extends ServiceTracker
+    {
+        AbstractManagedServiceTracker( String className )
+        {
+            super( bundleContext, className, null );
+            open();
+        }
+
+
+        public void removedService( ServiceReference reference, Object service )
+        {
+            // check whether we can take back the configuration object
+            String pid = ( String ) reference.getProperty( Constants.SERVICE_PID );
+            if ( pid != null )
+            {
+                ConfigurationImpl cfg = getCachedConfiguration( pid );
+                if ( cfg != null && reference.equals( cfg.getServiceReference() ) )
+                {
+                    cfg.setServiceReference( null );
+                }
+            }
+
+            super.removedService( reference, service );
+        }
+    }
+
+    private class ManagedServiceTracker extends AbstractManagedServiceTracker
+    {
+        ManagedServiceTracker()
+        {
+            super( ManagedService.class.getName() );
+        }
+
+
+        public Object addingService( ServiceReference reference )
+        {
+            ManagedService service = ( ManagedService ) super.addingService( reference );
+
+            // configure the managed service
+            if ( service != null )
+            {
+                configure( reference, service );
+            }
+
+            return service;
+        }
+    }
+
+    private class ManagedServiceFactoryTracker extends AbstractManagedServiceTracker
+    {
+        ManagedServiceFactoryTracker()
+        {
+            super( ManagedServiceFactory.class.getName() );
+        }
+
+
+        public Object addingService( ServiceReference reference )
+        {
+            ManagedServiceFactory service = ( ManagedServiceFactory ) super.addingService( reference );
+
+            // configure the managed service
+            if ( service != null )
+            {
+                configure( reference, service );
+            }
+
+            return service;
+        }
+    }
+}

Propchange: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/ConfigurationManager.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/ConfigurationManager.java
------------------------------------------------------------------------------
    svn:keywords = author date id revision url

Added: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/Factory.java
URL: http://svn.apache.org/viewvc/incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/Factory.java?view=auto&rev=527592
==============================================================================
--- incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/Factory.java (added)
+++ incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/Factory.java Wed Apr 11 11:12:33 2007
@@ -0,0 +1,185 @@
+/* 
+ * 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.felix.cm.impl;
+
+
+import java.io.IOException;
+import java.util.Dictionary;
+import java.util.HashSet;
+import java.util.Hashtable;
+import java.util.Set;
+
+import org.apache.felix.cm.PersistenceManager;
+import org.osgi.service.cm.ConfigurationAdmin;
+import org.osgi.service.log.LogService;
+
+
+/**
+ * The <code>Factory</code> class is used to manage mappings between factory PIDs
+ * the configuration PID belonging to it.
+ *
+ * @author fmeschbe
+ */
+class Factory
+{
+
+    public static final String FACTORY_PID_LIST = "factory.pidList";
+
+    // the persistence manager storing this factory mapping
+    private PersistenceManager persistenceManager;
+    
+    // the factory PID of this factory
+    private String factoryPid;
+    
+    // the bundle location to which factory PID mapping is bound 
+    private String bundleLocation;
+    
+    // the set of configuration PIDs belonging to this factory
+    private Set pids;
+
+
+    static boolean exists( PersistenceManager persistenceManager, String factoryPid )
+    {
+        return persistenceManager.exists( factoryPidToIdentifier( factoryPid ) );
+    }
+
+
+    static Factory load( PersistenceManager persistenceManager, String factoryPid ) throws IOException
+    {
+        Dictionary dict = persistenceManager.load( factoryPidToIdentifier( factoryPid ) );
+        return new Factory( persistenceManager, factoryPid, dict );
+    }
+
+
+    private static String factoryPidToIdentifier( String factoryPid )
+    {
+        return factoryPid + ".factory";
+    }
+
+
+    Factory( PersistenceManager persistenceManager, String factoryPid )
+    {
+        this.persistenceManager = persistenceManager;
+        this.factoryPid = factoryPid;
+        this.pids = new HashSet();
+    }
+
+
+    Factory( PersistenceManager persistenceManager, String factoryPid, Dictionary props )
+    {
+        this( persistenceManager, factoryPid );
+
+        // set bundle location
+        setBundleLocation( ( String ) props.get( ConfigurationAdmin.SERVICE_BUNDLELOCATION ) );
+
+        // set pids
+        String[] pidList = ( String[] ) props.get( FACTORY_PID_LIST );
+        if ( pidList != null )
+        {
+            for ( int i = 0; i < pidList.length; i++ )
+            {
+                addPID( pidList[i] );
+            }
+        }
+    }
+
+
+    PersistenceManager getPersistenceManager()
+    {
+        return persistenceManager;
+    }
+
+
+    String getFactoryPid()
+    {
+        return factoryPid;
+    }
+
+
+    String getBundleLocation()
+    {
+        return bundleLocation;
+    }
+
+
+    void setBundleLocation( String bundleLocation )
+    {
+        this.bundleLocation = bundleLocation;
+        
+        // 104.15.2.8 The bundle location will be set persistently
+        storeSilently();
+    }
+
+
+    Set getPIDs()
+    {
+        return new HashSet( pids );
+    }
+
+
+    boolean addPID( String pid )
+    {
+        return pids.add( pid );
+    }
+
+
+    boolean removePID( String pid )
+    {
+        return pids.remove( pid );
+    }
+
+
+    void store() throws IOException
+    {
+        Hashtable props = new Hashtable();
+
+        if ( bundleLocation != null )
+        {
+            props.put( ConfigurationAdmin.SERVICE_BUNDLELOCATION, getBundleLocation() );
+        }
+
+        if ( !pids.isEmpty() )
+        {
+            props.put( FACTORY_PID_LIST, pids.toArray( new String[pids.size()] ) );
+        }
+
+        String id = factoryPidToIdentifier( getFactoryPid() );
+        if ( props.isEmpty() )
+        {
+            persistenceManager.delete( id );
+        }
+        else
+        {
+            persistenceManager.store( id, props );
+        }
+    }
+    
+    void storeSilently()
+    {
+        try
+        {
+            store();
+        }
+        catch ( IOException ioe )
+        {
+            // should actually log this problem
+            // configurationManager.log( LogService.LOG_ERROR, "Persisting new bundle location failed", ioe );
+        }
+    }
+}

Propchange: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/Factory.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/Factory.java
------------------------------------------------------------------------------
    svn:keywords = author date id revision url

Added: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/PersistenceManagerProxy.java
URL: http://svn.apache.org/viewvc/incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/PersistenceManagerProxy.java?view=auto&rev=527592
==============================================================================
--- incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/PersistenceManagerProxy.java (added)
+++ incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/PersistenceManagerProxy.java Wed Apr 11 11:12:33 2007
@@ -0,0 +1,120 @@
+/* 
+ * 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.felix.cm.impl;
+
+
+import java.io.IOException;
+import java.util.Dictionary;
+import java.util.Enumeration;
+
+import org.apache.felix.cm.PersistenceManager;
+
+
+/**
+ * The <code>PersistenceManagerProxy</code> TODO
+ *
+ * @author fmeschbe
+ */
+class PersistenceManagerProxy implements PersistenceManager
+{
+
+    private PersistenceManager delegatee;
+
+
+    PersistenceManagerProxy( PersistenceManager delegatee )
+    {
+        setPersistenceManager( delegatee );
+    }
+
+
+    /**
+     * @param pid
+     * @throws IOException
+     * @see org.apache.felix.cm.PersistenceManager#delete(java.lang.String)
+     */
+    public void delete( String pid ) throws IOException
+    {
+        checkDelegatee();
+        delegatee.delete( pid );
+    }
+
+
+    /**
+     * @param pid
+     * @return
+     * @see org.apache.felix.cm.PersistenceManager#exists(java.lang.String)
+     */
+    public boolean exists( String pid )
+    {
+        return delegatee != null && delegatee.exists( pid );
+    }
+
+
+    /**
+     * @return
+     * @throws IOException
+     * @see org.apache.felix.cm.PersistenceManager#getDictionaries()
+     */
+    public Enumeration getDictionaries() throws IOException
+    {
+        checkDelegatee();
+        return delegatee.getDictionaries();
+    }
+
+
+    /**
+     * @param pid
+     * @return
+     * @throws IOException
+     * @see org.apache.felix.cm.PersistenceManager#load(java.lang.String)
+     */
+    public Dictionary load( String pid ) throws IOException
+    {
+        checkDelegatee();
+        return delegatee.load( pid );
+    }
+
+
+    /**
+     * @param pid
+     * @param properties
+     * @throws IOException
+     * @see org.apache.felix.cm.PersistenceManager#store(java.lang.String, java.util.Dictionary)
+     */
+    public void store( String pid, Dictionary properties ) throws IOException
+    {
+        checkDelegatee();
+        delegatee.store( pid, properties );
+    }
+
+
+    void setPersistenceManager( PersistenceManager delegatee )
+    {
+        this.delegatee = delegatee;
+    }
+
+
+    void checkDelegatee() throws IOException
+    {
+        if ( delegatee == null )
+        {
+            throw new IOException( "PersistenceManager not valid" );
+        }
+    }
+}

Propchange: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/PersistenceManagerProxy.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/PersistenceManagerProxy.java
------------------------------------------------------------------------------
    svn:keywords = author date id revision url

Added: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/RankingComparator.java
URL: http://svn.apache.org/viewvc/incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/RankingComparator.java?view=auto&rev=527592
==============================================================================
--- incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/RankingComparator.java (added)
+++ incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/RankingComparator.java Wed Apr 11 11:12:33 2007
@@ -0,0 +1,98 @@
+/* 
+ * 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.felix.cm.impl;
+
+
+import java.util.Comparator;
+
+import org.osgi.framework.Constants;
+import org.osgi.framework.ServiceReference;
+import org.osgi.service.cm.ConfigurationPlugin;
+
+
+/**
+ * The <code>RankingComparator</code> TODO
+ *
+ * @author fmeschbe
+ */
+public class RankingComparator implements Comparator
+{
+
+    private final boolean naturalOrder;
+    private final String rankProperty;
+
+
+    public RankingComparator(boolean naturalOrder)
+    {
+        this( naturalOrder, Constants.SERVICE_RANKING );
+    }
+
+
+    public RankingComparator( boolean naturalOrder, String rankProperty )
+    {
+        this.naturalOrder = naturalOrder;
+        this.rankProperty = rankProperty;
+    }
+
+
+    public int compare( Object obj1, Object obj2 )
+    {
+        if ( obj1.equals( obj2 ) )
+        {
+            return 0;
+        }
+
+        int rank1 = getInt( ( ServiceReference ) obj1, rankProperty );
+        int rank2 = getInt( ( ServiceReference ) obj2, rankProperty );
+
+        // use service id, if rankings are equal
+        if ( rank1 == rank2 )
+        {
+            rank1 = getInt( ( ServiceReference ) obj1, Constants.SERVICE_ID );
+            rank2 = getInt( ( ServiceReference ) obj2, Constants.SERVICE_ID );
+        }
+
+        if ( rank1 == rank2 )
+        {
+            return 0;
+        }
+        else if ( naturalOrder && rank1 > rank2)
+        {
+            return 1;
+        }
+        else
+        {
+            return -1;
+        }
+    }
+
+
+    private int getInt( ServiceReference sr, String property )
+    {
+        Object rankObj = sr.getProperty( property );
+        if ( rankObj instanceof Integer )
+        {
+            return ( ( Integer ) rankObj ).intValue();
+        }
+
+        // null or not an integer
+        return 0;
+    }
+
+}

Propchange: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/RankingComparator.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/RankingComparator.java
------------------------------------------------------------------------------
    svn:keywords = author date id revision url

Added: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/UpdateThread.java
URL: http://svn.apache.org/viewvc/incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/UpdateThread.java?view=auto&rev=527592
==============================================================================
--- incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/UpdateThread.java (added)
+++ incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/UpdateThread.java Wed Apr 11 11:12:33 2007
@@ -0,0 +1,119 @@
+/* 
+ * 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.felix.cm.impl;
+
+
+import java.util.LinkedList;
+
+import org.osgi.service.log.LogService;
+
+
+/**
+ * The <code>UpdateThread</code> is the thread used to update managed services
+ * and managed service factories as well as to send configuration events.
+ *
+ * @author fmeschbe
+ */
+public class UpdateThread extends Thread
+{
+
+    // the configuration manager on whose behalf this thread is started
+    // (this is mainly used for logging)
+    private ConfigurationManager configurationManager;
+    
+    // the queue of Runnable instances  to be run
+    private LinkedList updateTasks;
+
+
+    public UpdateThread( ConfigurationManager configurationManager )
+    {
+        super( "Configuration Updater" );
+
+        this.configurationManager = configurationManager;
+        this.updateTasks = new LinkedList();
+    }
+
+
+    // waits on Runnable instances coming into the queue. As instances come
+    // in, this method calls the Runnable.run method, logs any exception
+    // happening and keeps on waiting for the next Runnable. If the Runnable
+    // taken from the queue is this thread instance itself, the thread
+    // terminates.
+    public void run()
+    {
+        for ( ;; )
+        {
+            Runnable task;
+            synchronized ( updateTasks )
+            {
+                while ( updateTasks.isEmpty() )
+                {
+                    try
+                    {
+                        updateTasks.wait();
+                    }
+                    catch ( InterruptedException ie )
+                    {
+                        // don't care
+                    }
+                }
+
+                task = ( Runnable ) updateTasks.removeFirst();
+            }
+
+            // return if the task is this thread itself
+            if ( task == this )
+            {
+                return;
+            }
+
+            // otherwise execute the task, log any issues
+            try
+            {
+                task.run();
+            }
+            catch ( Throwable t )
+            {
+                configurationManager.log( LogService.LOG_ERROR, "Unexpected problem executing task", t );
+            }
+        }
+    }
+
+
+    // cause this thread to terminate by adding this thread to the end
+    // of the queue
+    void terminate()
+    {
+        schedule( this );
+    }
+
+
+    // queue the given runnable to be run as soon as possible
+    void schedule( Runnable update )
+    {
+        synchronized ( updateTasks )
+        {
+            // append to the task queue
+            updateTasks.add( update );
+            
+            // notify the waiting thread
+            updateTasks.notifyAll();
+        }
+    }
+}

Propchange: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/UpdateThread.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/felix/trunk/configadmin/src/main/java/org/apache/felix/cm/impl/UpdateThread.java
------------------------------------------------------------------------------
    svn:keywords = author date id revision url

Added: incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/MockBundleContext.java
URL: http://svn.apache.org/viewvc/incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/MockBundleContext.java?view=auto&rev=527592
==============================================================================
--- incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/MockBundleContext.java (added)
+++ incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/MockBundleContext.java Wed Apr 11 11:12:33 2007
@@ -0,0 +1,260 @@
+/*
+ * $Url: $
+ * $Id$
+ *
+ * Copyright 1997-2005 Day Management AG
+ * Barfuesserplatz 6, 4001 Basel, Switzerland
+ * All Rights Reserved.
+ *
+ * This software is the confidential and proprietary information of
+ * Day Management AG, ("Confidential Information"). You shall not
+ * disclose such Confidential Information and shall use it only in
+ * accordance with the terms of the license agreement you entered into
+ * with Day.
+ */
+package org.apache.felix.cm;
+
+import java.io.File;
+import java.io.InputStream;
+import java.util.Dictionary;
+
+import org.osgi.framework.Bundle;
+import org.osgi.framework.BundleContext;
+import org.osgi.framework.BundleException;
+import org.osgi.framework.BundleListener;
+import org.osgi.framework.Filter;
+import org.osgi.framework.FrameworkListener;
+import org.osgi.framework.InvalidSyntaxException;
+import org.osgi.framework.ServiceListener;
+import org.osgi.framework.ServiceReference;
+import org.osgi.framework.ServiceRegistration;
+
+/**
+ * The <code>MockBundleContext</code> TODO
+ *
+ * @author fmeschbe
+ * @version $Rev:$, $Date:$
+ */
+public class MockBundleContext implements BundleContext
+{
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#addBundleListener(org.osgi.framework.BundleListener)
+     */
+    public void addBundleListener( BundleListener arg0 )
+    {
+        // TODO Auto-generated method stub
+
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#addFrameworkListener(org.osgi.framework.FrameworkListener)
+     */
+    public void addFrameworkListener( FrameworkListener arg0 )
+    {
+        // TODO Auto-generated method stub
+
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#addServiceListener(org.osgi.framework.ServiceListener)
+     */
+    public void addServiceListener( ServiceListener arg0 )
+    {
+        // TODO Auto-generated method stub
+
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#addServiceListener(org.osgi.framework.ServiceListener, java.lang.String)
+     */
+    public void addServiceListener( ServiceListener arg0, String arg1 ) throws InvalidSyntaxException
+    {
+        // TODO Auto-generated method stub
+
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#createFilter(java.lang.String)
+     */
+    public Filter createFilter( String arg0 ) throws InvalidSyntaxException
+    {
+        // TODO Auto-generated method stub
+        return null;
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#getAllServiceReferences(java.lang.String, java.lang.String)
+     */
+    public ServiceReference[] getAllServiceReferences( String arg0, String arg1 ) throws InvalidSyntaxException
+    {
+        // TODO Auto-generated method stub
+        return null;
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#getBundle()
+     */
+    public Bundle getBundle()
+    {
+        // TODO Auto-generated method stub
+        return null;
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#getBundle(long)
+     */
+    public Bundle getBundle( long arg0 )
+    {
+        // TODO Auto-generated method stub
+        return null;
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#getBundles()
+     */
+    public Bundle[] getBundles()
+    {
+        // TODO Auto-generated method stub
+        return null;
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#getDataFile(java.lang.String)
+     */
+    public File getDataFile( String arg0 )
+    {
+        // TODO Auto-generated method stub
+        return null;
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#getProperty(java.lang.String)
+     */
+    public String getProperty( String arg0 )
+    {
+        // TODO Auto-generated method stub
+        return null;
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#getService(org.osgi.framework.ServiceReference)
+     */
+    public Object getService( ServiceReference arg0 )
+    {
+        // TODO Auto-generated method stub
+        return null;
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#getServiceReference(java.lang.String)
+     */
+    public ServiceReference getServiceReference( String arg0 )
+    {
+        // TODO Auto-generated method stub
+        return null;
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#getServiceReferences(java.lang.String, java.lang.String)
+     */
+    public ServiceReference[] getServiceReferences( String arg0, String arg1 ) throws InvalidSyntaxException
+    {
+        // TODO Auto-generated method stub
+        return null;
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#installBundle(java.lang.String)
+     */
+    public Bundle installBundle( String arg0 ) throws BundleException
+    {
+        // TODO Auto-generated method stub
+        return null;
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#installBundle(java.lang.String, java.io.InputStream)
+     */
+    public Bundle installBundle( String arg0, InputStream arg1 ) throws BundleException
+    {
+        // TODO Auto-generated method stub
+        return null;
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#registerService(java.lang.String[], java.lang.Object, java.util.Dictionary)
+     */
+    public ServiceRegistration registerService( String[] arg0, Object arg1, Dictionary arg2 )
+    {
+        // TODO Auto-generated method stub
+        return null;
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#registerService(java.lang.String, java.lang.Object, java.util.Dictionary)
+     */
+    public ServiceRegistration registerService( String arg0, Object arg1, Dictionary arg2 )
+    {
+        // TODO Auto-generated method stub
+        return null;
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#removeBundleListener(org.osgi.framework.BundleListener)
+     */
+    public void removeBundleListener( BundleListener arg0 )
+    {
+        // TODO Auto-generated method stub
+
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#removeFrameworkListener(org.osgi.framework.FrameworkListener)
+     */
+    public void removeFrameworkListener( FrameworkListener arg0 )
+    {
+        // TODO Auto-generated method stub
+
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#removeServiceListener(org.osgi.framework.ServiceListener)
+     */
+    public void removeServiceListener( ServiceListener arg0 )
+    {
+        // TODO Auto-generated method stub
+
+    }
+
+
+    /* (non-Javadoc)
+     * @see org.osgi.framework.BundleContext#ungetService(org.osgi.framework.ServiceReference)
+     */
+    public boolean ungetService( ServiceReference arg0 )
+    {
+        // TODO Auto-generated method stub
+        return false;
+    }
+
+}

Propchange: incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/MockBundleContext.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/MockBundleContext.java
------------------------------------------------------------------------------
    svn:keywords = author date id revision url

Added: incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/file/FileNameTest.java
URL: http://svn.apache.org/viewvc/incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/file/FileNameTest.java?view=auto&rev=527592
==============================================================================
--- incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/file/FileNameTest.java (added)
+++ incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/file/FileNameTest.java Wed Apr 11 11:12:33 2007
@@ -0,0 +1,104 @@
+/*
+ * $Url: $
+ * $Id$
+ *
+ * Copyright 1997-2005 Day Management AG
+ * Barfuesserplatz 6, 4001 Basel, Switzerland
+ * All Rights Reserved.
+ *
+ * This software is the confidential and proprietary information of
+ * Day Management AG, ("Confidential Information"). You shall not
+ * disclose such Confidential Information and shall use it only in
+ * accordance with the terms of the license agreement you entered into
+ * with Day.
+ */
+package org.apache.felix.cm.file;
+
+
+import java.io.File;
+import java.util.BitSet;
+
+import junit.framework.TestCase;
+
+
+public class FileNameTest extends TestCase
+{
+
+    public void testPidPlain()
+    {
+        assertEquals( "plain", encodePath( "plain" ) );
+        assertEquals( "plain" + File.separatorChar + "path", encodePath( "plain.path" ) );
+        assertEquals( "encod%00e8", encodePath( "encodè" ) );
+        assertEquals( "encod%00e8" + File.separatorChar + "path", encodePath( "encodè/path" ) );
+        assertEquals( "encode" + File.separatorChar + "%1234" + File.separatorChar + "path", encodePath( "encode/\u1234/path" ) );
+        assertEquals( "encode" + File.separatorChar + " %0025 " + File.separatorChar + "path", encodePath( "encode/ % /path" ) );
+    }
+
+    private static final BitSet VALID_PATH_CHARS;
+
+    static
+    {
+        VALID_PATH_CHARS = new BitSet();
+
+        for ( int i = 'a'; i <= 'z'; i++ )
+        {
+            VALID_PATH_CHARS.set( i );
+        }
+        for ( int i = 'A'; i <= 'Z'; i++ )
+        {
+            VALID_PATH_CHARS.set( i );
+        }
+        for ( int i = '0'; i <= '9'; i++ )
+        {
+            VALID_PATH_CHARS.set( i );
+        }
+        VALID_PATH_CHARS.set( File.separatorChar );
+        VALID_PATH_CHARS.set( ' ' );
+        VALID_PATH_CHARS.set( '-' );
+        VALID_PATH_CHARS.set( '_' );
+    }
+
+
+    private String encodePath( String pid )
+    {
+        // replace dots by File.separatorChar
+        pid = pid.replace( '.', File.separatorChar );
+
+        // replace slash by File.separatorChar if different
+        if (File.separatorChar != '/') {
+            pid = pid.replace( '/', File.separatorChar );
+        }
+
+        // scan for first non-valid character (if any)
+        int first = 0;
+        while ( first < pid.length() && VALID_PATH_CHARS.get( pid.charAt( first ) ) )
+        {
+            first++;
+        }
+
+        // check whether we exhausted
+        if ( first < pid.length() )
+        {
+            StringBuffer buf = new StringBuffer( pid.substring( 0, first ) );
+
+            for ( int i = first; i < pid.length(); i++ )
+            {
+                char c = pid.charAt( i );
+                if ( VALID_PATH_CHARS.get( c ) )
+                {
+                    buf.append( c );
+                }
+                else
+                {
+                    String val = "000" + Integer.toHexString( c );
+                    buf.append( '%' );
+                    buf.append( val.substring( val.length() - 4 ) );
+                }
+            }
+            
+            return buf.toString();
+        }
+        
+        return pid;
+    }
+}

Propchange: incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/file/FileNameTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/file/FileNameTest.java
------------------------------------------------------------------------------
    svn:keywords = author date id revision url

Added: incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/file/FilePersistenceManagerTest.java
URL: http://svn.apache.org/viewvc/incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/file/FilePersistenceManagerTest.java?view=auto&rev=527592
==============================================================================
--- incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/file/FilePersistenceManagerTest.java (added)
+++ incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/file/FilePersistenceManagerTest.java Wed Apr 11 11:12:33 2007
@@ -0,0 +1,177 @@
+/*
+ * $Url: $
+ * $Id$
+ *
+ * Copyright 1997-2005 Day Management AG
+ * Barfuesserplatz 6, 4001 Basel, Switzerland
+ * All Rights Reserved.
+ *
+ * This software is the confidential and proprietary information of
+ * Day Management AG, ("Confidential Information"). You shall not
+ * disclose such Confidential Information and shall use it only in
+ * accordance with the terms of the license agreement you entered into
+ * with Day.
+ */
+package org.apache.felix.cm.file;
+
+
+import java.io.File;
+import java.io.IOException;
+import java.lang.reflect.Array;
+import java.util.Arrays;
+import java.util.Dictionary;
+import java.util.Enumeration;
+import java.util.Hashtable;
+import java.util.Vector;
+
+import junit.framework.TestCase;
+
+
+/**
+ * The <code>FilePersistenceManagerTest</code> TODO
+ *
+ * @author fmeschbe
+ * @version $Rev:$, $Date:$
+ */
+public class FilePersistenceManagerTest extends TestCase
+{
+    private File file = new File( System.getProperty( "java.io.tmpdir" ), "config" );
+
+    private FilePersistenceManager fpm;
+
+
+    protected void setUp() throws Exception
+    {
+        super.setUp();
+
+        fpm = new FilePersistenceManager( file.getAbsolutePath() );
+    }
+
+
+    protected void tearDown() throws Exception
+    {
+        File[] children = file.listFiles();
+        for ( int i = 0; children != null && i < children.length; i++ )
+        {
+            children[i].delete();
+        }
+        file.delete();
+
+        super.tearDown();
+    }
+
+
+    public void testCreateDir()
+    {
+        assertTrue( file.isDirectory() );
+    }
+
+
+    public void testSimple() throws IOException
+    {
+        check( "String", "String Value" );
+        check( "Integer", new Integer( 2 ) );
+        check( "Long", new Long( 2 ) );
+        check( "Float", new Float( 2 ) );
+        check( "Double", new Double( 2 ) );
+        check( "Byte", new Byte( ( byte ) 2 ) );
+        check( "Short", new Short( ( short ) 2 ) );
+        check( "Character", new Character( 'a' ) );
+        check( "Boolean", Boolean.TRUE );
+    }
+
+
+    public void testQuoting() throws IOException
+    {
+        check( "QuotingSeparators", "\\()[]{}.,=" );
+        check( "QuotingWellKnown", "BSP:\b, TAB:\t, LF:\n, FF:\f, CR:\r" );
+        check( "QuotingControl", new String( new char[]
+            { 5, 10, 32, 64 } ) );
+    }
+
+
+    public void testArray() throws IOException
+    {
+        check( "StringArray", new String[]
+            { "one", "two", "three" } );
+        check( "IntArray", new int[]
+            { 0, 1, 2 } );
+        check( "IntegerArray", new Integer[]
+            { new Integer( 0 ), new Integer( 1 ), new Integer( 2 ) } );
+    }
+
+
+    public void testVector() throws IOException
+    {
+        check( "StringVector", new Vector( Arrays.asList( new String[]
+            { "one", "two", "three" } ) ) );
+        check( "IntegerVector", new Vector( Arrays.asList( new Integer[]
+            { new Integer( 0 ), new Integer( 1 ), new Integer( 2 ) } ) ) );
+    }
+
+
+    public void testMultiValue() throws IOException
+    {
+        Dictionary props = new Hashtable();
+        props.put( "String", "String Value" );
+        props.put( "Integer", new Integer( 2 ) );
+        props.put( "Long", new Long( 2 ) );
+        props.put( "Float", new Float( 2 ) );
+        props.put( "Double", new Double( 2 ) );
+        props.put( "Byte", new Byte( ( byte ) 2 ) );
+        props.put( "Short", new Short( ( short ) 2 ) );
+        props.put( "Character", new Character( 'a' ) );
+        props.put( "Boolean", Boolean.TRUE );
+        props.put( "Array", new boolean[]
+            { true, false } );
+
+        check( "MultiValue", props );
+    }
+
+
+    private void check( String name, Object value ) throws IOException
+    {
+        Dictionary props = new Hashtable();
+        props.put( name, value );
+
+        check( name, props );
+    }
+
+
+    private void check( String pid, Dictionary props ) throws IOException
+    {
+        fpm.store( pid, props );
+
+        assertTrue( new File( file, pid + ".config" ).exists() );
+
+        Dictionary loaded = fpm.load( pid );
+        assertNotNull( loaded );
+        assertEquals( props.size(), loaded.size() );
+
+        for ( Enumeration pe = props.keys(); pe.hasMoreElements(); )
+        {
+            String key = ( String ) pe.nextElement();
+            checkValues( props.get( key ), loaded.get( key ) );
+        }
+    }
+
+
+    private void checkValues( Object value1, Object value2 )
+    {
+        assertNotNull( value2 );
+        if ( value1.getClass().isArray() )
+        {
+            assertTrue( value2.getClass().isArray() );
+            assertEquals( value1.getClass().getComponentType(), value2.getClass().getComponentType() );
+            assertEquals( Array.getLength( value1 ), Array.getLength( value2 ) );
+            for ( int i = 0; i < Array.getLength( value1 ); i++ )
+            {
+                assertEquals( Array.get( value1, i ), Array.get( value2, i ) );
+            }
+        }
+        else
+        {
+            assertEquals( value1, value2 );
+        }
+    }
+}

Propchange: incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/file/FilePersistenceManagerTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/felix/trunk/configadmin/src/test/java/org/apache/felix/cm/file/FilePersistenceManagerTest.java
------------------------------------------------------------------------------
    svn:keywords = author date id revision url