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 2013/12/28 00:49:59 UTC

svn commit: r1553762 - in /directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap: ./ handlers/ handlers/controls/ handlers/extended/ replication/consumer/ replication/provider/

Author: elecharny
Date: Fri Dec 27 23:49:58 2013
New Revision: 1553762

URL: http://svn.apache.org/r1553762
Log:
o Removed some unused imports

Modified:
    directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/LdapSession.java
    directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/SearchAbandonListener.java
    directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/controls/PagedSearchContext.java
    directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/extended/PwdModifyHandler.java
    directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/consumer/ReplicationConsumerImpl.java
    directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/provider/SyncReplRequestHandler.java

Modified: directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/LdapSession.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/LdapSession.java?rev=1553762&r1=1553761&r2=1553762&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/LdapSession.java (original)
+++ directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/LdapSession.java Fri Dec 27 23:49:58 2013
@@ -34,7 +34,6 @@ import org.apache.directory.api.ldap.mod
 import org.apache.directory.server.core.api.CoreSession;
 import org.apache.directory.server.core.api.LdapPrincipal;
 import org.apache.directory.server.core.api.SearchRequestContainer;
-import org.apache.directory.server.core.api.filtering.EntryFilteringCursor;
 import org.apache.directory.server.i18n.I18n;
 import org.apache.directory.server.ldap.handlers.controls.PagedSearchContext;
 import org.apache.mina.core.session.IoSession;
@@ -118,7 +117,7 @@ public class LdapSession
      * a session to be authenticated :<br>
      * - the coreSession must not be null<br>
      * - and the state should be Authenticated.
-     * 
+     *
      * @return <code>true</code> if the session is not anonymous
      */
     public boolean isAuthenticated()
@@ -132,7 +131,7 @@ public class LdapSession
      * a session to be authenticated :<br>
      * - it has to exist<br>
      * - and the session should not be anonymous.
-     * 
+     *
      * @return <code>true</code> if the session is not anonymous
      */
     public boolean isAnonymous()
@@ -144,7 +143,7 @@ public class LdapSession
     /**
      * Check if the session is processing a BindRequest, either Simple
      * or SASL
-     * 
+     *
      * @return <code>true</code> if the session is in AuthPending state
      */
     public boolean isAuthPending()
@@ -156,7 +155,7 @@ public class LdapSession
 
     /**
      * Check if the session is processing a Simple BindRequest
-     * 
+     *
      * @return <code>true</code> if the session is in AuthPending state
      */
     public boolean isSimpleAuthPending()
@@ -167,7 +166,7 @@ public class LdapSession
 
     /**
      * Check if the session is processing a SASL BindRequest
-     * 
+     *
      * @return <code>true</code> if the session is in AuthPending state
      */
     public boolean isSaslAuthPending()
@@ -201,7 +200,7 @@ public class LdapSession
 
     /**
      * Sets the logical core DirectoryService session.
-     * 
+     *
      * @param coreSession the logical core DirectoryService session
      */
     public void setCoreSession( CoreSession coreSession )
@@ -229,7 +228,7 @@ public class LdapSession
 
     /**
      * Abandons a specific request by messageId.
-     * 
+     *
      * @param messageId The request ID to abandon
      */
     public AbandonableRequest abandonOutstandingRequest( int messageId )
@@ -240,7 +239,7 @@ public class LdapSession
         {
             request = outstandingRequests.remove( messageId );
         }
-        
+
         // Remove the PagedSearch cursors now
         try
         {
@@ -300,8 +299,8 @@ public class LdapSession
             outstandingRequests.remove( request.getMessageId() );
         }
     }
-    
-    
+
+
     /**
      * @return A list of all the abandonable requests for this session.
      */
@@ -313,7 +312,7 @@ public class LdapSession
         }
     }
 
-    
+
     /**
      * Registers a new searchRequest
      *
@@ -398,7 +397,7 @@ public class LdapSession
 
     /**
      * Get the mechanism selected by a user during a SASL Bind negotiation.
-     * 
+     *
      * @return The used mechanism, if any
      */
     public String getCurrentMechanism()
@@ -409,7 +408,7 @@ public class LdapSession
 
     /**
      * Add a Sasl property and value
-     * 
+     *
      * @param property the property to add
      * @param value the value for this property
      */
