You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@directory.apache.org by ak...@apache.org on 2011/01/23 02:17:26 UTC

svn commit: r1062306 [14/32] - in /directory: apacheds-manuals/trunk/src/advanced-user-guide/ apacheds-manuals/trunk/src/basic-user-guide/ apacheds/trunk/core-annotations/src/main/java/org/apache/directory/server/core/factory/ apacheds/trunk/core-api/s...

Modified: directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/SyncReplConsumer.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/SyncReplConsumer.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/SyncReplConsumer.java (original)
+++ directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/SyncReplConsumer.java Sun Jan 23 01:17:06 2011
@@ -80,8 +80,8 @@ import org.apache.directory.shared.ldap.
 import org.apache.directory.shared.ldap.message.control.replication.SyncModifyDnType;
 import org.apache.directory.shared.ldap.message.control.replication.SyncStateTypeEnum;
 import org.apache.directory.shared.ldap.message.control.replication.SynchronizationModeEnum;
-import org.apache.directory.shared.ldap.name.DN;
-import org.apache.directory.shared.ldap.name.RDN;
+import org.apache.directory.shared.ldap.name.Dn;
+import org.apache.directory.shared.ldap.name.Rdn;
 import org.apache.directory.shared.ldap.schema.AttributeType;
 import org.apache.directory.shared.ldap.schema.AttributeTypeOptions;
 import org.apache.directory.shared.ldap.schema.SchemaManager;
@@ -158,7 +158,7 @@ public class SyncReplConsumer implements
 
     private List<Modification> cookieModLst;
 
-    private DN configEntryDn;
+    private Dn configEntryDn;
 
     private static AttributeType COOKIE_AT_TYPE;
 
@@ -200,7 +200,7 @@ public class SyncReplConsumer implements
         cookieModLst = new ArrayList<Modification>( 1 );
         cookieModLst.add( cookieMod );
 
-        configEntryDn = new DN( config.getConfigEntryDn(), schemaManager );
+        configEntryDn = new Dn( config.getConfigEntryDn(), schemaManager );
 
         prepareSyncSearchRequest();
     }
