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 2011/11/13 00:55:25 UTC

svn commit: r1201360 [2/2] - in /directory/apacheds/branches/apacheds-osgi: kerberos-codec/ kerberos-codec/src/main/java/org/apache/directory/server/ kerberos-codec/src/main/java/org/apache/directory/server/kerberos/protocol/codec/ kerberos-codec/src/m...

Modified: directory/apacheds/branches/apacheds-osgi/service-builder/src/main/java/org/apache/directory/server/config/builder/ServiceBuilder.java
URL: http://svn.apache.org/viewvc/directory/apacheds/branches/apacheds-osgi/service-builder/src/main/java/org/apache/directory/server/config/builder/ServiceBuilder.java?rev=1201360&r1=1201359&r2=1201360&view=diff
==============================================================================
--- directory/apacheds/branches/apacheds-osgi/service-builder/src/main/java/org/apache/directory/server/config/builder/ServiceBuilder.java (original)
+++ directory/apacheds/branches/apacheds-osgi/service-builder/src/main/java/org/apache/directory/server/config/builder/ServiceBuilder.java Sat Nov 12 23:55:24 2011
@@ -346,8 +346,8 @@ public class ServiceBuilder
 
     /**
      * Load the entries from a Ldif file recursively
-     * @throws LdapLdifException 
-     * @throws IOException 
+     * @throws LdapLdifException
+     * @throws IOException
      */
     private static void loadEntries( File ldifFile, List<LdifEntry> entries ) throws LdapLdifException, IOException
     {
@@ -460,7 +460,7 @@ public class ServiceBuilder
             
             try
             {
-                Class authnImplClass = Class.forName( fqcn );
+                Class<?> authnImplClass = Class.forName( fqcn );
                 authenticator = ( Authenticator ) authnImplClass.newInstance();
             }
             catch( Exception e )
@@ -509,7 +509,7 @@ public class ServiceBuilder
 
     
     /**
-     * Creates the array of transports read from the DIT 
+     * Creates the array of transports read from the DIT
      * 
      * @param transportBeans The array of Transport configuration
      * @return An arry of Transport instance
@@ -528,7 +528,7 @@ public class ServiceBuilder
     }
 
     /**
-     * Creates the array of transports read from the DIT 
+     * Creates the array of transports read from the DIT
      * 
      * @param transportBeans The array of Transport configuration
      * @return An arry of Transport instance
@@ -569,7 +569,7 @@ public class ServiceBuilder
     }
 
     /**
-     * Instantiates a NtpServer based on the configuration present in the partition 
+     * Instantiates a NtpServer based on the configuration present in the partition
      *
      * @param ntpServerBean The NtpServerBean containing the NtpServer configuration
      * @return Instance of NtpServer
@@ -597,7 +597,7 @@ public class ServiceBuilder
 
 
     /**
-     * Instantiates a DhcpServer based on the configuration present in the partition 
+     * Instantiates a DhcpServer based on the configuration present in the partition
      *
      * @param dhcpServerBean The DhcpServerBean containing the DhcpServer configuration
      * @return Instance of DhcpServer
@@ -625,7 +625,7 @@ public class ServiceBuilder
 
 
     /**
-     * Instantiates a KdcServer based on the configuration present in the partition 
+     * Instantiates a KdcServer based on the configuration present in the partition
      *
      * @param kdcServerBean The KdcServerBean containing the KdcServer configuration
      * @return Instance of KdcServer
@@ -655,7 +655,7 @@ public class ServiceBuilder
         // BodyChecksumVerified
         kdcServer.setBodyChecksumVerified( kdcServerBean.isKrbBodyChecksumVerified() );
         
-        // CatalogBased 
+        // CatalogBased
         //kdcServer.setCatelogBased( kdcServerBean.is );
         
         // EmptyAddressesAllowed
@@ -704,7 +704,7 @@ public class ServiceBuilder
     
     
     /**
-     * Instantiates the HttpWebApps based on the configuration present in the partition 
+     * Instantiates the HttpWebApps based on the configuration present in the partition
      *
      * @param httpWebAppBeans The list of HttpWebAppBeans containing the HttpWebAppBeans configuration
      * @return Instances of HttpWebAppBean
@@ -742,7 +742,7 @@ public class ServiceBuilder
     
     
     /**
-     * Instantiates a HttpServer based on the configuration present in the partition 
+     * Instantiates a HttpServer based on the configuration present in the partition
      *
      * @param httpServerBean The HttpServerBean containing the HttpServer configuration
      * @return Instance of LdapServer
@@ -799,7 +799,7 @@ public class ServiceBuilder
     
     
     /**
-     * Instantiates a ChangePasswordServer based on the configuration present in the partition 
+     * Instantiates a ChangePasswordServer based on the configuration present in the partition
      *
      * @param ldapServerBean The ChangePasswordServerBean containing the ChangePasswordServer configuration
      * @return Instance of ChangePasswordServer
@@ -861,7 +861,7 @@ public class ServiceBuilder
     */
     
     /**
-     * Instantiates a LdapServer based on the configuration present in the partition 
+     * Instantiates a LdapServer based on the configuration present in the partition
      *
      * @param ldapServerBean The LdapServerBean containing the LdapServer configuration
      * @return Instance of LdapServer
@@ -937,7 +937,7 @@ public class ServiceBuilder
                 }
                 catch ( Exception e )
                 {
-                    String message = "Failed to load and instantiate ExtendedOperationHandler implementation " 
+                    String message = "Failed to load and instantiate ExtendedOperationHandler implementation "
                         + extendedpHandlerBean.getExtendedOpId() + ": " + e.getMessage();
                     LOG.error( message );
                     throw new ConfigurationException( message );
@@ -999,7 +999,7 @@ public class ServiceBuilder
             {
                 if( className == null )
                 {
-                    consumerClass = ReplicationConsumerImpl.class; 
+                    consumerClass = ReplicationConsumerImpl.class;
                 }
                 else
                 {
@@ -1129,7 +1129,7 @@ public class ServiceBuilder
      * 
      * @param jdbmPartitionBean the JdbmPartition bean
      * @return The instantiated JdbmPartition
-     * @throws LdapInvalidDnException 
+     * @throws LdapInvalidDnException
      * @throws Exception If the instance cannot be created
      */
     public static JdbmPartition createJdbmPartition( DirectoryService directoryService, JdbmPartitionBean jdbmPartitionBean ) throws ConfigurationException
@@ -1176,7 +1176,7 @@ public class ServiceBuilder
                 
                 if ( ( entries != null ) && ( entries.size() > 0 ) )
                 {
-                    LdifEntry entry = entries.get( 0 );
+                    entries.get( 0 );
                 }
             }
             catch ( LdapLdifException lle )