@@ -421,7 +420,7 @@ public class LdapSession
 
     /**
      * Get a Sasl property's value
-     * 
+     *
      * @param property the property to get
      * @return the associated value, or null if we don't have such a property
      */
@@ -475,7 +474,7 @@ public class LdapSession
      * Add a new Paged Search context into the stored context. If some
      * context with the same id already exists, it will be closed and
      * removed.
-     * 
+     *
      * @param context The context to add
      */
     public void addPagedSearchContext( PagedSearchContext context ) throws Exception
@@ -504,7 +503,7 @@ public class LdapSession
 
     /**
      * Remove a Paged Search context from the map storing all of them.
-     * 
+     *
      * @param contextId The context ID to remove
      * @return The removed context if any found
      */
@@ -513,10 +512,10 @@ public class LdapSession
         return pagedSearchContexts.remove( contextId );
     }
 
-    
+
     /**
      * Close all the pending cursors for all the pending PagedSearches
-     * 
+     *
      * @throws Exception If we've got an exception.
      */
     public void closeAllPagedSearches() throws Exception
@@ -524,9 +523,9 @@ public class LdapSession
         for ( int contextId : pagedSearchContexts.keySet() )
         {
             PagedSearchContext context = pagedSearchContexts.get( contextId );
-            
+
             Cursor<Entry> cursor = context.getCursor();
-            
+
             if ( cursor != null )
             {
                 cursor.close();

Modified: directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/SearchAbandonListener.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/SearchAbandonListener.java?rev=1553762&r1=1553761&r2=1553762&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/SearchAbandonListener.java (original)
+++ directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/SearchAbandonListener.java Fri Dec 27 23:49:58 2013
@@ -25,14 +25,13 @@ import org.apache.directory.api.ldap.mod
 import org.apache.directory.api.ldap.model.message.AbandonListener;
 import org.apache.directory.api.ldap.model.message.AbandonableRequest;
 import org.apache.directory.server.core.api.event.DirectoryListener;
-import org.apache.directory.server.core.api.filtering.EntryFilteringCursor;
 import org.apache.directory.server.ldap.LdapServer;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 
 /**
- * An AbandonListener implementation which closes an associated cursor or 
+ * An AbandonListener implementation which closes an associated cursor or
  * removes a DirectoryListener.
  *
  * @author <a href="mailto:dev@directory.apache.org">Apache Directory Project</a>

Modified: directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/controls/PagedSearchContext.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/controls/PagedSearchContext.java?rev=1553762&r1=1553761&r2=1553762&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/controls/PagedSearchContext.java (original)
+++ directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/controls/PagedSearchContext.java Fri Dec 27 23:49:58 2013
@@ -33,7 +33,6 @@ import org.apache.directory.api.ldap.mod
 import org.apache.directory.api.ldap.model.schema.AttributeType;
 import org.apache.directory.api.ldap.model.schema.SchemaManager;
 import org.apache.directory.api.util.Strings;
-import org.apache.directory.server.core.api.filtering.EntryFilteringCursor;
 import org.apache.directory.server.ldap.LdapSession;
 
 

Modified: directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/extended/PwdModifyHandler.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/extended/PwdModifyHandler.java?rev=1553762&r1=1553761&r2=1553762&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/extended/PwdModifyHandler.java (original)
+++ directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/handlers/extended/PwdModifyHandler.java Fri Dec 27 23:49:58 2013
@@ -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.server.ldap.handlers.extended;
 
@@ -27,7 +27,6 @@ import java.util.List;
 import java.util.Set;
 
 import org.apache.directory.api.ldap.extras.controls.ppolicy.PasswordPolicy;
-import org.apache.directory.api.ldap.extras.controls.ppolicy_impl.PasswordPolicyDecorator;
 import org.apache.directory.api.ldap.extras.extended.PwdModifyRequest;
 import org.apache.directory.api.ldap.extras.extended.PwdModifyResponse;
 import org.apache.directory.api.ldap.extras.extended.PwdModifyResponseImpl;
@@ -56,12 +55,12 @@ import org.slf4j.LoggerFactory;
 
 /**
  * An handler to manage PwdModifyRequest. Users can send a pwdModify request
- * for their own passwords, or for another people password. Only admin can 
+ * for their own passwords, or for another people password. Only admin can
  * change someone else password without having to provide the original password.
  * Here rae the different use cases : <br/>
  * <ul>
  * </ul>
- * 
+ *
  * @author <a href="mailto:dev@directory.apache.org">Apache Directory Project</a>
  */
 public class PwdModifyHandler implements ExtendedOperationHandler<PwdModifyRequest, PwdModifyResponse>
@@ -133,7 +132,7 @@ public class PwdModifyHandler implements
         {
             modifyContext.addRequestControl( ppolicyControl );
         }
-        
+
         List<Modification> modifications = new ArrayList<Modification>();
         Modification modification = null;
 
@@ -178,7 +177,7 @@ public class PwdModifyHandler implements
 
         ResultCodeEnum errorCode = null;
         String errorMessage = null;
-        
+
         try
         {
             service.getOperationManager().modify( modifyContext );
@@ -188,16 +187,16 @@ public class PwdModifyHandler implements
             // Ok, all done
             PwdModifyResponseImpl pmrl = new PwdModifyResponseImpl(
                 req.getMessageId(), ResultCodeEnum.SUCCESS );
-            
+
             ppolicyControl = modifyContext.getResponseControl( PasswordPolicy.OID );
-            
+
             if( ppolicyControl != null )
             {
                 pmrl.addControl( ppolicyControl );
             }
-            
+
             requestor.getIoSession().write( pmrl );
-            
+
             return;
         }
         catch ( LdapOperationException loe )
@@ -211,15 +210,15 @@ public class PwdModifyHandler implements
             errorCode = ResultCodeEnum.OTHER;
             errorMessage = le.getMessage();
         }
-        
+
         // We can't modify the password
         LOG.error( "Cannot modify the password for user " + userDn + ", exception : " + errorMessage );
         PwdModifyResponseImpl errorPmrl = new PwdModifyResponseImpl(
             req.getMessageId(), errorCode, "Cannot modify the password for user "
                 + userDn + ", exception : " + errorMessage );
-        
+
         ppolicyControl = modifyContext.getResponseControl( PasswordPolicy.OID );
-        
+
         if( ppolicyControl != null )
         {
             errorPmrl.addControl( ppolicyControl );
@@ -278,7 +277,7 @@ public class PwdModifyHandler implements
 
         ResultCodeEnum errorCode = null;
         String errorMessage = null;
-        
+
         try
         {
             service.getOperationManager().modify( modifyContext );
@@ -288,14 +287,14 @@ public class PwdModifyHandler implements
             // Ok, all done
             PwdModifyResponseImpl pmrl = new PwdModifyResponseImpl(
                 req.getMessageId(), ResultCodeEnum.SUCCESS );
-            
+
             ppolicyControl = modifyContext.getResponseControl( PasswordPolicy.OID );
-            
+
             if( ppolicyControl != null )
             {
                 pmrl.addControl( ppolicyControl );
             }
-            
+
             requestor.getIoSession().write( pmrl );
             return;
         }
@@ -310,7 +309,7 @@ public class PwdModifyHandler implements
             errorCode = ResultCodeEnum.OTHER;
             errorMessage = le.getMessage();
         }
-        
+
         // We can't modify the password
         LOG.error( "Cannot modify the password for user " + principalDn + ", exception : " + errorMessage );
 
@@ -319,7 +318,7 @@ public class PwdModifyHandler implements
                 + principalDn + ", exception : " + errorMessage );
 
         ppolicyControl = modifyContext.getResponseControl( PasswordPolicy.OID );
