You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@directory.apache.org by el...@apache.org on 2012/02/14 16:23:23 UTC

svn commit: r1243988 - in /directory: apacheds/trunk/core-api/src/main/java/org/apache/directory/server/core/api/schema/registries/synchronizers/ shared/trunk/ldap/model/src/main/java/org/apache/directory/shared/ldap/model/schema/registries/

Author: elecharny
Date: Tue Feb 14 15:23:22 2012
New Revision: 1243988

URL: http://svn.apache.org/viewvc?rev=1243988&view=rev
Log:
o get rid of direct references to the Registries class, we now use teh SchemaManager instead.

Modified:
    directory/apacheds/trunk/core-api/src/main/java/org/apache/directory/server/core/api/schema/registries/synchronizers/RegistrySynchronizerAdaptor.java
    directory/apacheds/trunk/core-api/src/main/java/org/apache/directory/server/core/api/schema/registries/synchronizers/SchemaSynchronizer.java
    directory/shared/trunk/ldap/model/src/main/java/org/apache/directory/shared/ldap/model/schema/registries/AbstractSchemaLoader.java

Modified: directory/apacheds/trunk/core-api/src/main/java/org/apache/directory/server/core/api/schema/registries/synchronizers/RegistrySynchronizerAdaptor.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/core-api/src/main/java/org/apache/directory/server/core/api/schema/registries/synchronizers/RegistrySynchronizerAdaptor.java?rev=1243988&r1=1243987&r2=1243988&view=diff
==============================================================================
--- directory/apacheds/trunk/core-api/src/main/java/org/apache/directory/server/core/api/schema/registries/synchronizers/RegistrySynchronizerAdaptor.java (original)
+++ directory/apacheds/trunk/core-api/src/main/java/org/apache/directory/server/core/api/schema/registries/synchronizers/RegistrySynchronizerAdaptor.java Tue Feb 14 15:23:22 2012
@@ -47,14 +47,13 @@ import org.apache.directory.shared.ldap.
 import org.apache.directory.shared.ldap.model.schema.ObjectClass;
 import org.apache.directory.shared.ldap.model.schema.SchemaManager;
 import org.apache.directory.shared.ldap.model.schema.registries.ObjectClassRegistry;
-import org.apache.directory.shared.ldap.model.schema.registries.Registries;
 import org.apache.directory.shared.util.Strings;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 
 /**
- * Central point of control for schemas enforced by the server.  The 
+ * Central point of control for schemas enforced by the server.  The
  * following duties are presently performed by this class:
  * 
  * <ul>
@@ -99,8 +98,12 @@ public class RegistrySynchronizerAdaptor
             MetaSchemaConstants.META_NAME_FORM_OC
     };
 
-    private final Registries registries;
+    /** The SchemaManager */
+    private final SchemaManager schemaManager;
+    
+    /** The ObjectClss Attribute */
     private final AttributeType objectClassAT;
+    
     private final RegistrySynchronizer[] registrySynchronizers = new RegistrySynchronizer[11];
     private final Map<String, RegistrySynchronizer> objectClass2synchronizerMap = new HashMap<String, RegistrySynchronizer>();
     private final SchemaSynchronizer schemaSynchronizer;