@@ -235,7 +235,7 @@ public class SyncReplConsumer implements
 
             if ( ldapResult.getResultCode() != ResultCodeEnum.SUCCESS )
             {
-                LOG.warn( "Failed to bind to the server with the given bind DN {} and credentials: {}", config.getReplUserDn(), ldapResult );
+                LOG.warn( "Failed to bind to the server with the given bind Dn {} and credentials: {}", config.getReplUserDn(), ldapResult );
             }
             else
             {
@@ -262,7 +262,7 @@ public class SyncReplConsumer implements
 
         searchRequest = new SearchRequestImpl();
 
-        searchRequest.setBase( new DN( baseDn ) );
+        searchRequest.setBase( new Dn( baseDn ) );
         searchRequest.setFilter( config.getFilter() );
         searchRequest.setSizeLimit( config.getSearchSizeLimit() );
         searchRequest.setTimeLimit( config.getSearchTimeout() );
@@ -395,7 +395,7 @@ public class SyncReplConsumer implements
                 case DELETE:
                     LOG.debug( "deleting entry with dn {}", remoteEntry.getDn().getName() );
                     // incase of a MODDN operation resulting in a branch to be moved out of scope
-                    // ApacheDS replication provider sends a single delete event on the DN of the moved branch
+                    // ApacheDS replication provider sends a single delete event on the Dn of the moved branch
                     // so the branch needs to be recursively deleted here
                     deleteRecursive( remoteEntry.getDn(), null );
                     break;
@@ -576,7 +576,7 @@ public class SyncReplConsumer implements
         if ( resultCode == ResultCodeEnum.NO_SUCH_OBJECT )
         {
             // log the error and handle it appropriately
-            LOG.warn( "given replication base DN {} is not found on provider", config.getBaseDn() );
+            LOG.warn( "given replication base Dn {} is not found on provider", config.getBaseDn() );
             if ( syncType == SynchronizationModeEnum.REFRESH_AND_PERSIST )
             {
                 LOG.warn( "disconnecting the consumer running in refreshAndPersist mode from the provider" );
@@ -588,7 +588,7 @@ public class SyncReplConsumer implements
             LOG.info( "unable to perform the content synchronization cause E_SYNC_REFRESH_REQUIRED" );
             try
             {
-                deleteRecursive( new DN( config.getBaseDn() ), null );
+                deleteRecursive( new Dn( config.getBaseDn() ), null );
             }
             catch ( Exception e )
             {
@@ -724,7 +724,7 @@ public class SyncReplConsumer implements
                 }
                 catch ( Exception e )
                 {
-                    // can be ignored, most likely happens if there is no entry with the given DN
+                    // can be ignored, most likely happens if there is no entry with the given Dn
                     // log in debug mode
                     LOG.debug( "Failed to read the cookie from the entry", e );
                 }
@@ -763,7 +763,7 @@ public class SyncReplConsumer implements
             }
             catch ( Exception e )
             {
-                LOG.warn( "Failed to delete the cookie from the entry with DN {}", configEntryDn );
+                LOG.warn( "Failed to delete the cookie from the entry with Dn {}", configEntryDn );
                 LOG.warn( "{}", e );
             }
         }
@@ -779,21 +779,21 @@ public class SyncReplConsumer implements
     {
         SyncModifyDnType modDnType = modDnControl.getModDnType();
 
-        DN entryDn = new DN( modDnControl.getEntryDn() );
+        Dn entryDn = new Dn( modDnControl.getEntryDn() );
         switch ( modDnType )
         {
             case MOVE:
 
                 LOG.debug( "moving {} to the new parent {}", entryDn, modDnControl.getNewSuperiorDn() );
 
-                session.move( entryDn, new DN( modDnControl.getNewSuperiorDn() ) );
+                session.move( entryDn, new Dn( modDnControl.getNewSuperiorDn() ) );
                 break;
 
             case RENAME:
 
-                RDN newRdn = new RDN( modDnControl.getNewRdn() );
+                Rdn newRdn = new Rdn( modDnControl.getNewRdn() );
                 boolean deleteOldRdn = modDnControl.isDeleteOldRdn();
-                LOG.debug( "renaming the DN {} with new RDN {} and deleteOldRdn flag set to {}", new String[]
+                LOG.debug( "renaming the Dn {} with new Rdn {} and deleteOldRdn flag set to {}", new String[]
                     { entryDn.getName(), newRdn.getName(), String.valueOf( deleteOldRdn ) } );
 
                 session.rename( entryDn, newRdn, deleteOldRdn );
@@ -801,12 +801,12 @@ public class SyncReplConsumer implements
 
             case MOVEANDRENAME:
 
-                DN newParentDn = new DN( modDnControl.getNewSuperiorDn() );
-                newRdn = new RDN( modDnControl.getNewRdn() );
+                Dn newParentDn = new Dn( modDnControl.getNewSuperiorDn() );
+                newRdn = new Rdn( modDnControl.getNewRdn() );
                 deleteOldRdn = modDnControl.isDeleteOldRdn();
 
                 LOG.debug(
-                    "moveAndRename on the DN {} with new newParent DN {}, new RDN {} and deleteOldRdn flag set to {}",
+                    "moveAndRename on the Dn {} with new newParent Dn {}, new Rdn {} and deleteOldRdn flag set to {}",
                     new String[]
                         { entryDn.getName(), newParentDn.getName(), newRdn.getName(), String.valueOf( deleteOldRdn ) } );
 
@@ -958,7 +958,7 @@ public class SyncReplConsumer implements
             }
         }
 
-        DN dn = new DN( config.getBaseDn(), schemaManager );
+        Dn dn = new Dn( config.getBaseDn(), schemaManager );
 
         LOG.debug( "selecting entries to be deleted using filter {}", filter.toString() );
         EntryFilteringCursor cursor = session.search( dn, SearchScope.SUBTREE, filter,
@@ -1025,14 +1025,14 @@ public class SyncReplConsumer implements
 
 
     /**
-     * removes all child entries present under the given DN and finally the DN itself
+     * removes all child entries present under the given Dn and finally the Dn itself
      *
      * Working:
-     *          This is a recursive function which maintains a Map<DN,Cursor>.
+     *          This is a recursive function which maintains a Map<Dn,Cursor>.
      *          The way the cascade delete works is by checking for children for a
-     *          given DN(i.e opening a search cursor) and if the cursor is empty
-     *          then delete the DN else for each entry's DN present in cursor call
-     *          deleteChildren() with the DN and the reference to the map.
+     *          given Dn(i.e opening a search cursor) and if the cursor is empty
+     *          then delete the Dn else for each entry's Dn present in cursor call
+     *          deleteChildren() with the Dn and the reference to the map.
      *
      *          The reason for opening a search cursor is based on an assumption
      *          that an entry *might* contain children, consider the below DIT fragment
@@ -1048,11 +1048,11 @@ public class SyncReplConsumer implements
      *   In the case of passing a non-null DeleteListener, the return value will always be null, cause the
      *   operation is treated as asynchronous and response result will be sent using the listener callback
      *
-     * @param rootDn the DN which will be removed after removing its children
-     * @param map a map to hold the Cursor related to a DN
-     * @throws Exception If the DN is not valid or if the deletion failed
+     * @param rootDn the Dn which will be removed after removing its children
+     * @param map a map to hold the Cursor related to a Dn
+     * @throws Exception If the Dn is not valid or if the deletion failed
      */
-    private void deleteRecursive( DN rootDn, Map<DN, EntryFilteringCursor> cursorMap ) throws Exception
+    private void deleteRecursive( Dn rootDn, Map<Dn, EntryFilteringCursor> cursorMap ) throws Exception
     {
         LOG.debug( "searching for {}", rootDn.getName() );
         EntryFilteringCursor cursor = null;
@@ -1061,7 +1061,7 @@ public class SyncReplConsumer implements
         {
             if ( cursorMap == null )
             {
-                cursorMap = new HashMap<DN, EntryFilteringCursor>();
+                cursorMap = new HashMap<Dn, EntryFilteringCursor>();
             }
 
             cursor = cursorMap.get( rootDn );
@@ -1075,7 +1075,7 @@ public class SyncReplConsumer implements
                 cursorMap.put( rootDn, cursor );
             }
 
-            if ( !cursor.next() ) // if this is a leaf entry's DN
+            if ( !cursor.next() ) // if this is a leaf entry's Dn
             {
                 LOG.debug( "deleting {}", rootDn.getName() );
                 cursorMap.remove( rootDn );
@@ -1100,7 +1100,7 @@ public class SyncReplConsumer implements
         }
         catch ( Exception e )
         {
-            String msg = "Failed to delete child entries under the DN " + rootDn.getName();
+            String msg = "Failed to delete child entries under the Dn " + rootDn.getName();
             LOG.error( msg, e );
             throw e;
         }

Modified: directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/SyncReplProvider.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/SyncReplProvider.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/SyncReplProvider.java (original)
+++ directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/SyncReplProvider.java Sun Jan 23 01:17:06 2011
@@ -559,7 +559,7 @@ public class SyncReplProvider implements
 
         if ( syncStateType == SyncStateTypeEnum.DELETE )
         {
-            // clear the entry's all attributes except the DN and entryUUID
+            // clear the entry's all attributes except the Dn and entryUUID
             entry.clear();
             entry.add( uuid );
         }

Modified: directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/SyncreplConfiguration.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/SyncreplConfiguration.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/SyncreplConfiguration.java (original)
+++ directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/SyncreplConfiguration.java Sun Jan 23 01:17:06 2011
@@ -46,7 +46,7 @@ public class SyncreplConfiguration
     /** port number of the syncrepl provider server, default is 389 */
     private int port = 389;
 
-    /** replication user's DN */
+    /** replication user's Dn */
     private String replUserDn;
 
     /** password for binding with replication user dn */
@@ -58,7 +58,7 @@ public class SyncreplConfiguration
     /** time interval for successive sync requests, default is 60 seconds */
     private long refreshInterval = 60 * 1000;
 
-    /** the base DN whose content will be searched for replicating */
+    /** the base Dn whose content will be searched for replicating */
     private String baseDn;
 
     /** the ldap filter for fetching the entries, default value is (objectClass=*) */
@@ -156,7 +156,7 @@ public class SyncreplConfiguration
 
 
     /**
-     * @return the replication user's DN
+     * @return the replication user's Dn
      */
     public String getReplUserDn()
     {
@@ -165,7 +165,7 @@ public class SyncreplConfiguration
 
 
     /**
-     * @param replUserdDn the DN of the replication user
+     * @param replUserdDn the Dn of the replication user
      */
     public void setReplUserDn( String replUserdDn )
     {

Modified: directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/DirectoryBackedService.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/DirectoryBackedService.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/DirectoryBackedService.java (original)
+++ directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/DirectoryBackedService.java Sun Jan 23 01:17:06 2011
@@ -60,9 +60,9 @@ public abstract class DirectoryBackedSer
 
 
     /**
-     * Returns the search base DN.
+     * Returns the search base Dn.
      *
-     * @return The search base DN.
+     * @return The search base Dn.
      */
     public String getSearchBaseDn()
     {

Modified: directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/catalog/Catalog.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/catalog/Catalog.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/catalog/Catalog.java (original)
+++ directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/catalog/Catalog.java Sun Jan 23 01:17:06 2011
@@ -22,17 +22,17 @@ package org.apache.directory.server.prot
 
 
 /**
- * The interface for resolving search-base DN's from zone or realm names.
+ * The interface for resolving search-base Dn's from zone or realm names.
  *
  * @author <a href="mailto:dev@directory.apache.org">Apache Directory Project</a>
  */
 public interface Catalog
 {
     /**
-     * Returns the base DN for searches, given a zone or realm name.
+     * Returns the base Dn for searches, given a zone or realm name.
      *
      * @param name
-     * @return The base DN for searches.
+     * @return The base Dn for searches.
      */
     public String getBaseDn( String name );
 }

Modified: directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/catalog/GetCatalog.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/catalog/GetCatalog.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/catalog/GetCatalog.java (original)
+++ directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/catalog/GetCatalog.java Sun Jan 23 01:17:06 2011
@@ -33,7 +33,7 @@ import org.apache.directory.shared.ldap.
 import org.apache.directory.shared.ldap.filter.FilterParser;
 import org.apache.directory.shared.ldap.filter.SearchScope;
 import org.apache.directory.shared.ldap.message.AliasDerefMode;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 
 
 /**
@@ -49,12 +49,12 @@ public class GetCatalog implements Direc
     /**
      * Note that the base is relative to the existing context.
      */
-    public Object execute( CoreSession session, DN base ) throws Exception
+    public Object execute( CoreSession session, Dn base ) throws Exception
     {
         String filter = "(objectClass=" + ApacheSchemaConstants.APACHE_CATALOG_ENTRY_OC + ")";
 
         EntryFilteringCursor list = session.search( 
-            DN.EMPTY_DN, 
+            Dn.EMPTY_DN,
             SearchScope.SUBTREE, 
             FilterParser.parse( session.getDirectoryService().getSchemaManager(), filter ), 
             AliasDerefMode.DEREF_ALWAYS,

Modified: directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/store/DirectoryServiceOperation.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/store/DirectoryServiceOperation.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/store/DirectoryServiceOperation.java (original)
+++ directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/store/DirectoryServiceOperation.java Sun Jan 23 01:17:06 2011
@@ -23,7 +23,7 @@ package org.apache.directory.server.prot
 import java.io.Serializable;
 
 import org.apache.directory.server.core.CoreSession;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 
 
 /**
@@ -37,9 +37,9 @@ public interface DirectoryServiceOperati
      * The command pattern execute method.
      * 
      * @param session The CoreSession to execute the command with
-     * @param baseDn The base DN for working with the context
+     * @param baseDn The base Dn for working with the context
      * @return Object The result returned by the command
      * @throws Exception The exception thrown by the command
      */
-    public Object execute( CoreSession session, DN baseDn ) throws Exception;
+    public Object execute( CoreSession session, Dn baseDn ) throws Exception;
 }

Modified: directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/store/LdifFileLoader.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/store/LdifFileLoader.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/store/LdifFileLoader.java (original)
+++ directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/store/LdifFileLoader.java Sun Jan 23 01:17:06 2011
@@ -35,7 +35,7 @@ import org.apache.directory.shared.ldap.
 import org.apache.directory.shared.ldap.exception.LdapException;
 import org.apache.directory.shared.ldap.ldif.LdifEntry;
 import org.apache.directory.shared.ldap.ldif.LdifReader;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -126,11 +126,11 @@ public class LdifFileLoader
     /**
      * Applies filters making sure failures in one filter do not effect another.
      *
-     * @param dn    the DN of the entry
+     * @param dn    the Dn of the entry
      * @param entry the attributes of the entry
      * @return true if all filters passed the entry, false otherwise
      */
-    private boolean applyFilters( DN dn, Entry entry )
+    private boolean applyFilters( Dn dn, Entry entry )
     {
         boolean accept = true;
         final int limit = filters.size();
@@ -176,7 +176,7 @@ public class LdifFileLoader
 
             for ( LdifEntry ldifEntry:new LdifReader( in ) )
             {
-                DN dn = ldifEntry.getDn();
+                Dn dn = ldifEntry.getDn();
 
                 if ( ldifEntry.isEntry() )
                 {

Modified: directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/store/LdifLoadFilter.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/store/LdifLoadFilter.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/store/LdifLoadFilter.java (original)
+++ directory/apacheds/trunk/protocol-shared/src/main/java/org/apache/directory/server/protocol/shared/store/LdifLoadFilter.java Sun Jan 23 01:17:06 2011
@@ -25,7 +25,7 @@ import java.io.File;
 import org.apache.directory.server.core.CoreSession;
 import org.apache.directory.shared.ldap.entry.Entry;
 import org.apache.directory.shared.ldap.exception.LdapException;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 
 
 /**
@@ -45,5 +45,5 @@ public interface LdifLoadFilter
      * @return true if the entry will be created in the DIT, false if it is to be skipped
      * @throws LdapException
      */
-    boolean filter( File file, DN dn, Entry entry, CoreSession coreSession ) throws LdapException;
+    boolean filter( File file, Dn dn, Entry entry, CoreSession coreSession ) throws LdapException;
 }

Modified: directory/apacheds/trunk/server-annotations/src/test/java/org/apache/directory/server/factory/DirectoryServiceAnnotationTest.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-annotations/src/test/java/org/apache/directory/server/factory/DirectoryServiceAnnotationTest.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-annotations/src/test/java/org/apache/directory/server/factory/DirectoryServiceAnnotationTest.java (original)
+++ directory/apacheds/trunk/server-annotations/src/test/java/org/apache/directory/server/factory/DirectoryServiceAnnotationTest.java Sun Jan 23 01:17:06 2011
@@ -17,9 +17,9 @@
  *   under the License.
  *
  */
-
 package org.apache.directory.server.factory;
 
+
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertTrue;
 
@@ -47,7 +47,7 @@ import org.apache.directory.server.core.
 import org.apache.directory.server.core.partition.Partition;
 import org.apache.directory.server.ldap.LdapServer;
 import org.apache.directory.shared.ldap.message.control.Control;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 import org.apache.directory.shared.ldap.util.JndiUtils;
 import org.apache.mina.util.AvailablePortFinder;
 import org.junit.Test;
@@ -160,7 +160,7 @@ public class DirectoryServiceAnnotationT
             }
         }
         
-        assertTrue( service.getAdminSession().exists( new DN( "dc=example,dc=com" ) ) );
+        assertTrue( service.getAdminSession().exists( new Dn( "dc=example,dc=com" ) ) );
 
         service.shutdown();
         FileUtils.deleteDirectory( service.getInstanceLayout().getInstanceDirectory() );
@@ -227,7 +227,7 @@ public class DirectoryServiceAnnotationT
             }
         }
         
-        assertTrue( service.getAdminSession().exists( new DN( "dc=example,dc=com" ) ) );
+        assertTrue( service.getAdminSession().exists( new Dn( "dc=example,dc=com" ) ) );
 
         // Now, get the server
         LdapServer ldapServer = ServerAnnotationProcessor.createLdapServer( service, AvailablePortFinder

Modified: directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ConfigPartitionReader.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ConfigPartitionReader.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ConfigPartitionReader.java (original)
+++ directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ConfigPartitionReader.java Sun Jan 23 01:17:06 2011
@@ -53,8 +53,8 @@ import org.apache.directory.shared.ldap.
 import org.apache.directory.shared.ldap.filter.EqualityNode;
 import org.apache.directory.shared.ldap.filter.SearchScope;
 import org.apache.directory.shared.ldap.message.AliasDerefMode;
-import org.apache.directory.shared.ldap.name.DN;
-import org.apache.directory.shared.ldap.name.RDN;
+import org.apache.directory.shared.ldap.name.Dn;
+import org.apache.directory.shared.ldap.name.Rdn;
 import org.apache.directory.shared.ldap.schema.AttributeType;
 import org.apache.directory.shared.ldap.schema.ObjectClass;
 import org.apache.directory.shared.ldap.schema.SchemaManager;
@@ -308,17 +308,17 @@ public class ConfigPartitionReader
             {
                 beanField.setBoolean( bean, Boolean.parseBoolean( valueStr ) );
             }
-            else if ( type == DN.class )
+            else if ( type == Dn.class )
             {
                 try
                 {
-                    DN dn = new DN( valueStr );
+                    Dn dn = new Dn( valueStr );
                     beanField.set( bean, dn );
                 }
                 catch ( LdapInvalidDnException lide )
                 {
-                    String message = "The DN '" + valueStr + "' for attribute " + fieldAttr.getId()
-                        + " is not a valid DN";
+                    String message = "The Dn '" + valueStr + "' for attribute " + fieldAttr.getId()
+                        + " is not a valid Dn";
                     LOG.error( message );
                     throw new ConfigurationException( message );
                 }
@@ -378,17 +378,17 @@ public class ConfigPartitionReader
                 {
                     beanField.setBoolean( bean, Boolean.parseBoolean( valueStr ) );
                 }
-                else if ( type == DN.class )
+                else if ( type == Dn.class )
                 {
                     try
                     {
-                        DN dn = new DN( valueStr );
+                        Dn dn = new Dn( valueStr );
                         beanField.set( bean, dn );
                     }
                     catch ( LdapInvalidDnException lide )
                     {
-                        String message = "The DN '" + valueStr + "' for attribute " + fieldAttr.getId()
-                            + " is not a valid DN";
+                        String message = "The Dn '" + valueStr + "' for attribute " + fieldAttr.getId()
+                            + " is not a valid Dn";
                         LOG.error( message );
                         throw new ConfigurationException( message );
                     }
@@ -563,7 +563,7 @@ public class ConfigPartitionReader
                 {
                     // No : we have to loop recursively on all the elements which are
                     // under the ou=<element-name> branch
-                    DN newBase = entry.getDn().add( "ou=" + beanFieldName );
+                    Dn newBase = entry.getDn().add( "ou=" + beanFieldName );
 
                     // We have to remove the 's' at the end of the field name
                     String attributeName = fieldName.substring( 0, fieldName.length() - 1 );
@@ -708,7 +708,7 @@ public class ConfigPartitionReader
     /**
      * Read some configuration element from the DIT using its name 
      */
-    private List<AdsBaseBean> read( DN baseDn, String name, SearchScope scope, boolean mandatory )
+    private List<AdsBaseBean> read( Dn baseDn, String name, SearchScope scope, boolean mandatory )
         throws ConfigurationException
     {
         LOG.debug( "Reading from '{}', entry {}", baseDn, name );
@@ -737,7 +737,7 @@ public class ConfigPartitionReader
                     cursor.close();
 
                     // the requested element is mandatory so let's throw an exception
-                    String message = "No directoryService instance was configured under the DN "
+                    String message = "No directoryService instance was configured under the Dn "
                         + configPartition.getSuffix();
                     LOG.error( message );
                     throw new ConfigurationException( message );
@@ -817,7 +817,7 @@ public class ConfigPartitionReader
     /**
      * Read the configuration from the DIT, returning a bean containing all of it.
      * <p>
-     * This method implicitly uses <em>"ou=config"</em> as base DN
+     * This method implicitly uses <em>"ou=config"</em> as base Dn
      * 
      * @return The Config bean, containing the whole configuration
      * @throws ConfigurationException If we had some issue reading the configuration
@@ -825,32 +825,32 @@ public class ConfigPartitionReader
     public ConfigBean readConfig() throws LdapException
     {
         // The starting point is the DirectoryService element
-        return readConfig( new DN( new RDN( SchemaConstants.OU_AT, "config" ) ) );
+        return readConfig( new Dn( new Rdn( SchemaConstants.OU_AT, "config" ) ) );
     }
 
 
     /**
      * Read the configuration from the DIT, returning a bean containing all of it.
      * 
-     * @param base The base DN in the DIT where the configuration is stored
+     * @param base The base Dn in the DIT where the configuration is stored
      * @return The Config bean, containing the whole configuration
      * @throws ConfigurationException If we had some issue reading the configuration
      */
     public ConfigBean readConfig( String baseDn ) throws LdapException
     {
         // The starting point is the DirectoryService element
-        return readConfig( new DN( baseDn ), ConfigSchemaConstants.ADS_DIRECTORY_SERVICE_OC.getValue() );
+        return readConfig( new Dn( baseDn ), ConfigSchemaConstants.ADS_DIRECTORY_SERVICE_OC.getValue() );
     }
 
 
     /**
      * Read the configuration from the DIT, returning a bean containing all of it.
      * 
-     * @param base The base DN in the DIT where the configuration is stored
+     * @param base The base Dn in the DIT where the configuration is stored
      * @return The Config bean, containing the whole configuration
      * @throws ConfigurationException If we had some issue reading the configuration
      */
-    public ConfigBean readConfig( DN baseDn ) throws ConfigurationException
+    public ConfigBean readConfig( Dn baseDn ) throws ConfigurationException
     {
         // The starting point is the DirectoryService element
         return readConfig( baseDn, ConfigSchemaConstants.ADS_DIRECTORY_SERVICE_OC.getValue() );
@@ -860,26 +860,26 @@ public class ConfigPartitionReader
     /**
      * Read the configuration from the DIT, returning a bean containing all of it.
      * 
-     * @param baseDn The base DN in the DIT where the configuration is stored
+     * @param baseDn The base Dn in the DIT where the configuration is stored
      * @param objectClass The element to read from the DIT
      * @return The bean containing the configuration for the required element
      * @throws ConfigurationException
      */
     public ConfigBean readConfig( String baseDn, String objectClass ) throws LdapException
     {
-        return readConfig( new DN( baseDn ), objectClass );
+        return readConfig( new Dn( baseDn ), objectClass );
     }
 
 
     /**
      * Read the configuration from the DIT, returning a bean containing all of it.
      * 
-     * @param baseDn The base DN in the DIT where the configuration is stored
+     * @param baseDn The base Dn in the DIT where the configuration is stored
      * @param objectClass The element to read from the DIT
      * @return The bean containing the configuration for the required element
      * @throws ConfigurationException
      */
-    public ConfigBean readConfig( DN baseDn, String objectClass ) throws ConfigurationException
+    public ConfigBean readConfig( Dn baseDn, String objectClass ) throws ConfigurationException
     {
         LOG.debug( "Reading configuration for the {} element, from {} ", objectClass, baseDn );
         ConfigBean configBean = new ConfigBean();

Modified: directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ConfigWriter.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ConfigWriter.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ConfigWriter.java (original)
+++ directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ConfigWriter.java Sun Jan 23 01:17:06 2011
@@ -38,8 +38,8 @@ import org.apache.directory.shared.ldap.
 import org.apache.directory.shared.ldap.exception.LdapException;
 import org.apache.directory.shared.ldap.exception.LdapInvalidDnException;
 import org.apache.directory.shared.ldap.ldif.LdifEntry;
-import org.apache.directory.shared.ldap.name.DN;
-import org.apache.directory.shared.ldap.name.RDN;
+import org.apache.directory.shared.ldap.name.Dn;
+import org.apache.directory.shared.ldap.name.Rdn;
 import org.apache.directory.shared.ldap.schema.ObjectClass;
 import org.apache.directory.shared.ldap.schema.SchemaManager;
 
@@ -95,7 +95,7 @@ public class ConfigWriter
 
                 // Building the default config root entry 'ou=config'
                 LdifEntry configRootEntry = new LdifEntry();
-                configRootEntry.setDn( new DN( SchemaConstants.OU_AT + "=" + "config" ) );
+                configRootEntry.setDn( new Dn( SchemaConstants.OU_AT + "=" + "config" ) );
                 addObjectClassAttribute( schemaManager, configRootEntry, "organizationalUnit" );
                 addAttributeTypeValues( SchemaConstants.OU_AT, "config", configRootEntry );
                 entries.add( configRootEntry );
@@ -274,7 +274,7 @@ public class ConfigWriter
      * Adds a configuration bean to the list of entries.
      *
      * @param rootDn
-     *      the current root DN
+     *      the current root Dn
      * @param schemaManager
      *      the schema manager
      * @param bean
@@ -283,7 +283,7 @@ public class ConfigWriter
      *      the list of the entries
      * @throws Exception
      */
-    private void addBean( DN rootDn, SchemaManager schemaManager, AdsBaseBean bean, List<LdifEntry> entries )
+    private void addBean( Dn rootDn, SchemaManager schemaManager, AdsBaseBean bean, List<LdifEntry> entries )
         throws Exception
     {
         addBean( rootDn, schemaManager, bean, entries, null, null );
@@ -294,7 +294,7 @@ public class ConfigWriter
      * Adds a configuration bean to the list of entries.
      *
      * @param rootDn
-     *      the current root DN
+     *      the current root Dn
      * @param schemaManager
      *      the schema manager
      * @param bean
@@ -305,10 +305,10 @@ public class ConfigWriter
      *      the parent entry
      * @param attributeTypeForParentEntry
      *      the attribute type to use when adding the value of 
-     *      the RDN to the parent entry
+     *      the Rdn to the parent entry
      * @throws Exception
      */
-    private void addBean( DN rootDn, SchemaManager schemaManager, AdsBaseBean bean, List<LdifEntry> entries,
+    private void addBean( Dn rootDn, SchemaManager schemaManager, AdsBaseBean bean, List<LdifEntry> entries,
         LdifEntry parentEntry, String attributeTypeForParentEntry )
         throws Exception
     {
@@ -361,7 +361,7 @@ public class ConfigWriter
                             {
                                 // Creating the entry for the container and adding it to the list
                                 LdifEntry containerEntry = new LdifEntry();
-                                containerEntry.setDn( entry.getDn().add( new RDN( SchemaConstants.OU_AT, container ) ) );
+                                containerEntry.setDn( entry.getDn().add( new Rdn( SchemaConstants.OU_AT, container ) ) );
                                 addObjectClassAttribute( schemaManager, containerEntry,
                                     SchemaConstants.ORGANIZATIONAL_UNIT_OC );
                                 addAttributeTypeValues( SchemaConstants.OU_AT, container, containerEntry );
@@ -396,7 +396,7 @@ public class ConfigWriter
                             }
                             else
                             {
-                                // Is it the field value used as RDN and do we need to insert a value in the parent entry?
+                                // Is it the field value used as Rdn and do we need to insert a value in the parent entry?
                                 if ( ( configurationElement.isRdn() ) && ( parentEntry != null )
                                     && ( attributeTypeForParentEntry != null ) )
                                 {
@@ -490,19 +490,19 @@ public class ConfigWriter
 
 
     /**
-     * Gets the DN associated with the configuration bean based on the given base DN.
+     * Gets the Dn associated with the configuration bean based on the given base Dn.
      *
-     * @param baseDN
-     *      the base DN
+     * @param baseDn
+     *      the base Dn
      * @param bean
      *      the configuration bean
      * @return
-     *      the DN associated with the configuration bean based on the given base DN.
+     *      the Dn associated with the configuration bean based on the given base Dn.
      * @throws LdapInvalidDnException
      * @throws IllegalArgumentException
      * @throws IllegalAccessException
      */
-    private DN getDn( DN baseDN, AdsBaseBean bean ) throws LdapInvalidDnException, IllegalArgumentException,
+    private Dn getDn( Dn baseDn, AdsBaseBean bean ) throws LdapInvalidDnException, IllegalArgumentException,
         IllegalAccessException
     {
         // Getting the class of the bean
@@ -529,11 +529,11 @@ public class ConfigWriter
                 field.setAccessible( true );
 
                 // Looking for the @ConfigurationElement annotation and
-                // if the field is the RDN
+                // if the field is the Rdn
                 ConfigurationElement configurationElement = field.getAnnotation( ConfigurationElement.class );
                 if ( ( configurationElement != null ) && ( configurationElement.isRdn() ) )
                 {
-                    return baseDN.add( new RDN( configurationElement.attributeType(), field.get( bean ).toString() ) );
+                    return baseDn.add( new Rdn( configurationElement.attributeType(), field.get( bean ).toString() ) );
                 }
             }
 
@@ -541,7 +541,7 @@ public class ConfigWriter
             beanClass = beanClass.getSuperclass();
         }
 
-        return DN.EMPTY_DN; // TODO Throw an error when we reach that point
+        return Dn.EMPTY_DN; // TODO Throw an error when we reach that point
     }
 
 

Modified: directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ConfigurationElement.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ConfigurationElement.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ConfigurationElement.java (original)
+++ directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ConfigurationElement.java Sun Jan 23 01:17:06 2011
@@ -50,21 +50,21 @@ public @interface ConfigurationElement
 
     /**
      * Returns true if of the qualified field (attribute type and value) 
-     * is the RDN of the entry.
+     * is the Rdn of the entry.
      *
      * @return
      *      <code>true</code> if of the qualified field (attribute type and value) 
-     * is the RDN of the entry,
+     * is the Rdn of the entry,
      *      <code>false</code> if not.
      */
     boolean isRdn() default false;
 
 
     /**
-     * Returns the string value of the DN of the container.
+     * Returns the string value of the Dn of the container.
      *
      * @return
-     *      the string value of the DN of the container.
+     *      the string value of the Dn of the container.
      */
     String container() default "";
 

Modified: directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ReadOnlyConfigurationPartition.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ReadOnlyConfigurationPartition.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ReadOnlyConfigurationPartition.java (original)
+++ directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/ReadOnlyConfigurationPartition.java Sun Jan 23 01:17:06 2011
@@ -41,7 +41,7 @@ import org.apache.directory.shared.ldap.
 import org.apache.directory.shared.ldap.exception.LdapException;
 import org.apache.directory.shared.ldap.ldif.LdifEntry;
 import org.apache.directory.shared.ldap.ldif.LdifReader;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 import org.apache.directory.shared.ldap.schema.SchemaManager;
 
 
@@ -79,7 +79,7 @@ public class ReadOnlyConfigurationPartit
         // Initializing the wrapped partition
         setWrappedPartition( new AvlPartition() );
         setId( "config" );
-        setSuffix( new DN( "ou=config" ) );
+        setSuffix( new Dn( "ou=config" ) );
         wrappedPartition.setSchemaManager( schemaManager );
         wrappedPartition.initialize();
 

Modified: directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/AdsBaseBean.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/AdsBaseBean.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/AdsBaseBean.java (original)
+++ directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/AdsBaseBean.java Sun Jan 23 01:17:06 2011
@@ -21,7 +21,7 @@ package org.apache.directory.server.conf
 
 
 import org.apache.directory.server.config.ConfigurationElement;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 import org.apache.directory.shared.util.Strings;
 
 
@@ -129,9 +129,9 @@ public abstract class AdsBaseBean
 
 
     /**
-     * Formated print of a DN that can be null
+     * Formated print of a Dn that can be null
      */
-    protected String toString( String tabs, String name, DN value )
+    protected String toString( String tabs, String name, Dn value )
     {
         if ( value != null )
         {

Modified: directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/DSBasedServerBean.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/DSBasedServerBean.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/DSBasedServerBean.java (original)
+++ directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/DSBasedServerBean.java Sun Jan 23 01:17:06 2011
@@ -21,7 +21,7 @@ package org.apache.directory.server.conf
 
 
 import org.apache.directory.server.config.ConfigurationElement;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 
 
 /**
@@ -37,8 +37,8 @@ public class DSBasedServerBean extends S
      * configuration for catalog entries.  Otherwise it will use this
      * search base as a single point of searching the DIT.
      */
-    @ConfigurationElement(attributeType = "ads-searchBaseDN")
-    private DN searchBaseDN;
+    @ConfigurationElement(attributeType = "ads-searchBaseDn")
+    private Dn searchBaseDn;
 
 
     /**
@@ -50,22 +50,22 @@ public class DSBasedServerBean extends S
 
 
     /**
-     * Returns the search base DN.
+     * Returns the search base Dn.
      *
-     * @return The search base DN.
+     * @return The search base Dn.
      */
-    public DN getSearchBaseDn()
+    public Dn getSearchBaseDn()
     {
-        return searchBaseDN;
+        return searchBaseDn;
     }
 
 
     /**
      * @param searchBaseDn The searchBaseDn to set.
      */
-    public void setSearchBaseDn( DN searchBaseDn )
+    public void setSearchBaseDn( Dn searchBaseDn )
     {
-        this.searchBaseDN = searchBaseDn;
+        this.searchBaseDn = searchBaseDn;
     }
 
 
@@ -77,7 +77,7 @@ public class DSBasedServerBean extends S
         StringBuilder sb = new StringBuilder();
 
         sb.append( super.toString( tabs ) );
-        sb.append( toString( tabs, "searchBaseDN", searchBaseDN ) );
+        sb.append( toString( tabs, "searchBaseDn", searchBaseDn) );
 
         return sb.toString();
     }

Modified: directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/DirectoryServiceBean.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/DirectoryServiceBean.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/DirectoryServiceBean.java (original)
+++ directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/DirectoryServiceBean.java Sun Jan 23 01:17:06 2011
@@ -49,7 +49,7 @@ public class DirectoryServiceBean extend
     @ConfigurationElement(attributeType = "ads-dsAllowAnonymousAccess")
     private boolean dsAllowAnonymousAccess = false;
 
-    /** The flag that tells if DN must be denormalized */
+    /** The flag that tells if Dn must be denormalized */
     @ConfigurationElement(attributeType = "ads-dsDenormalizeOpAttrsEnabled")
     private boolean dsDenormalizeOpAttrsEnabled = true;
 

Modified: directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/PartitionBean.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/PartitionBean.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/PartitionBean.java (original)
+++ directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/PartitionBean.java Sun Jan 23 01:17:06 2011
@@ -24,7 +24,7 @@ import java.util.ArrayList;
 import java.util.List;
 
 import org.apache.directory.server.config.ConfigurationElement;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 
 
 /**
@@ -40,7 +40,7 @@ public abstract class PartitionBean exte
 
     /** The Partition suffix */
     @ConfigurationElement(attributeType = "ads-partitionSuffix")
-    private DN partitionSuffix;
+    private Dn partitionSuffix;
 
     /** Tells if the data should be flushed to disk immediately */
     @ConfigurationElement(attributeType = "ads-partitionSyncOnWrite")
@@ -84,7 +84,7 @@ public abstract class PartitionBean exte
     /**
      * @return the partitionSuffix
      */
-    public DN getPartitionSuffix()
+    public Dn getPartitionSuffix()
     {
         return partitionSuffix;
     }
@@ -93,7 +93,7 @@ public abstract class PartitionBean exte
     /**
      * @param partitionSuffix the partitionSuffix to set
      */
-    public void setPartitionSuffix( DN partitionSuffix )
+    public void setPartitionSuffix( Dn partitionSuffix )
     {
         this.partitionSuffix = partitionSuffix;
     }

Modified: directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/ReplConsumerBean.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/ReplConsumerBean.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/ReplConsumerBean.java (original)
+++ directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/ReplConsumerBean.java Sun Jan 23 01:17:06 2011
@@ -21,7 +21,7 @@ package org.apache.directory.server.conf
 
 
 import org.apache.directory.server.config.ConfigurationElement;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 
 
 /**
@@ -43,9 +43,9 @@ public class ReplConsumerBean extends Ad
     @ConfigurationElement(attributeType = "ads-replAliasDerefMode")
     private String replAliasDerefMode;
 
-    /** The Search Base DN */
-    @ConfigurationElement(attributeType = "ads-searchBaseDN")
-    private DN searchBaseDN;
+    /** The Search Base Dn */
+    @ConfigurationElement(attributeType = "ads-searchBaseDn")
+    private Dn searchBaseDn;
 
     /** The last CSN sent */
     @ConfigurationElement(attributeType = "ads-replLastSentCsn")
@@ -143,20 +143,20 @@ public class ReplConsumerBean extends Ad
 
 
     /**
-     * @return the searchBaseDN
+     * @return the searchBaseDn
      */
-    public DN getSearchBaseDN()
+    public Dn getSearchBaseDn()
     {
-        return searchBaseDN;
+        return searchBaseDn;
     }
 
 
     /**
-     * @param searchBaseDN the searchBaseDN to set
+     * @param searchBaseDn the searchBaseDn to set
      */
-    public void setSearchBaseDN( DN searchBaseDN )
+    public void setSearchBaseDn(Dn searchBaseDn)
     {
-        this.searchBaseDN = searchBaseDN;
+        this.searchBaseDn = searchBaseDn;
     }
 
 
@@ -299,7 +299,7 @@ public class ReplConsumerBean extends Ad
         sb.append( tabs ).append( "  consumer ID : " ).append( replConsumerId ).append( '\n' );
         sb.append( tabs ).append( "  replica ID : " ).append( dsReplicaId ).append( '\n' );
         sb.append( tabs ).append( "  last sent CSN : " ).append( replLastSentCsn ).append( '\n' );
-        sb.append( tabs ).append( "  search base DN : " ).append( searchBaseDN.getName() ).append( '\n' );
+        sb.append( tabs ).append( "  search base Dn : " ).append( searchBaseDn.getName() ).append( '\n' );
         sb.append( tabs ).append( "  search filter : " ).append( replSearchFilter ).append( '\n' );
         sb.append( tabs ).append( "  search scope : " ).append( replSearchScope ).append( '\n' );
         sb.append( tabs ).append( "  alias dereferencing mode : " ).append( replAliasDerefMode ).append( '\n' );

Modified: directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/ReplProviderBean.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/ReplProviderBean.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/ReplProviderBean.java (original)
+++ directory/apacheds/trunk/server-config/src/main/java/org/apache/directory/server/config/beans/ReplProviderBean.java Sun Jan 23 01:17:06 2011
@@ -21,7 +21,7 @@ package org.apache.directory.server.conf
 
 
 import org.apache.directory.server.config.ConfigurationElement;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 
 
 /**
@@ -39,9 +39,9 @@ public class ReplProviderBean extends Ad
     @ConfigurationElement(attributeType = "ads-dsReplicaId")
     private String dsReplicaId;
 
-    /** The Search Base DN */
-    @ConfigurationElement(attributeType = "ads-searchBaseDN")
-    private DN searchBaseDN;
+    /** The Search Base Dn */
+    @ConfigurationElement(attributeType = "ads-searchBaseDn")
+    private Dn searchBaseDn;
 
     /** The replication provider host name */
     @ConfigurationElement(attributeType = "ads-replProvHostName")
@@ -83,9 +83,9 @@ public class ReplProviderBean extends Ad
     @ConfigurationElement(attributeType = "ads-replSearchTimeout")
     private int replSearchTimeout;
 
-    /** The replication user DN */
-    @ConfigurationElement(attributeType = "ads-replUserDN")
-    private DN replUserDN;
+    /** The replication user Dn */
+    @ConfigurationElement(attributeType = "ads-replUserDn")
+    private Dn replUserDn;
 
     /** The replication user password */
     @ConfigurationElement(attributeType = "ads-replUserPassword")
@@ -147,18 +147,18 @@ public class ReplProviderBean extends Ad
     /**
      * @return the searchBaseDn
      */
-    public DN getSearchBaseDn()
+    public Dn getSearchBaseDn()
     {
-        return searchBaseDN;
+        return searchBaseDn;
     }
 
 
     /**
      * @param searchBaseDN the searchBaseDn to set
      */
-    public void setSearchBaseDn( DN searchBaseDn )
+    public void setSearchBaseDn( Dn searchBaseDn )
     {
-        this.searchBaseDN = searchBaseDn;
+        this.searchBaseDn = searchBaseDn;
     }
 
 
@@ -345,18 +345,18 @@ public class ReplProviderBean extends Ad
     /**
      * @return the replUserDn
      */
-    public DN isReplUserDn()
+    public Dn isReplUserDn()
     {
-        return replUserDN;
+        return replUserDn;
     }
 
 
     /**
      * @param replUserDn the replUserDn to set
      */
-    public void setReplUserDn( DN replUserDn )
+    public void setReplUserDn( Dn replUserDn )
     {
-        this.replUserDN = replUserDn;
+        this.replUserDn = replUserDn;
     }
 
 
@@ -408,7 +408,7 @@ public class ReplProviderBean extends Ad
 
         sb.append( tabs ).append( "  provider ID : " ).append( replProviderId ).append( '\n' );
         sb.append( tabs ).append( "  replica ID : " ).append( dsReplicaId ).append( '\n' );
-        sb.append( tabs ).append( "  search base DN : " ).append( searchBaseDN.getName() ).append( '\n' );
+        sb.append( tabs ).append( "  search base Dn : " ).append( searchBaseDn.getName() ).append( '\n' );
         sb.append( tabs ).append( "  provider host name : " ).append( replProvHostName ).append( '\n' );
         sb.append( tabs ).append( "  provider port : " ).append( replProvPort ).append( '\n' );
         sb.append( toString( tabs, "  alias dereferencing mode", replAliasDerefMode ) );
@@ -419,7 +419,7 @@ public class ReplProviderBean extends Ad
         sb.append( toString( tabs, "  search filter", replSearchFilter ) );
         sb.append( tabs ).append( "  search size limit : " ).append( replSearchSizeLimit ).append( '\n' );
         sb.append( tabs ).append( "  search time limit : " ).append( replSearchTimeout ).append( '\n' );
-        sb.append( toString( tabs, "  user DN", replUserDN ) );
+        sb.append( toString( tabs, "  user Dn", replUserDn) );
         sb.append( toString( tabs, "  user password", replUserPassword ) );
         sb.append( toString( tabs, "  cookie", replCookie ) );
 

Modified: directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/ChangePasswordConfigReaderTest.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/ChangePasswordConfigReaderTest.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/ChangePasswordConfigReaderTest.java (original)
+++ directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/ChangePasswordConfigReaderTest.java Sun Jan 23 01:17:06 2011
@@ -32,7 +32,7 @@ import org.apache.directory.junit.tools.
 import org.apache.directory.server.config.beans.ChangePasswordServerBean;
 import org.apache.directory.server.config.beans.ConfigBean;
 import org.apache.directory.server.core.partition.ldif.SingleFileLdifPartition;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 import org.apache.directory.shared.ldap.schema.SchemaManager;
 import org.apache.directory.shared.ldap.schema.registries.SchemaLoader;
 import org.apache.directory.shared.ldap.schemaextractor.SchemaLdifExtractor;
@@ -84,7 +84,7 @@ public class ChangePasswordConfigReaderT
 
         // We have to load the schema now, otherwise we won't be able
         // to initialize the Partitions, as we won't be able to parse 
-        // and normalize their suffix DN
+        // and normalize their suffix Dn
         schemaManager.loadAllEnabled();
 
         List<Throwable> errors = schemaManager.getErrors();
@@ -112,13 +112,13 @@ public class ChangePasswordConfigReaderT
         SingleFileLdifPartition configPartition = new SingleFileLdifPartition();
         configPartition.setId( "config" );
         configPartition.setPartitionPath( new File( configFile ).toURI() );
-        configPartition.setSuffix( new DN( "ou=config" ) );
+        configPartition.setSuffix( new Dn( "ou=config" ) );
         configPartition.setSchemaManager( schemaManager );
         
         configPartition.initialize();
         ConfigPartitionReader cpReader = new ConfigPartitionReader( configPartition );
         
-        ConfigBean configBean = cpReader.readConfig( new DN( "ou=servers,ads-directoryServiceId=default,ou=config" ), ConfigSchemaConstants.ADS_CHANGE_PASSWORD_SERVER_OC.getValue() );
+        ConfigBean configBean = cpReader.readConfig( new Dn( "ou=servers,ads-directoryServiceId=default,ou=config" ), ConfigSchemaConstants.ADS_CHANGE_PASSWORD_SERVER_OC.getValue() );
 
         assertNotNull( configBean );
         ChangePasswordServerBean changePasswordServerBean = (ChangePasswordServerBean)configBean.getDirectoryServiceBeans().get( 0 );

Modified: directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/ConfigPartitionReaderTest.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/ConfigPartitionReaderTest.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/ConfigPartitionReaderTest.java (original)
+++ directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/ConfigPartitionReaderTest.java Sun Jan 23 01:17:06 2011
@@ -32,7 +32,7 @@ import org.apache.directory.junit.tools.
 import org.apache.directory.server.config.beans.ConfigBean;
 import org.apache.directory.server.config.beans.DirectoryServiceBean;
 import org.apache.directory.server.core.partition.ldif.SingleFileLdifPartition;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 import org.apache.directory.shared.ldap.schema.SchemaManager;
 import org.apache.directory.shared.ldap.schema.registries.SchemaLoader;
 import org.apache.directory.shared.ldap.schemaextractor.SchemaLdifExtractor;
@@ -83,7 +83,7 @@ public class ConfigPartitionReaderTest
 
         // We have to load the schema now, otherwise we won't be able
         // to initialize the Partitions, as we won't be able to parse 
-        // and normalize their suffix DN
+        // and normalize their suffix Dn
         schemaManager.loadAllEnabled();
 
         List<Throwable> errors = schemaManager.getErrors();
@@ -106,7 +106,7 @@ public class ConfigPartitionReaderTest
         SingleFileLdifPartition configPartition = new SingleFileLdifPartition();
         configPartition.setId( "config" );
         configPartition.setPartitionPath( new File( configFile ).toURI() );
-        configPartition.setSuffix( new DN( "ou=config" ) );
+        configPartition.setSuffix( new Dn( "ou=config" ) );
         configPartition.setSchemaManager( schemaManager );
 
         configPartition.initialize();

Modified: directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/ConfigWriterTest.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/ConfigWriterTest.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/ConfigWriterTest.java (original)
+++ directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/ConfigWriterTest.java Sun Jan 23 01:17:06 2011
@@ -39,7 +39,7 @@ import org.apache.directory.server.core.
 import org.apache.directory.shared.ldap.entry.Entry;
 import org.apache.directory.shared.ldap.ldif.LdifEntry;
 import org.apache.directory.shared.ldap.ldif.LdifReader;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 import org.apache.directory.shared.ldap.schema.SchemaManager;
 import org.apache.directory.shared.ldap.schema.registries.SchemaLoader;
 import org.apache.directory.shared.ldap.schemaextractor.SchemaLdifExtractor;
@@ -89,7 +89,7 @@ public class ConfigWriterTest
 
         // We have to load the schema now, otherwise we won't be able
         // to initialize the Partitions, as we won't be able to parse 
-        // and normalize their suffix DN
+        // and normalize their suffix Dn
         schemaManager.loadAllEnabled();
 
         List<Throwable> errors = schemaManager.getErrors();
@@ -112,7 +112,7 @@ public class ConfigWriterTest
         SingleFileLdifPartition configPartition = new SingleFileLdifPartition();
         configPartition.setId( "config" );
         configPartition.setPartitionPath( new File( configFile ).toURI() );
-        configPartition.setSuffix( new DN( "ou=config" ) );
+        configPartition.setSuffix( new Dn( "ou=config" ) );
         configPartition.setSchemaManager( schemaManager );
         configPartition.initialize();
 

Modified: directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/DhcpServerConfigReaderTest.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/DhcpServerConfigReaderTest.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/DhcpServerConfigReaderTest.java (original)
+++ directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/DhcpServerConfigReaderTest.java Sun Jan 23 01:17:06 2011
@@ -32,7 +32,7 @@ import org.apache.directory.junit.tools.
 import org.apache.directory.server.config.beans.ConfigBean;
 import org.apache.directory.server.config.beans.DhcpServerBean;
 import org.apache.directory.server.core.partition.ldif.SingleFileLdifPartition;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 import org.apache.directory.shared.ldap.schema.SchemaManager;
 import org.apache.directory.shared.ldap.schema.registries.SchemaLoader;
 import org.apache.directory.shared.ldap.schemaextractor.SchemaLdifExtractor;
@@ -84,7 +84,7 @@ public class DhcpServerConfigReaderTest
 
         // We have to load the schema now, otherwise we won't be able
         // to initialize the Partitions, as we won't be able to parse 
-        // and normalize their suffix DN
+        // and normalize their suffix Dn
         schemaManager.loadAllEnabled();
 
         List<Throwable> errors = schemaManager.getErrors();
@@ -105,13 +105,13 @@ public class DhcpServerConfigReaderTest
         SingleFileLdifPartition configPartition = new SingleFileLdifPartition();
         configPartition.setId( "config" );
         configPartition.setPartitionPath( new File( configFile ).toURI() );
-        configPartition.setSuffix( new DN( "ou=config" ) );
+        configPartition.setSuffix( new Dn( "ou=config" ) );
         configPartition.setSchemaManager( schemaManager );
         
         configPartition.initialize();
         ConfigPartitionReader cpReader = new ConfigPartitionReader( configPartition );
         
-        ConfigBean configBean = cpReader.readConfig( new DN( "ou=servers,ads-directoryServiceId=default,ou=config" ), ConfigSchemaConstants.ADS_DHCP_SERVER_OC.getValue() );
+        ConfigBean configBean = cpReader.readConfig( new Dn( "ou=servers,ads-directoryServiceId=default,ou=config" ), ConfigSchemaConstants.ADS_DHCP_SERVER_OC.getValue() );
 
         assertNotNull( configBean );
         DhcpServerBean dhcpServerBean = (DhcpServerBean)configBean.getDirectoryServiceBeans().get( 0 );

Modified: directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/DnsServerConfigReaderTest.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/DnsServerConfigReaderTest.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/DnsServerConfigReaderTest.java (original)
+++ directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/DnsServerConfigReaderTest.java Sun Jan 23 01:17:06 2011
@@ -32,7 +32,7 @@ import org.apache.directory.junit.tools.
 import org.apache.directory.server.config.beans.ConfigBean;
 import org.apache.directory.server.config.beans.DnsServerBean;
 import org.apache.directory.server.core.partition.ldif.SingleFileLdifPartition;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 import org.apache.directory.shared.ldap.schema.SchemaManager;
 import org.apache.directory.shared.ldap.schema.registries.SchemaLoader;
 import org.apache.directory.shared.ldap.schemaextractor.SchemaLdifExtractor;
@@ -82,7 +82,7 @@ public class DnsServerConfigReaderTest
 
         // We have to load the schema now, otherwise we won't be able
         // to initialize the Partitions, as we won't be able to parse 
-        // and normalize their suffix DN
+        // and normalize their suffix Dn
         schemaManager.loadAllEnabled();
 
         List<Throwable> errors = schemaManager.getErrors();
@@ -103,13 +103,13 @@ public class DnsServerConfigReaderTest
         SingleFileLdifPartition configPartition = new SingleFileLdifPartition();
         configPartition.setId( "config" );
         configPartition.setPartitionPath( new File( configFile ).toURI() );
-        configPartition.setSuffix( new DN( "ou=config" ) );
+        configPartition.setSuffix( new Dn( "ou=config" ) );
         configPartition.setSchemaManager( schemaManager );
         
         configPartition.initialize();
         ConfigPartitionReader cpReader = new ConfigPartitionReader( configPartition );
         
-        ConfigBean configBean = cpReader.readConfig( new DN( "ou=servers,ads-directoryServiceId=default,ou=config" ), ConfigSchemaConstants.ADS_DNS_SERVER_OC.getValue() );
+        ConfigBean configBean = cpReader.readConfig( new Dn( "ou=servers,ads-directoryServiceId=default,ou=config" ), ConfigSchemaConstants.ADS_DNS_SERVER_OC.getValue() );
 
         assertNotNull( configBean );
         DnsServerBean dnsServerBean = (DnsServerBean)configBean.getDirectoryServiceBeans().get( 0 );

Modified: directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/HttpServerConfigReaderTest.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/HttpServerConfigReaderTest.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/HttpServerConfigReaderTest.java (original)
+++ directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/HttpServerConfigReaderTest.java Sun Jan 23 01:17:06 2011
@@ -32,7 +32,7 @@ import org.apache.directory.junit.tools.
 import org.apache.directory.server.config.beans.ConfigBean;
 import org.apache.directory.server.config.beans.HttpServerBean;
 import org.apache.directory.server.core.partition.ldif.SingleFileLdifPartition;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 import org.apache.directory.shared.ldap.schema.SchemaManager;
 import org.apache.directory.shared.ldap.schema.registries.SchemaLoader;
 import org.apache.directory.shared.ldap.schemaextractor.SchemaLdifExtractor;
@@ -82,7 +82,7 @@ public class HttpServerConfigReaderTest
 
         // We have to load the schema now, otherwise we won't be able
         // to initialize the Partitions, as we won't be able to parse 
-        // and normalize their suffix DN
+        // and normalize their suffix Dn
         schemaManager.loadAllEnabled();
 
         List<Throwable> errors = schemaManager.getErrors();
@@ -103,13 +103,13 @@ public class HttpServerConfigReaderTest
         SingleFileLdifPartition configPartition = new SingleFileLdifPartition();
         configPartition.setId( "config" );
         configPartition.setPartitionPath( new File( configFile ).toURI() );
-        configPartition.setSuffix( new DN( "ou=config" ) );
+        configPartition.setSuffix( new Dn( "ou=config" ) );
         configPartition.setSchemaManager( schemaManager );
         
         configPartition.initialize();
         ConfigPartitionReader cpReader = new ConfigPartitionReader( configPartition );
         
-        ConfigBean configBean = cpReader.readConfig( new DN( "ou=servers,ads-directoryServiceId=default,ou=config" ), ConfigSchemaConstants.ADS_HTTP_SERVER_OC.getValue() );
+        ConfigBean configBean = cpReader.readConfig( new Dn( "ou=servers,ads-directoryServiceId=default,ou=config" ), ConfigSchemaConstants.ADS_HTTP_SERVER_OC.getValue() );
 
         assertNotNull( configBean );
         HttpServerBean httpServerBean = (HttpServerBean)configBean.getDirectoryServiceBeans().get( 0 );

Modified: directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/KerberosServerConfigReaderTest.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/KerberosServerConfigReaderTest.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/KerberosServerConfigReaderTest.java (original)
+++ directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/KerberosServerConfigReaderTest.java Sun Jan 23 01:17:06 2011
@@ -32,7 +32,7 @@ import org.apache.directory.junit.tools.
 import org.apache.directory.server.config.beans.ConfigBean;
 import org.apache.directory.server.config.beans.KdcServerBean;
 import org.apache.directory.server.core.partition.ldif.SingleFileLdifPartition;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 import org.apache.directory.shared.ldap.schema.SchemaManager;
 import org.apache.directory.shared.ldap.schema.registries.SchemaLoader;
 import org.apache.directory.shared.ldap.schemaextractor.SchemaLdifExtractor;
@@ -83,7 +83,7 @@ public class KerberosServerConfigReaderT
 
         // We have to load the schema now, otherwise we won't be able
         // to initialize the Partitions, as we won't be able to parse 
-        // and normalize their suffix DN
+        // and normalize their suffix Dn
         schemaManager.loadAllEnabled();
 
         List<Throwable> errors = schemaManager.getErrors();
@@ -104,13 +104,13 @@ public class KerberosServerConfigReaderT
         SingleFileLdifPartition configPartition = new SingleFileLdifPartition();
         configPartition.setId( "config" );
         configPartition.setPartitionPath( new File( configFile ).toURI() );
-        configPartition.setSuffix( new DN( "ou=config" ) );
+        configPartition.setSuffix( new Dn( "ou=config" ) );
         configPartition.setSchemaManager( schemaManager );
         
         configPartition.initialize();
         ConfigPartitionReader cpReader = new ConfigPartitionReader( configPartition );
         
-        ConfigBean configBean = cpReader.readConfig( new DN( "ou=servers,ads-directoryServiceId=default,ou=config" ), ConfigSchemaConstants.ADS_KERBEROS_SERVER_OC.getValue() );
+        ConfigBean configBean = cpReader.readConfig( new Dn( "ou=servers,ads-directoryServiceId=default,ou=config" ), ConfigSchemaConstants.ADS_KERBEROS_SERVER_OC.getValue() );
 
         assertNotNull( configBean );
         KdcServerBean kdcServerBean = (KdcServerBean)configBean.getDirectoryServiceBeans().get( 0 );

Modified: directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/LdapServerConfigReaderTest.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/LdapServerConfigReaderTest.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/LdapServerConfigReaderTest.java (original)
+++ directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/LdapServerConfigReaderTest.java Sun Jan 23 01:17:06 2011
@@ -32,7 +32,7 @@ import org.apache.directory.junit.tools.
 import org.apache.directory.server.config.beans.ConfigBean;
 import org.apache.directory.server.config.beans.LdapServerBean;
 import org.apache.directory.server.core.partition.ldif.SingleFileLdifPartition;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 import org.apache.directory.shared.ldap.schema.SchemaManager;
 import org.apache.directory.shared.ldap.schema.registries.SchemaLoader;
 import org.apache.directory.shared.ldap.schemaextractor.SchemaLdifExtractor;
@@ -83,7 +83,7 @@ public class LdapServerConfigReaderTest
 
         // We have to load the schema now, otherwise we won't be able
         // to initialize the Partitions, as we won't be able to parse 
-        // and normalize their suffix DN
+        // and normalize their suffix Dn
         schemaManager.loadAllEnabled();
 
         List<Throwable> errors = schemaManager.getErrors();
@@ -104,13 +104,13 @@ public class LdapServerConfigReaderTest
         SingleFileLdifPartition configPartition = new SingleFileLdifPartition();
         configPartition.setId( "config" );
         configPartition.setPartitionPath( new File( configFile ).toURI() );
-        configPartition.setSuffix( new DN( "ou=config" ) );
+        configPartition.setSuffix( new Dn( "ou=config" ) );
         configPartition.setSchemaManager( schemaManager );
         
         configPartition.initialize();
         ConfigPartitionReader cpReader = new ConfigPartitionReader( configPartition );
         
-        ConfigBean configBean = cpReader.readConfig( new DN( "ou=servers,ads-directoryServiceId=default,ou=config" ), ConfigSchemaConstants.ADS_LDAP_SERVER_OC.getValue() );
+        ConfigBean configBean = cpReader.readConfig( new Dn( "ou=servers,ads-directoryServiceId=default,ou=config" ), ConfigSchemaConstants.ADS_LDAP_SERVER_OC.getValue() );
 
         assertNotNull( configBean );
         LdapServerBean ldapServerBean = (LdapServerBean)configBean.getDirectoryServiceBeans().get( 0 );

Modified: directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/NtpServerConfigReaderTest.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/NtpServerConfigReaderTest.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/NtpServerConfigReaderTest.java (original)
+++ directory/apacheds/trunk/server-config/src/test/java/org/apache/directory/server/config/NtpServerConfigReaderTest.java Sun Jan 23 01:17:06 2011
@@ -32,7 +32,7 @@ import org.apache.directory.junit.tools.
 import org.apache.directory.server.config.beans.ConfigBean;
 import org.apache.directory.server.config.beans.NtpServerBean;
 import org.apache.directory.server.core.partition.ldif.SingleFileLdifPartition;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 import org.apache.directory.shared.ldap.schema.SchemaManager;
 import org.apache.directory.shared.ldap.schema.registries.SchemaLoader;
 import org.apache.directory.shared.ldap.schemaextractor.SchemaLdifExtractor;
@@ -82,7 +82,7 @@ public class NtpServerConfigReaderTest
 
         // We have to load the schema now, otherwise we won't be able
         // to initialize the Partitions, as we won't be able to parse 
-        // and normalize their suffix DN
+        // and normalize their suffix Dn
         schemaManager.loadAllEnabled();
 
         List<Throwable> errors = schemaManager.getErrors();
@@ -103,13 +103,13 @@ public class NtpServerConfigReaderTest
         SingleFileLdifPartition configPartition = new SingleFileLdifPartition();
         configPartition.setId( "config" );
         configPartition.setPartitionPath( new File( configFile ).toURI() );
-        configPartition.setSuffix( new DN( "ou=config" ) );
+        configPartition.setSuffix( new Dn( "ou=config" ) );
         configPartition.setSchemaManager( schemaManager );
         
         configPartition.initialize();
         ConfigPartitionReader cpReader = new ConfigPartitionReader( configPartition );
         
-        ConfigBean configBean = cpReader.readConfig( new DN( "ou=servers,ads-directoryServiceId=default,ou=config" ), ConfigSchemaConstants.ADS_NTP_SERVER_OC.getValue() );
+        ConfigBean configBean = cpReader.readConfig( new Dn( "ou=servers,ads-directoryServiceId=default,ou=config" ), ConfigSchemaConstants.ADS_NTP_SERVER_OC.getValue() );
 
         assertNotNull( configBean );
         NtpServerBean ntpServerBean = (NtpServerBean)configBean.getDirectoryServiceBeans().get( 0 );

Modified: directory/apacheds/trunk/server-integ/src/test/java/org/apache/directory/server/admin/AdministrativePointPersistentIT.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/server-integ/src/test/java/org/apache/directory/server/admin/AdministrativePointPersistentIT.java?rev=1062306&r1=1062305&r2=1062306&view=diff
==============================================================================
--- directory/apacheds/trunk/server-integ/src/test/java/org/apache/directory/server/admin/AdministrativePointPersistentIT.java (original)
+++ directory/apacheds/trunk/server-integ/src/test/java/org/apache/directory/server/admin/AdministrativePointPersistentIT.java Sun Jan 23 01:17:06 2011
@@ -39,7 +39,7 @@ import org.apache.directory.server.core.
 import org.apache.directory.server.core.integ.IntegrationUtils;
 import org.apache.directory.shared.ldap.entry.Entry;
 import org.apache.directory.shared.ldap.entry.EntryAttribute;
-import org.apache.directory.shared.ldap.name.DN;
+import org.apache.directory.shared.ldap.name.Dn;
 import org.apache.directory.shared.ldap.schema.SchemaManager;
 import org.apache.directory.shared.ldap.util.tree.DnNode;
 import org.junit.After;
@@ -199,46 +199,46 @@ public class AdministrativePointPersiste
         DnNode<SubschemaAdministrativePoint> ssCache = ldapServer.getDirectoryService().getSubschemaAPCache();
 
         // The ACs
-        AdministrativePoint aap1 = acCache.getElement( new DN( "ou=AAP1,ou=noAP1,ou=system", schemaManager ) );
+        AdministrativePoint aap1 = acCache.getElement( new Dn( "ou=AAP1,ou=noAP1,ou=system", schemaManager ) );
         assertNotNull( aap1 );
 
-        AdministrativePoint aap2 = acCache.getElement( new DN( "ou=AAP2,ou=system", schemaManager ) );
+        AdministrativePoint aap2 = acCache.getElement( new Dn( "ou=AAP2,ou=system", schemaManager ) );
         assertNotNull( aap2 );
 
-        AdministrativePoint subAap1 = acCache.getElement( new DN( "ou=subAAP1,ou=noAP3,ou=AAP2,ou=system",
+        AdministrativePoint subAap1 = acCache.getElement( new Dn( "ou=subAAP1,ou=noAP3,ou=AAP2,ou=system",
             schemaManager ) );
         assertNotNull( subAap1 );
 
         // The ACs
-        aap1 = caCache.getElement( new DN( "ou=AAP1,ou=noAP1,ou=system", schemaManager ) );
+        aap1 = caCache.getElement( new Dn( "ou=AAP1,ou=noAP1,ou=system", schemaManager ) );
         assertNotNull( aap1 );
 
-        aap2 = caCache.getElement( new DN( "ou=AAP2,ou=system", schemaManager ) );
+        aap2 = caCache.getElement( new Dn( "ou=AAP2,ou=system", schemaManager ) );
         assertNotNull( aap2 );
 
-        subAap1 = caCache.getElement( new DN( "ou=subAAP1,ou=noAP3,ou=AAP2,ou=system",
+        subAap1 = caCache.getElement( new Dn( "ou=subAAP1,ou=noAP3,ou=AAP2,ou=system",
             schemaManager ) );
         assertNotNull( subAap1 );
 
         // The TEs
-        aap1 = teCache.getElement( new DN( "ou=AAP1,ou=noAP1,ou=system", schemaManager ) );
+        aap1 = teCache.getElement( new Dn( "ou=AAP1,ou=noAP1,ou=system", schemaManager ) );
         assertNotNull( aap1 );
 
-        aap2 = teCache.getElement( new DN( "ou=AAP2,ou=system", schemaManager ) );
+        aap2 = teCache.getElement( new Dn( "ou=AAP2,ou=system", schemaManager ) );
         assertNotNull( aap2 );
 
-        subAap1 = teCache.getElement( new DN( "ou=subAAP1,ou=noAP3,ou=AAP2,ou=system",
+        subAap1 = teCache.getElement( new Dn( "ou=subAAP1,ou=noAP3,ou=AAP2,ou=system",
             schemaManager ) );
         assertNotNull( subAap1 );
 
         // The SSs
-        aap1 = ssCache.getElement( new DN( "ou=AAP1,ou=noAP1,ou=system", schemaManager ) );
+        aap1 = ssCache.getElement( new Dn( "ou=AAP1,ou=noAP1,ou=system", schemaManager ) );
         assertNotNull( aap1 );
 
-        aap2 = ssCache.getElement( new DN( "ou=AAP2,ou=system", schemaManager ) );
+        aap2 = ssCache.getElement( new Dn( "ou=AAP2,ou=system", schemaManager ) );
         assertNotNull( aap2 );
 
-        subAap1 = ssCache.getElement( new DN( "ou=subAAP1,ou=noAP3,ou=AAP2,ou=system",
+        subAap1 = ssCache.getElement( new Dn( "ou=subAAP1,ou=noAP3,ou=AAP2,ou=system",
             schemaManager ) );
         assertNotNull( subAap1 );
     }