-        
+
         if( ppolicyControl != null )
         {
             errorPmrl.addControl( ppolicyControl );
@@ -383,7 +382,7 @@ public class PwdModifyHandler implements
                 }
                 else
                 {
-                    // We are administrator, we can try to modify the user's credentials 
+                    // We are administrator, we can try to modify the user's credentials
                     modifyUserPassword( requestor, userDn, oldPassword, newPassword, req );
                 }
             }
@@ -407,7 +406,7 @@ public class PwdModifyHandler implements
             }
             catch ( LdapException le )
             {
-                // We can't bind with the provided information : we thus can't 
+                // We can't bind with the provided information : we thus can't
                 // change the password...
                 requestor.getIoSession().write( new PwdModifyResponseImpl(
                     req.getMessageId(), ResultCodeEnum.INVALID_CREDENTIALS ) );
@@ -415,7 +414,7 @@ public class PwdModifyHandler implements
                 return;
             }
 
-            // Ok, we were able to bind using the userIdentity and the password. Let's 
+            // Ok, we were able to bind using the userIdentity and the password. Let's
             // modify the password now
             ModifyOperationContext modifyContext = new ModifyOperationContext( adminSession );
             modifyContext.setDn( userDn );

Modified: directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/consumer/ReplicationConsumerImpl.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/consumer/ReplicationConsumerImpl.java?rev=1553762&r1=1553761&r2=1553762&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/consumer/ReplicationConsumerImpl.java (original)
+++ directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/consumer/ReplicationConsumerImpl.java Fri Dec 27 23:49:58 2013
@@ -80,7 +80,6 @@ import org.apache.directory.ldap.client.
 import org.apache.directory.server.core.api.CoreSession;
 import org.apache.directory.server.core.api.DirectoryService;
 import org.apache.directory.server.core.api.OperationManager;