@@ -123,10 +126,9 @@ public class RegistrySynchronizerAdaptor
 
     public RegistrySynchronizerAdaptor( SchemaManager schemaManager ) throws Exception
     {
-        this.registries = schemaManager.getRegistries();
+        this.schemaManager = schemaManager;
         this.schemaSynchronizer = new SchemaSynchronizer( schemaManager );
-        this.objectClassAT = this.registries.getAttributeTypeRegistry()
-            .lookup( SchemaConstants.OBJECT_CLASS_AT );
+        this.objectClassAT = schemaManager.lookupAttributeTypeRegistry( SchemaConstants.OBJECT_CLASS_AT );
 
         this.registrySynchronizers[COMPARATOR_INDEX] = new ComparatorSynchronizer( schemaManager );
         this.registrySynchronizers[NORMALIZER_INDEX] = new NormalizerSynchronizer( schemaManager );
@@ -140,7 +142,8 @@ public class RegistrySynchronizerAdaptor
         this.registrySynchronizers[DIT_CONTENT_RULE_INDEX] = new DitContentRuleSynchronizer( schemaManager );
         this.registrySynchronizers[NAME_FORM_INDEX] = new NameFormSynchronizer( schemaManager );
 
-        ObjectClassRegistry ocReg = registries.getObjectClassRegistry();
+        ObjectClassRegistry ocReg = schemaManager.getObjectClassRegistry();
+        
         for ( int ii = 0; ii < META_OBJECT_CLASSES.length; ii++ )
         {
             ObjectClass oc = ocReg.lookup( META_OBJECT_CLASSES[ii] );
@@ -153,7 +156,7 @@ public class RegistrySynchronizerAdaptor
      * Add a new SchemaObject or a new Schema in the Schema partition.
      *
      * @param addContext The Add context, containing the entry to be added
-     * @throws Exception If the addition failed 
+     * @throws Exception If the addition failed
      */
     public void add( AddOperationContext addContext ) throws LdapException
     {
@@ -163,7 +166,7 @@ public class RegistrySynchronizerAdaptor
         for ( Value<?> value : oc )
         {
 
-            String oid = registries.getObjectClassRegistry().getOidByName( value.getString() );
+            String oid = schemaManager.getObjectClassRegistry().getOidByName( value.getString() );
 
             if ( objectClass2synchronizerMap.containsKey( oid ) )
             {
@@ -230,7 +233,7 @@ public class RegistrySynchronizerAdaptor
 
         for ( Value<?> value : oc )
         {
-            String oid = registries.getObjectClassRegistry().getOidByName( value.getString() );
+            String oid = schemaManager.getObjectClassRegistry().getOidByName( value.getString() );
 
             if ( objectClass2synchronizerMap.containsKey( oid ) )
             {
@@ -285,7 +288,7 @@ public class RegistrySynchronizerAdaptor
 
         for ( Value<?> value : oc )
         {
-            String oid = registries.getObjectClassRegistry().getOidByName( value.getString() );
+            String oid = schemaManager.getObjectClassRegistry().getOidByName( value.getString() );
 
             if ( objectClass2synchronizerMap.containsKey( oid ) )
             {
@@ -327,7 +330,7 @@ public class RegistrySynchronizerAdaptor
 
         for ( Value<?> value : oc )
         {
-            String oid = registries.getObjectClassRegistry().getOidByName( value.getString() );
+            String oid = schemaManager.getObjectClassRegistry().getOidByName( value.getString() );
 
             if ( objectClass2synchronizerMap.containsKey( oid ) )
             {
@@ -356,7 +359,7 @@ public class RegistrySynchronizerAdaptor
 
         for ( Value<?> value : oc )
         {
-            String oid = registries.getObjectClassRegistry().getOidByName( value.getString() );
+            String oid = schemaManager.getObjectClassRegistry().getOidByName( value.getString() );
 
             if ( objectClass2synchronizerMap.containsKey( oid ) )
             {
@@ -386,7 +389,7 @@ public class RegistrySynchronizerAdaptor
 
         for ( Value<?> value : oc )
         {
-            String oid = registries.getObjectClassRegistry().getOidByName( value.getString() );
+            String oid = schemaManager.getObjectClassRegistry().getOidByName( value.getString() );
 
             if ( objectClass2synchronizerMap.containsKey( oid ) )
             {

Modified: directory/apacheds/trunk/core-api/src/main/java/org/apache/directory/server/core/api/schema/registries/synchronizers/SchemaSynchronizer.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/core-api/src/main/java/org/apache/directory/server/core/api/schema/registries/synchronizers/SchemaSynchronizer.java?rev=1243988&r1=1243987&r2=1243988&view=diff
==============================================================================
--- directory/apacheds/trunk/core-api/src/main/java/org/apache/directory/server/core/api/schema/registries/synchronizers/SchemaSynchronizer.java (original)
+++ directory/apacheds/trunk/core-api/src/main/java/org/apache/directory/server/core/api/schema/registries/synchronizers/SchemaSynchronizer.java Tue Feb 14 15:23:22 2012
@@ -44,7 +44,6 @@ import org.apache.directory.shared.ldap.
 import org.apache.directory.shared.ldap.model.name.Rdn;
 import org.apache.directory.shared.ldap.model.schema.AttributeType;
 import org.apache.directory.shared.ldap.model.schema.SchemaManager;
-import org.apache.directory.shared.ldap.model.schema.registries.Registries;
 import org.apache.directory.shared.ldap.model.schema.registries.Schema;
 import org.apache.directory.shared.ldap.schemaloader.SchemaEntityFactory;
 import org.apache.directory.shared.util.Strings;
@@ -67,12 +66,11 @@ public class SchemaSynchronizer implemen
     private static final Logger LOG = LoggerFactory.getLogger( SchemaSynchronizer.class );
 
     private final SchemaEntityFactory factory;
-    //private final PartitionSchemaLoader loader;
 
     private final SchemaManager schemaManager;
 
     /** The global registries */
-    private final Registries registries;
+    //private final Registries registries;
 
     /** The m-disable AttributeType */
     private final AttributeType disabledAT;
@@ -95,13 +93,12 @@ public class SchemaSynchronizer implemen
      */
     public SchemaSynchronizer( SchemaManager schemaManager ) throws Exception
     {
-        this.registries = schemaManager.getRegistries();
+        //this.registries = schemaManager.getRegistries();
         this.schemaManager = schemaManager;
-        disabledAT = registries.getAttributeTypeRegistry().lookup( MetaSchemaConstants.M_DISABLED_AT );
+        disabledAT = schemaManager.lookupAttributeTypeRegistry( MetaSchemaConstants.M_DISABLED_AT );
         factory = new SchemaEntityFactory();
-        cnAT = registries.getAttributeTypeRegistry().lookup( SchemaConstants.CN_AT );
-        dependenciesAT = registries.getAttributeTypeRegistry()
-            .lookup( MetaSchemaConstants.M_DEPENDENCIES_AT );
+        cnAT = schemaManager.lookupAttributeTypeRegistry( SchemaConstants.CN_AT );
+        dependenciesAT = schemaManager.lookupAttributeTypeRegistry( MetaSchemaConstants.M_DEPENDENCIES_AT );
 
         ouSchemaDn = new Dn( schemaManager, SchemaConstants.OU_SCHEMA );
     }
@@ -264,7 +261,7 @@ public class SchemaSynchronizer implemen
     public void rename( Entry entry, Rdn newRdn, boolean cascade ) throws LdapException
     {
         String rdnAttribute = newRdn.getUpType();
-        String rdnAttributeOid = registries.getAttributeTypeRegistry().getOidByName( rdnAttribute );
+        String rdnAttributeOid = schemaManager.getAttributeTypeRegistry().getOidByName( rdnAttribute );
 
         if ( !rdnAttributeOid.equals( cnAT.getOid() ) )
         {
@@ -478,7 +475,7 @@ public class SchemaSynchronizer implemen
 
     private boolean disableSchema( String schemaName ) throws LdapException
     {
-        Schema schema = registries.getLoadedSchema( schemaName );
+        Schema schema = schemaManager.getLoadedSchema( schemaName );
 
         if ( schema == null )
         {
@@ -490,44 +487,6 @@ public class SchemaSynchronizer implemen
 
         return schemaManager.disable( schemaName );
 
-        /*
-        // First check that the schema is not already disabled
-        Map<String, Schema> schemas = registries.getLoadedSchemas();
-
-        Schema schema = schemas.get( schemaName );
-
-        if ( ( schema == null ) || schema.isDisabled() )
-        {
-            // The schema is disabled, do nothing
-            return SCHEMA_UNCHANGED;
-        }
-
-        Set<String> dependents = schemaManager.listEnabledDependentSchemaNames( schemaName );
-
-        if ( ! dependents.isEmpty() )
-        {
-            throw new LdapUnwillingToPerformException(
-                "Cannot disable schema with enabled dependents: " + dependents,
-                ResultCodeEnum.UNWILLING_TO_PERFORM );
-        }
-
-        schema.disable();
-
-        // Use brute force right now : iterate through all the schemaObjects
-        // searching for those associated with the disabled schema
-        disableAT( session, schemaName );
-
-        Set<SchemaObjectWrapper> content = registries.getLoadedSchema( schemaName ).getContent();
-
-        for ( SchemaObjectWrapper schemaWrapper : content )
-        {
-            SchemaObject schemaObject = schemaWrapper.get();
-
-            System.out.println( "Disabling " + schemaObject.getName() );
-        }
-
-        return SCHEMA_MODIFIED;
-        */
     }
 
 
@@ -537,7 +496,7 @@ public class SchemaSynchronizer implemen
      */
     private boolean enableSchema( String schemaName ) throws LdapException
     {
-        Schema schema = registries.getLoadedSchema( schemaName );
+        Schema schema = schemaManager.getLoadedSchema( schemaName );
 
         if ( schema == null )
         {
@@ -570,7 +529,7 @@ public class SchemaSynchronizer implemen
         if ( isEnabled )
         {
             // check to make sure all the dependencies are also enabled
-            Map<String, Schema> loaded = registries.getLoadedSchemas();
+            Map<String, Schema> loaded = schemaManager.getRegistries().getLoadedSchemas();
 
             for ( Value<?> value : dependencies )
             {

Modified: directory/shared/trunk/ldap/model/src/main/java/org/apache/directory/shared/ldap/model/schema/registries/AbstractSchemaLoader.java
URL: http://svn.apache.org/viewvc/directory/shared/trunk/ldap/model/src/main/java/org/apache/directory/shared/ldap/model/schema/registries/AbstractSchemaLoader.java?rev=1243988&r1=1243987&r2=1243988&view=diff
==============================================================================
--- directory/shared/trunk/ldap/model/src/main/java/org/apache/directory/shared/ldap/model/schema/registries/AbstractSchemaLoader.java (original)
+++ directory/shared/trunk/ldap/model/src/main/java/org/apache/directory/shared/ldap/model/schema/registries/AbstractSchemaLoader.java Tue Feb 14 15:23:22 2012
@@ -6,16 +6,16 @@
  *  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. 
- *  
+ *  under the License.
+ * 
  */
 package org.apache.directory.shared.ldap.model.schema.registries;
 
@@ -34,6 +34,7 @@ import org.apache.directory.shared.ldap.
 import org.apache.directory.shared.ldap.model.entry.Entry;
 import org.apache.directory.shared.ldap.model.entry.Attribute;
 import org.apache.directory.shared.ldap.model.entry.Value;
+import org.apache.directory.shared.ldap.model.schema.SchemaManager;
 import org.apache.directory.shared.util.StringConstants;
 import org.apache.directory.shared.util.Strings;
 
@@ -49,8 +50,8 @@ public abstract class AbstractSchemaLoad
     /** The listener. */
     protected SchemaLoaderListener listener;
 
-    /** 
-     * A map of all available schema names to schema objects. This map is 
+    /**
+     * A map of all available schema names to schema objects. This map is
      * populated when this class is created with all the schemas present in
      * the LDIF based schema repository.
      */
@@ -97,16 +98,16 @@ public abstract class AbstractSchemaLoad
      * @param schema the schema
      * @param registries the registries
      */
-    protected final void notifyListenerOrRegistries( Schema schema, Registries registries )
+    protected final void notifyListenerOrRegistries( Schema schema, SchemaManager schemaManager )
     {
         if ( listener != null )
         {
             listener.schemaLoaded( schema );
         }
 
-        if ( registries != listener )
+        if ( schemaManager != listener )
         {
-            registries.schemaLoaded( schema );
+            schemaManager.getRegistries().schemaLoaded( schema );
         }
     }
 
@@ -283,14 +284,14 @@ public abstract class AbstractSchemaLoad
     
     
     /**
-     * Register the comparator contained in the given LdifEntry into the registries. 
+     * Register the comparator contained in the given LdifEntry into the registries.
      *
      * @param registries The Registries
      * @param entry The LdifEntry containing the comparator description
      * @param schema The associated schema
      * @throws Exception If the registering failed
      *
-    protected LdapComparator<?> registerComparator( Registries registries, LdifEntry entry, Schema schema ) 
+    protected LdapComparator<?> registerComparator( Registries registries, LdifEntry entry, Schema schema )
         throws Exception
     {
         return registerComparator( registries, entry.getEntry(), schema );
@@ -298,17 +299,17 @@ public abstract class AbstractSchemaLoad
     
     
     /**
-     * Register the comparator contained in the given Entry into the registries. 
+     * Register the comparator contained in the given Entry into the registries.
      *
      * @param registries The Registries
      * @param entry The Entry containing the comparator description
      * @param schema The associated schema
      * @throws Exception If the registering failed
      *
-    protected LdapComparator<?> registerComparator( Registries registries, Entry entry, Schema schema ) 
+    protected LdapComparator<?> registerComparator( Registries registries, Entry entry, Schema schema )
         throws Exception
     {
-        LdapComparator<?> comparator = 
+        LdapComparator<?> comparator =
             factory.getLdapComparator( entry, registries, schema.getSchemaName() );
         comparator.setOid( entry.get( MetaSchemaConstants.M_OID_AT ).getString() );
 
@@ -336,7 +337,7 @@ public abstract class AbstractSchemaLoad
     
     
     /**
-     * Register the SyntaxChecker contained in the given LdifEntry into the registries. 
+     * Register the SyntaxChecker contained in the given LdifEntry into the registries.
      *
      * @param registries The Registries
      * @param entry The LdifEntry containing the SyntaxChecker description
@@ -344,10 +345,10 @@ public abstract class AbstractSchemaLoad
      * @return the created SyntaxChecker instance
      * @throws Exception If the registering failed
      *
-    protected SyntaxChecker registerSyntaxChecker( Registries registries, LdifEntry entry, Schema schema) 
+    protected SyntaxChecker registerSyntaxChecker( Registries registries, LdifEntry entry, Schema schema)
         throws Exception
     {
-        SyntaxChecker syntaxChecker = 
+        SyntaxChecker syntaxChecker =
             factory.getSyntaxChecker( entry.getEntry(), registries, schema.getSchemaName() );
         syntaxChecker.setOid( entry.get( MetaSchemaConstants.M_OID_AT ).getString() );
 
@@ -375,7 +376,7 @@ public abstract class AbstractSchemaLoad
     
     
     /**
-     * Register the Normalizer contained in the given LdifEntry into the registries. 
+     * Register the Normalizer contained in the given LdifEntry into the registries.
      *
      * @param registries The Registries
      * @param entry The LdifEntry containing the Normalizer description
@@ -383,7 +384,7 @@ public abstract class AbstractSchemaLoad
      * @return the created Normalizer instance
      * @throws Exception If the registering failed
      *
-    protected Normalizer registerNormalizer( Registries registries, LdifEntry entry, Schema schema) 
+    protected Normalizer registerNormalizer( Registries registries, LdifEntry entry, Schema schema)
         throws Exception
     {
         Normalizer normalizer =
@@ -413,7 +414,7 @@ public abstract class AbstractSchemaLoad
     
     
     /**
-     * Register the MatchingRule contained in the given LdifEntry into the registries. 
+     * Register the MatchingRule contained in the given LdifEntry into the registries.
      *
      * @param registries The Registries
      * @param entry The LdifEntry containing the MatchingRule description
@@ -421,10 +422,10 @@ public abstract class AbstractSchemaLoad
      * @return the created MatchingRule instance
      * @throws Exception If the registering failed
      *
-    protected MatchingRule registerMatchingRule( Registries registries, LdifEntry entry, Schema schema) 
+    protected MatchingRule registerMatchingRule( Registries registries, LdifEntry entry, Schema schema)
         throws Exception
     {
-        MatchingRule matchingRule = factory.getMatchingRule( 
+        MatchingRule matchingRule = factory.getMatchingRule(
             entry.getEntry(), registries, schema.getSchemaName() );
 
         if ( registries.isRelaxed() )
@@ -451,7 +452,7 @@ public abstract class AbstractSchemaLoad
     
     
     /**
-     * Register the Syntax contained in the given LdifEntry into the registries. 
+     * Register the Syntax contained in the given LdifEntry into the registries.
      *
      * @param registries The Registries
      * @param entry The LdifEntry containing the Syntax description
@@ -459,10 +460,10 @@ public abstract class AbstractSchemaLoad
      * @return the created Syntax instance
      * @throws Exception If the registering failed
      *
-    protected LdapSyntax registerSyntax( Registries registries, LdifEntry entry, Schema schema) 
+    protected LdapSyntax registerSyntax( Registries registries, LdifEntry entry, Schema schema)
         throws Exception
     {
-        LdapSyntax syntax = factory.getSyntax( 
+        LdapSyntax syntax = factory.getSyntax(
             entry.getEntry(), registries, schema.getSchemaName() );
 
         if ( registries.isRelaxed() )
@@ -489,7 +490,7 @@ public abstract class AbstractSchemaLoad
     
     
     /**
-     * Register the AttributeType contained in the given LdifEntry into the registries. 
+     * Register the AttributeType contained in the given LdifEntry into the registries.
      *
      * @param registries The Registries
      * @param entry The LdifEntry containing the AttributeType description
@@ -497,7 +498,7 @@ public abstract class AbstractSchemaLoad
      * @return the created AttributeType instance
      * @throws Exception If the registering failed
      *
-    protected AttributeType registerAttributeType( Registries registries, LdifEntry entry, Schema schema ) 
+    protected AttributeType registerAttributeType( Registries registries, LdifEntry entry, Schema schema )
         throws Exception
     {
         AttributeType attributeType = factory.getAttributeType( entry.getEntry(), registries, schema.getSchemaName() );
@@ -526,7 +527,7 @@ public abstract class AbstractSchemaLoad
     
     
     /**
-     * Register the MatchingRuleUse contained in the given LdifEntry into the registries. 
+     * Register the MatchingRuleUse contained in the given LdifEntry into the registries.
      *
      * @param registries The Registries
      * @param entry The LdifEntry containing the MatchingRuleUse description
@@ -534,7 +535,7 @@ public abstract class AbstractSchemaLoad
      * @return the created MatchingRuleUse instance
      * @throws Exception If the registering failed
      *
-    protected MatchingRuleUse registerMatchingRuleUse( Registries registries, LdifEntry entry, Schema schema) 
+    protected MatchingRuleUse registerMatchingRuleUse( Registries registries, LdifEntry entry, Schema schema)
         throws Exception
     {
         throw new NotImplementedException( "Need to implement factory " +
@@ -543,7 +544,7 @@ public abstract class AbstractSchemaLoad
     
     
     /**
-     * Register the NameForm contained in the given LdifEntry into the registries. 
+     * Register the NameForm contained in the given LdifEntry into the registries.
      *
      * @param registries The Registries
      * @param entry The LdifEntry containing the NameForm description
@@ -551,7 +552,7 @@ public abstract class AbstractSchemaLoad
      * @return the created NameForm instance
      * @throws Exception If the registering failed
      *
-    protected NameForm registerNameForm( Registries registries, LdifEntry entry, Schema schema) 
+    protected NameForm registerNameForm( Registries registries, LdifEntry entry, Schema schema)
         throws Exception
     {
         throw new NotImplementedException( "Need to implement factory " +
@@ -560,7 +561,7 @@ public abstract class AbstractSchemaLoad
     
     
     /**
-     * Register the DitContentRule contained in the given LdifEntry into the registries. 
+     * Register the DitContentRule contained in the given LdifEntry into the registries.
      *
      * @param registries The Registries
      * @param entry The LdifEntry containing the DitContentRule description
@@ -568,7 +569,7 @@ public abstract class AbstractSchemaLoad
      * @return the created DitContentRule instance
      * @throws Exception If the registering failed
      *
-    protected DITContentRule registerDitContentRule( Registries registries, LdifEntry entry, Schema schema) 
+    protected DITContentRule registerDitContentRule( Registries registries, LdifEntry entry, Schema schema)
         throws Exception
     {
         throw new NotImplementedException( "Need to implement factory " +
@@ -577,7 +578,7 @@ public abstract class AbstractSchemaLoad
     
     
     /**
-     * Register the DitStructureRule contained in the given LdifEntry into the registries. 
+     * Register the DitStructureRule contained in the given LdifEntry into the registries.
      *
      * @param registries The Registries
      * @param entry The LdifEntry containing the DitStructureRule description
@@ -585,7 +586,7 @@ public abstract class AbstractSchemaLoad
      * @return the created DitStructureRule instance
      * @throws Exception If the registering failed
      *
-    protected DITStructureRule registerDitStructureRule( Registries registries, LdifEntry entry, Schema schema) 
+    protected DITStructureRule registerDitStructureRule( Registries registries, LdifEntry entry, Schema schema)
         throws Exception
     {
         throw new NotImplementedException( "Need to implement factory " +
@@ -594,7 +595,7 @@ public abstract class AbstractSchemaLoad
 
 
     /**
-     * Register the ObjectClass contained in the given LdifEntry into the registries. 
+     * Register the ObjectClass contained in the given LdifEntry into the registries.
      *
      * @param registries The Registries
      * @param entry The LdifEntry containing the ObjectClass description
@@ -602,7 +603,7 @@ public abstract class AbstractSchemaLoad
      * @return the created ObjectClass instance
      * @throws Exception If the registering failed
      *
-    protected ObjectClass registerObjectClass( Registries registries, LdifEntry entry, Schema schema) 
+    protected ObjectClass registerObjectClass( Registries registries, LdifEntry entry, Schema schema)
         throws Exception
     {
         return registerObjectClass( registries, entry.getEntry(), schema );
@@ -610,7 +611,7 @@ public abstract class AbstractSchemaLoad
 
 
     /**
-     * Register the ObjectClass contained in the given LdifEntry into the registries. 
+     * Register the ObjectClass contained in the given LdifEntry into the registries.
      *
      * @param registries The Registries
      * @param entry The Entry containing the ObjectClass description
@@ -618,7 +619,7 @@ public abstract class AbstractSchemaLoad
      * @return the created ObjectClass instance
      * @throws Exception If the registering failed
      *
-    protected ObjectClass registerObjectClass( Registries registries, Entry entry, Schema schema) 
+    protected ObjectClass registerObjectClass( Registries registries, Entry entry, Schema schema)
         throws Exception
     {
         ObjectClass objectClass = factory.getObjectClass( entry, registries, schema.getSchemaName() );