@@ -1246,12 +1246,12 @@ public class ServiceBuilder
 
     
     /**
-     * Instantiates a DirectoryService based on the configuration present in the partition 
+     * Instantiates a DirectoryService based on the configuration present in the partition
      *
      * @param directoryServiceBean The bean containing the configuration
-     * @param baseDirectory The working path for this DirectoryService 
+     * @param baseDirectory The working path for this DirectoryService
      * @return An instance of DirectoryService
-     * @throws Exception 
+     * @throws Exception
      */
     public static DirectoryService createDirectoryService( DirectoryServiceBean directoryServiceBean, InstanceLayout instanceLayout, SchemaManager schemaManager ) throws Exception
     {
@@ -1313,8 +1313,6 @@ public class ServiceBuilder
             directoryService.setJournal( journal );
         }
         
-        AuthenticationInterceptor authenticationInterceptor = (AuthenticationInterceptor)directoryService.getInterceptor( AuthenticationInterceptor.class.getSimpleName() );
-
         // MaxPDUSize
         directoryService.setMaxPDUSize( directoryServiceBean.getDsMaxPDUSize() );
         

Propchange: directory/apacheds/branches/apacheds-osgi/service-osgi/
------------------------------------------------------------------------------
--- svn:mergeinfo (added)
+++ svn:mergeinfo Sat Nov 12 23:55:24 2011
@@ -0,0 +1,10 @@
+/directory/apacheds/branches/apacheds-codec-merge/service-osgi:982369-987590
+/directory/apacheds/branches/apacheds-config/service-osgi:1023442-1029077
+/directory/apacheds/branches/apacheds-kerberos-codec-2.0/service-osgi:1040956-1043765
+/directory/apacheds/branches/apacheds-replication/service-osgi:749790-764110
+/directory/apacheds/branches/apacheds-schema/service-osgi:806623-896441
+/directory/apacheds/branches/apacheds-subtree/service-osgi:965203-965686
+/directory/apacheds/branches/milestones/service-osgi:1072812-1075328
+/directory/apacheds/branches/xdbm-refactoring/service-osgi:945827-946347
+/directory/apacheds/trunk/service-osgi:1066126-1067785,1068026-1072718,1072800-1075329,1185681-1201348
+/directory/studio/trunk/service-osgi:1067786-1067997