-import org.apache.directory.server.core.api.filtering.EntryFilteringCursor;
 import org.apache.directory.server.core.api.interceptor.context.AddOperationContext;
 import org.apache.directory.server.core.api.interceptor.context.LookupOperationContext;
 import org.apache.directory.server.core.api.interceptor.context.ModifyOperationContext;
@@ -199,8 +198,8 @@ public class ReplicationConsumerImpl imp
     /**
      * Connect to the remote server. Note that a SyncRepl consumer will be connected to only
      * one remote server
-     * 
-     * @return true if the connections have been successful. 
+     *
+     * @return true if the connections have been successful.
      */
     public boolean connect()
     {
@@ -328,7 +327,7 @@ public class ReplicationConsumerImpl imp
 
 
     /**
-     * Process a SearchResultEntry received from a consumer. We have to handle all the 
+     * Process a SearchResultEntry received from a consumer. We have to handle all the
      * cases :
      * - Add
      * - Modify
@@ -607,7 +606,7 @@ public class ReplicationConsumerImpl imp
     }
 
 
-    /** 
+    /**
      * {@inheritDoc}
      */
     public void setConfig( ReplicationConsumerConfig config )
@@ -870,17 +869,17 @@ public class ReplicationConsumerImpl imp
             {
                 connection.unBind();
                 LOG.info( "Unbound from the server {}", config.getProducer() );
-                
+
                 if ( CONSUMER_LOG.isDebugEnabled() )
                 {
                     MDC.put( "Replica", Integer.toString( config.getReplicaId() ) );
                     CONSUMER_LOG.info( "Unbound from the server {}", config.getProducer() );
                 }
-                
+
                 connection.close();
                 LOG.info( "Connection closed for the server {}", config.getProducer() );
                 CONSUMER_LOG.info( "Connection closed for the server {}", config.getProducer() );
-                
+
                 connection = null;
             }
         }
@@ -892,7 +891,7 @@ public class ReplicationConsumerImpl imp
         {
             // persist the cookie
             storeCookie();
-            
+
             // reset the cookie
             syncCookie = null;
         }

Modified: directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/provider/SyncReplRequestHandler.java
URL: http://svn.apache.org/viewvc/directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/provider/SyncReplRequestHandler.java?rev=1553762&r1=1553761&r2=1553762&view=diff
==============================================================================
--- directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/provider/SyncReplRequestHandler.java (original)
+++ directory/apacheds/trunk/protocol-ldap/src/main/java/org/apache/directory/server/ldap/replication/provider/SyncReplRequestHandler.java Fri Dec 27 23:49:58 2013
@@ -94,7 +94,6 @@ import org.apache.directory.server.core.
 import org.apache.directory.server.core.api.event.EventService;
 import org.apache.directory.server.core.api.event.EventType;
 import org.apache.directory.server.core.api.event.NotificationCriteria;
-import org.apache.directory.server.core.api.filtering.EntryFilteringCursor;
 import org.apache.directory.server.core.api.interceptor.context.DeleteOperationContext;
 import org.apache.directory.server.core.api.interceptor.context.ModifyOperationContext;
 import org.apache.directory.server.core.api.interceptor.context.OperationContext;