Modified: directory/apacheds/branches/apacheds-osgi/service/pom.xml
URL: http://svn.apache.org/viewvc/directory/apacheds/branches/apacheds-osgi/service/pom.xml?rev=1201360&r1=1201359&r2=1201360&view=diff
==============================================================================
--- directory/apacheds/branches/apacheds-osgi/service/pom.xml (original)
+++ directory/apacheds/branches/apacheds-osgi/service/pom.xml Sat Nov 12 23:55:24 2011
@@ -52,7 +52,6 @@
     <dependency>
       <groupId>org.apache.directory.shared</groupId>
       <artifactId>shared-ldap-codec-standalone</artifactId>
-      <scope>test</scope>
     </dependency>
     
     <dependency>

Propchange: directory/apacheds/branches/apacheds-osgi/test-framework/
------------------------------------------------------------------------------
--- svn:mergeinfo (original)
+++ svn:mergeinfo Sat Nov 12 23:55:24 2011
@@ -9,5 +9,5 @@
 /directory/apacheds/branches/apacheds-subtree/test-framework:965203-965686
 /directory/apacheds/branches/milestones/test-framework:1072812-1075328
 /directory/apacheds/branches/xdbm-refactoring/test-framework:945827-946347
-/directory/apacheds/trunk/test-framework:1066126-1067785,1068026-1072718,1072800-1075329,1185682-1188093,1188104-1197059
+/directory/apacheds/trunk/test-framework:1066126-1067785,1068026-1072718,1072800-1075329,1185681-1201348
 /directory/studio/trunk/test-framework:1067786-1067997

Propchange: directory/apacheds/branches/apacheds-osgi/xdbm-partition/
------------------------------------------------------------------------------
--- svn:mergeinfo (original)
+++ svn:mergeinfo Sat Nov 12 23:55:24 2011
@@ -4,5 +4,5 @@
 /directory/apacheds/branches/apacheds-jdbm/xdbm-partition:1160768-1164092
 /directory/apacheds/branches/apacheds-kerberos-codec-2.0/xdbm-partition:1040956-1043765
 /directory/apacheds/branches/milestones/xdbm-partition:1072812-1075328
-/directory/apacheds/trunk/xdbm-partition:1066126-1067785,1068026-1072718,1072800-1075329,1185682-1188093,1188104-1197059
+/directory/apacheds/trunk/xdbm-partition:1066126-1067785,1068026-1072718,1072800-1075329,1185681-1201348
 /directory/studio/trunk/xdbm-partition:1067786-1067997

Modified: directory/apacheds/branches/apacheds-osgi/xdbm-partition/src/main/java/org/apache/directory/server/core/partition/impl/btree/AbstractBTreePartition.java
URL: http://svn.apache.org/viewvc/directory/apacheds/branches/apacheds-osgi/xdbm-partition/src/main/java/org/apache/directory/server/core/partition/impl/btree/AbstractBTreePartition.java?rev=1201360&r1=1201359&r2=1201360&view=diff
==============================================================================
--- directory/apacheds/branches/apacheds-osgi/xdbm-partition/src/main/java/org/apache/directory/server/core/partition/impl/btree/AbstractBTreePartition.java (original)
+++ directory/apacheds/branches/apacheds-osgi/xdbm-partition/src/main/java/org/apache/directory/server/core/partition/impl/btree/AbstractBTreePartition.java Sat Nov 12 23:55:24 2011
@@ -41,7 +41,7 @@ import org.apache.directory.server.core.
 import org.apache.directory.server.core.api.interceptor.context.AddOperationContext;
 import org.apache.directory.server.core.api.interceptor.context.BindOperationContext;
 import org.apache.directory.server.core.api.interceptor.context.DeleteOperationContext;
-import org.apache.directory.server.core.api.interceptor.context.EntryOperationContext;
+import org.apache.directory.server.core.api.interceptor.context.HasEntryOperationContext;
 import org.apache.directory.server.core.api.interceptor.context.ListOperationContext;
 import org.apache.directory.server.core.api.interceptor.context.LookupOperationContext;
 import org.apache.directory.server.core.api.interceptor.context.ModifyOperationContext;
@@ -1799,7 +1799,7 @@ public abstract class AbstractBTreeParti
      * if it returns an entry by default.  Please override this method if
      * there is more effective way for your implementation.
      */