@@ -156,7 +155,7 @@ public class SyncReplRequestHandler impl
 
 
     /**
-     * Create a SyncReplRequestHandler empty instance 
+     * Create a SyncReplRequestHandler empty instance
      */
     public SyncReplRequestHandler()
     {
@@ -168,7 +167,7 @@ public class SyncReplRequestHandler impl
      */
     public void start( LdapServer server )
     {
-        // Check that the handler is not already started : we don't want to start it twice... 
+        // Check that the handler is not already started : we don't want to start it twice...
         if ( initialized )
         {
             LOG.warn( "syncrepl provider was already initialized" );
@@ -208,7 +207,7 @@ public class SyncReplRequestHandler impl
                 }
             }
 
-            // Create the replication manager 
+            // Create the replication manager
             replicaUtil = new ReplConsumerManager( dirService );
 
             loadReplicaInfo();
@@ -289,7 +288,7 @@ public class SyncReplRequestHandler impl
 
     /**
      * Process the incoming search request sent by a remote server when trying to replicate.
-     * 
+     *
      * @param session The used LdapSession. Should be the dedicated user
      * @param request The search request
      */
@@ -429,7 +428,7 @@ public class SyncReplRequestHandler impl
 
 
     /**
-     * process the update of the consumer, starting from the given LastEntryCSN the consumer 
+     * process the update of the consumer, starting from the given LastEntryCSN the consumer
      * has sent with the sync request.
      */
     private void doContentUpdate( LdapSession session, SearchRequest req, ReplicaEventLog replicaLog, String consumerCsn )
@@ -439,9 +438,9 @@ public class SyncReplRequestHandler impl
         {
             boolean refreshNPersist = isRefreshNPersist( req );
 
-            // if this method is called with refreshAndPersist  
+            // if this method is called with refreshAndPersist
             // means the client was offline after it initiated a persistent synch session
-            // we need to update the handler's session 
+            // we need to update the handler's session
             if ( refreshNPersist )
             {
                 SyncReplSearchListener handler = replicaLog.getPersistentListener();
@@ -491,31 +490,31 @@ public class SyncReplRequestHandler impl
 
 
     /**
-     * Process the initial refresh : we will send all the entries 
+     * Process the initial refresh : we will send all the entries
      */
     private void doInitialRefresh( LdapSession session, SearchRequest request ) throws Exception
     {
         PROVIDER_LOG.debug( "Starting an initial refresh" );
 
         SortRequestControl ctrl = ( SortRequestControl ) request.getControl( SortRequestControl.OID );
-        
+
         if( ctrl != null )
         {
             LOG.warn( "Removing the received sort control from the syncrepl search request during initial refresh" );
             request.removeControl( ctrl );
         }
-        
+
         LOG.debug( "Adding sort control to sort the entries by entryDn attribute to preserve order of insertion" );
         SortKey sk = new SortKey( SchemaConstants.ENTRY_DN_AT );
         // matchingrule for "entryDn"
         sk.setMatchingRuleId( "2.5.13.1" );
         sk.setReverseOrder( true );
-        
+
         ctrl = new SortRequestControlImpl();
         ctrl.addSortKey( sk );
 
         request.addControl( ctrl );
-        
+
         String originalFilter = request.getFilter().toString();
         InetSocketAddress address = ( InetSocketAddress ) session.getIoSession().getRemoteAddress();
         String hostName = address.getAddress().getHostName();
@@ -548,8 +547,8 @@ public class SyncReplRequestHandler impl
         SyncReplSearchListener replicationListener = new SyncReplSearchListener( session, request, replicaLog, false );
         replicaLog.setPersistentListener( replicationListener );
 
-        // compose notification criteria and add the listener to the event 
-        // service using that notification criteria to determine which events 
+        // compose notification criteria and add the listener to the event
+        // service using that notification criteria to determine which events
         // are to be delivered to the persistent search issuing client
         NotificationCriteria criteria = new NotificationCriteria();
         criteria.setAliasDerefMode( request.getDerefAliases() );
@@ -583,7 +582,7 @@ public class SyncReplRequestHandler impl
             {
                 PROVIDER_LOG
                     .debug( "Refresh&Persist requested : send the data being modified since the initial refresh" );
-                // Now, send the modified entries since the search has started 
+                // Now, send the modified entries since the search has started
                 sendContentFromLog( session, request, replicaLog, contextCsn );
 
                 byte[] cookie = LdapProtocolUtils.createCookie( replicaLog.getId(), replicaLog.getLastSentCsn() );
@@ -656,7 +655,7 @@ public class SyncReplRequestHandler impl
         LdapResult ldapResult = searchDoneResp.getLdapResult();
 
         // A normal search
-        // Check that we have a cursor or not. 
+        // Check that we have a cursor or not.
         // No cursor : do a search.
         Cursor<Entry> cursor = session.getCoreSession().search( req );
 
@@ -897,8 +896,8 @@ public class SyncReplRequestHandler impl
         }
 
         /*
-         * Non administrator based searches are limited by time if the server 
-         * has been configured with unlimited time and the request specifies 
+         * Non administrator based searches are limited by time if the server
+         * has been configured with unlimited time and the request specifies
          * unlimited search time
          */
         if ( ldapServer.getMaxTimeLimit() == NO_TIME_LIMIT && req.getTimeLimit() == NO_TIME_LIMIT )
@@ -907,9 +906,9 @@ public class SyncReplRequestHandler impl
         }
 
         /*
-         * If the non-administrator user specifies unlimited time but the server 
-         * is configured to limit the search time then we limit by the max time 
-         * allowed by the configuration 
+         * If the non-administrator user specifies unlimited time but the server
+         * is configured to limit the search time then we limit by the max time
+         * allowed by the configuration
          */
         if ( req.getTimeLimit() == 0 )
         {
@@ -918,8 +917,8 @@ public class SyncReplRequestHandler impl
         }
 
         /*
-         * If the non-administrative user specifies a time limit equal to or 
-         * less than the maximum limit configured in the server then we 
+         * If the non-administrative user specifies a time limit equal to or
+         * less than the maximum limit configured in the server then we
          * constrain search by the amount specified in the request
          */
         if ( ldapServer.getMaxTimeLimit() >= req.getTimeLimit() )
@@ -929,7 +928,7 @@ public class SyncReplRequestHandler impl
         }
 
         /*
-         * Here the non-administrative user's requested time limit is greater 
+         * Here the non-administrative user's requested time limit is greater
          * than what the server's configured maximum limit allows so we limit
          * the search to the configured limit
          */
@@ -940,11 +939,11 @@ public class SyncReplRequestHandler impl
     public ExprNode modifyFilter( LdapSession session, SearchRequest req ) throws Exception
     {
         /*
-         * Most of the time the search filter is just (objectClass=*) and if 
+         * Most of the time the search filter is just (objectClass=*) and if
          * this is the case then there's no reason at all to OR this with an
-         * (objectClass=referral).  If we detect this case then we leave it 
+         * (objectClass=referral).  If we detect this case then we leave it
          * as is to represent the OR condition:
-         * 
+         *
          *  (| (objectClass=referral)(objectClass=*)) == (objectClass=*)
          */
         boolean isOcPresenceFilter = false;
@@ -1042,7 +1041,7 @@ public class SyncReplRequestHandler impl
                     replicaLogMap.put( replica.getId(), replica );
                     eventLogNames.add( replica.getName() );
 
-                    // update the replicaCount's value to assign a correct value to the new replica(s) 
+                    // update the replicaCount's value to assign a correct value to the new replica(s)
                     if ( replicaCount.get() < replica.getId() )
                     {
                         replicaCount.set( replica.getId() );
@@ -1135,7 +1134,7 @@ public class SyncReplRequestHandler impl
 
 
     /**
-     * Get the Replica event log from the replica ID found in the cookie 
+     * Get the Replica event log from the replica ID found in the cookie
      */
     private ReplicaEventLog getReplicaEventLog( String cookieString ) throws Exception
     {
@@ -1169,7 +1168,7 @@ public class SyncReplRequestHandler impl
 
 
     /**
-     * Send an error response to he consue r: it has to send a SYNC_REFRESH request first. 
+     * Send an error response to he consue r: it has to send a SYNC_REFRESH request first.
      */
     private void sendESyncRefreshRequired( LdapSession session, SearchRequest req ) throws Exception
     {