-    public boolean hasEntry( EntryOperationContext entryContext ) throws LdapException
+    public boolean hasEntry( HasEntryOperationContext entryContext ) throws LdapException
     {
         try
         {

Modified: directory/apacheds/branches/apacheds-osgi/xdbm-partition/src/main/java/org/apache/directory/server/log/impl/LogFlushManager.java
URL: http://svn.apache.org/viewvc/directory/apacheds/branches/apacheds-osgi/xdbm-partition/src/main/java/org/apache/directory/server/log/impl/LogFlushManager.java?rev=1201360&r1=1201359&r2=1201360&view=diff
==============================================================================
--- directory/apacheds/branches/apacheds-osgi/xdbm-partition/src/main/java/org/apache/directory/server/log/impl/LogFlushManager.java (original)
+++ directory/apacheds/branches/apacheds-osgi/xdbm-partition/src/main/java/org/apache/directory/server/log/impl/LogFlushManager.java Sat Nov 12 23:55:24 2011
@@ -35,11 +35,11 @@ import org.apache.directory.server.log.L
 import org.apache.directory.server.log.UserLogRecord;
 
 /**
- * Manages the flushing of log to media and scanning of logs. All appends to the log file go through this class. 
+ * Manages the flushing of log to media and scanning of logs. All appends to the log file go through this class.
  *
- * Internally it manages a circular  buffer where appends initially go. Appends are first 
+ * Internally it manages a circular  buffer where appends initially go. Appends are first
  * appended to this in memory circular log. As the in memory circular log fills up or as the user requests
- *  memory buffer is flushed to the underlying media.  
+ *  memory buffer is flushed to the underlying media.
  *
  * @author <a href="mailto:dev@directory.apache.org">Apache Directory Project</a>
  */
@@ -65,7 +65,7 @@ class LogFlushManager
     private LogBuffer logBuffer;
     
     /** Flush status */
-    private FlushStatus flushStatus = new FlushStatus(); 
+    private FlushStatus flushStatus = new FlushStatus();
        
     /** Current LogFile appends go to */
     private LogFileManager.LogFileWriter currentLogFile;
@@ -109,7 +109,7 @@ class LogFlushManager
         boolean appendedRecord = false;
         byte[] userBuffer = userRecord.getDataBuffer();
         int length  = userRecord.getDataLength();
-        LogAnchor userLogAnchor = userRecord.getLogAnchor(); 
+        LogAnchor userLogAnchor = userRecord.getLogAnchor();
         
         int recordSize = LogFileRecords.RECORD_HEADER_SIZE + LogFileRecords.RECORD_FOOTER_SIZE + length;
         
@@ -142,10 +142,10 @@ class LogFlushManager
                 {
                     // First get the rewind count then the position to which the readhead advanced
                     int readHeadRewindCount = logBuffer.readHeadRewindCount.get();
-                    int readHeadPosition = logBuffer.readHeadPosition;                
+                    int readHeadPosition = logBuffer.readHeadPosition;
                     
-                    if ( ( logBuffer.writeHeadRewindCount == readHeadRewindCount ) || 
-                        ( ( logBuffer.writeHeadRewindCount == readHeadRewindCount + 1 ) && 
+                    if ( ( logBuffer.writeHeadRewindCount == readHeadRewindCount ) ||
+                        ( ( logBuffer.writeHeadRewindCount == readHeadRewindCount + 1 ) &&
                             ( readHeadPosition < writeHead.position() ) ) )
                     {
                         if ( writeHead.remaining() >= recordSize )
@@ -168,9 +168,9 @@ class LogFlushManager
                             logBuffer.writeHeadRewindCount++;
                         }
                     }
-                    else 
+                    else
                     {
-                        assert( logBuffer.writeHeadRewindCount == ( readHeadRewindCount + 1 ) ) : 
+                        assert( logBuffer.writeHeadRewindCount == ( readHeadRewindCount + 1 ) ) :
                                 "Unexpected sequence number for read/write heads:" + logBuffer.writeHeadRewindCount +
                                 " " + readHeadRewindCount;
                         
@@ -190,7 +190,7 @@ class LogFlushManager
                 
             }
             else
-            {   
+            {
                 this.flush( lsn, userBuffer, 0, length, true );
             }
             
@@ -223,10 +223,10 @@ class LogFlushManager
      * and is woken up to do its flush.
      * 
      * flushStatus.uptoLSN represents the highest lsn that any thread wanted to sync. If a couple of threads wait on sync to
-     * complete, the thread that wakes up and does the sync will take it for the team and sync upto flushStatus.uptoLSN so 
+     * complete, the thread that wakes up and does the sync will take it for the team and sync upto flushStatus.uptoLSN so
      * that logging is more efficient.
      * 
-     *  
+     * 
      *
      * @param flushLSN max LSN the calling thread wants to sync upto
      * @param userBuffer if not null, user buffer is appended to the log without any buffering
@@ -235,9 +235,9 @@ class LogFlushManager
      * @param appendLockHeld true if append lock is held
      * @throws IOException
      */
-    private void flush( long flushLSN, byte[] userBuffer, int offset, int length, 
+    private void flush( long flushLSN, byte[] userBuffer, int offset, int length,
                         boolean appendLockHeld ) throws IOException
-    {    
+    {
         long uptoLSN = flushLSN;
        
         if ( appendLockHeld == true )
@@ -264,7 +264,7 @@ class LogFlushManager
             {
                 flushLock.unlock();
                 return;
-            }      
+            }
             
             if ( flushStatus.flushInProgress == false )
             {
@@ -293,7 +293,7 @@ class LogFlushManager
         
         long flushedLSN = this.doFlush( uptoLSN, appendLockHeld );
         
-        // Now if there is a user buffer, flush from that        
+        // Now if there is a user buffer, flush from that
         if ( userBuffer != null )
         {
             ByteBuffer headerFooterHead = logBuffer.headerFooterHead;
@@ -302,7 +302,7 @@ class LogFlushManager
             this.writeHeader( headerFooterHead, length, flushLSN );
             currentLogFile.append( logBuffer.headerFooterBuffer, 0, LogFileRecords.RECORD_HEADER_MAGIC_NUMBER );
             
-            currentLogFile.append( userBuffer, offset, length );   
+            currentLogFile.append( userBuffer, offset, length );
             
             headerFooterHead.rewind();
             this.writeFooter( headerFooterHead, 0 );
@@ -383,8 +383,8 @@ class LogFlushManager
                 magicNumber = readHead.getInt();
                 
                 assert( magicNumber == LogFileRecords.RECORD_HEADER_MAGIC_NUMBER ) : " Record header magic " +
-                		"number does not match " + magicNumber + " expected "+ 
-                		LogFileRecords.RECORD_HEADER_MAGIC_NUMBER;
+                        "number does not match " + magicNumber + " expected "+
+                        LogFileRecords.RECORD_HEADER_MAGIC_NUMBER;
                 
                 length = readHead.getInt();
                 
@@ -417,10 +417,10 @@ class LogFlushManager
             // If there is something to flush, then do it now
             if ( totalLength > 0 )
             {
-                int offset;                 
+                int offset;
                 offset = logBuffer.readHeadPosition;
                 
-                currentLogFile.append( logBuffer.buffer, offset, totalLength );            
+                currentLogFile.append( logBuffer.buffer, offset, totalLength );
                        
                 //move the position to the next record
                 logBuffer.readHeadPosition = readHead.position();
@@ -444,7 +444,7 @@ class LogFlushManager
         buffer.putInt( LogFileRecords.RECORD_HEADER_MAGIC_NUMBER );
         buffer.putInt( length );
         buffer.putLong( lsn );
-        buffer.putLong( length ^ lsn ); 
+        buffer.putLong( length ^ lsn );
     }
     
     private void writeFooter ( ByteBuffer buffer, int checksum )
@@ -455,10 +455,10 @@ class LogFlushManager
     
     
     /**
-     * Used to group the memory buffer data together 
+     * Used to group the memory buffer data together
      */
     private static class LogBuffer
-    {        
+    {
         /** In memory buffer */
         byte buffer[];
                 

Propchange: directory/apacheds/branches/apacheds-osgi/xdbm-tools/
------------------------------------------------------------------------------
--- svn:mergeinfo (original)
+++ svn:mergeinfo Sat Nov 12 23:55:24 2011
@@ -4,5 +4,5 @@
 /directory/apacheds/branches/apacheds-jdbm/xdbm-tools:1160768-1164092
 /directory/apacheds/branches/apacheds-kerberos-codec-2.0/xdbm-tools:1040956-1043765
 /directory/apacheds/branches/milestones/xdbm-tools:1072812-1075328
-/directory/apacheds/trunk/xdbm-tools:1066126-1067785,1068026-1072718,1072800-1075329,1185682-1188093,1188104-1197059
+/directory/apacheds/trunk/xdbm-tools:1066126-1067785,1068026-1072718,1072800-1075329,1185681-1201348
 /directory/studio/trunk/xdbm-tools:1067786-1067997