You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@manifoldcf.apache.org by kw...@apache.org on 2010/08/23 20:08:42 UTC

svn commit: r988237 [22/24] - in /incubator/lcf/trunk: modules/connectors/activedirectory/connector/org/apache/acf/authorities/authorities/activedirectory/ modules/connectors/documentum/connector/org/apache/acf/crawler/authorities/DCTM/ modules/connect...

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/CrawlerAgent.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/CrawlerAgent.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/CrawlerAgent.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/CrawlerAgent.java Mon Aug 23 18:08:32 2010
@@ -34,7 +34,7 @@ public class CrawlerAgent implements IAg
   *@param threadContext is the thread context.
   */
   public CrawlerAgent(IThreadContext threadContext)
-    throws LCFException
+    throws ACFException
   {
     this.threadContext = threadContext;
   }
@@ -42,38 +42,38 @@ public class CrawlerAgent implements IAg
   /** Install agent.  This usually installs the agent's database tables etc.
   */
   public void install()
-    throws LCFException
+    throws ACFException
   {
     // Install the system tables for the crawler.
-    LCF.initializeEnvironment();
-    LCF.installSystemTables(threadContext);
+    ACF.initializeEnvironment();
+    ACF.installSystemTables(threadContext);
   }
 
   /** Uninstall agent.  This must clean up everything the agent is responsible for.
   */
   public void deinstall()
-    throws LCFException
+    throws ACFException
   {
-    LCF.initializeEnvironment();
-    LCF.deinstallSystemTables(threadContext);
+    ACF.initializeEnvironment();
+    ACF.deinstallSystemTables(threadContext);
   }
 
   /** Start the agent.  This method should spin up the agent threads, and
   * then return.
   */
   public void startAgent()
-    throws LCFException
+    throws ACFException
   {
-    LCF.initializeEnvironment();
-    LCF.startSystem(threadContext);
+    ACF.initializeEnvironment();
+    ACF.startSystem(threadContext);
   }
 
   /** Stop the agent.  This should shut down the agent threads.
   */
   public void stopAgent()
-    throws LCFException
+    throws ACFException
   {
-    LCF.stopSystem(threadContext);
+    ACF.stopSystem(threadContext);
   }
 
   /** Request permission from agent to delete an output connection.
@@ -81,36 +81,36 @@ public class CrawlerAgent implements IAg
   *@return true if the connection is in use, false otherwise.
   */
   public boolean isOutputConnectionInUse(String connName)
-    throws LCFException
+    throws ACFException
   {
-    return LCF.isOutputConnectionInUse(threadContext,connName);
+    return ACF.isOutputConnectionInUse(threadContext,connName);
   }
 
   /** Note the deregistration of a set of output connections.
   *@param connectionNames are the names of the connections being deregistered.
   */
   public void noteOutputConnectorDeregistration(String[] connectionNames)
-    throws LCFException
+    throws ACFException
   {
-    LCF.noteOutputConnectorDeregistration(threadContext,connectionNames);
+    ACF.noteOutputConnectorDeregistration(threadContext,connectionNames);
   }
 
   /** Note the registration of a set of output connections.
   *@param connectionNames are the names of the connections being registered.
   */
   public void noteOutputConnectorRegistration(String[] connectionNames)
-    throws LCFException
+    throws ACFException
   {
-    LCF.noteOutputConnectorRegistration(threadContext,connectionNames);
+    ACF.noteOutputConnectorRegistration(threadContext,connectionNames);
   }
 
   /** Note a change in configuration for an output connection.
   *@param connectionName is the name of the connections being changed.
   */
   public void noteOutputConnectionChange(String connectionName)
-    throws LCFException
+    throws ACFException
   {
-    LCF.noteOutputConnectionChange(threadContext,connectionName);
+    ACF.noteOutputConnectionChange(threadContext,connectionName);
   }
 
   /** Signal that an output connection needs to be "redone".  This means that all documents sent to that output connection must be sent again,
@@ -118,9 +118,9 @@ public class CrawlerAgent implements IAg
   *@param connectionName is the name of the connection being signalled.
   */
   public void signalOutputConnectionRedo(String connectionName)
-    throws LCFException
+    throws ACFException
   {
-    LCF.signalOutputConnectionRedo(threadContext,connectionName);
+    ACF.signalOutputConnectionRedo(threadContext,connectionName);
   }
 
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/DocDeleteResetManager.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/DocDeleteResetManager.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/DocDeleteResetManager.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/DocDeleteResetManager.java Mon Aug 23 18:08:32 2010
@@ -42,7 +42,7 @@ public class DocDeleteResetManager exten
 
   /** Reset */
   protected void performResetLogic(IThreadContext tc)
-    throws LCFException
+    throws ACFException
   {
     IJobManager jobManager = JobManagerFactory.make(tc);
     jobManager.resetDocDeleteWorkerStatus();

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/DocumentDeleteStufferThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/DocumentDeleteStufferThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/DocumentDeleteStufferThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/DocumentDeleteStufferThread.java Mon Aug 23 18:08:32 2010
@@ -48,7 +48,7 @@ public class DocumentDeleteStufferThread
   *@param n is the maximum number of threads that will be doing delete processing.
   */
   public DocumentDeleteStufferThread(DocumentDeleteQueue documentDeleteQueue, int n, DocDeleteResetManager resetManager)
-    throws LCFException
+    throws ACFException
   {
     super();
     this.documentDeleteQueue = documentDeleteQueue;
@@ -72,9 +72,9 @@ public class DocumentDeleteStufferThread
       ArrayList docList = new ArrayList();
 
       IDBInterface database = DBInterfaceFactory.make(threadContext,
-        LCF.getMasterDatabaseName(),
-        LCF.getMasterDatabaseUsername(),
-        LCF.getMasterDatabasePassword());
+        ACF.getMasterDatabaseName(),
+        ACF.getMasterDatabaseUsername(),
+        ACF.getMasterDatabasePassword());
 
       int deleteChunkSize = database.getMaxInClause();
 
@@ -90,7 +90,7 @@ public class DocumentDeleteStufferThread
           // can run out of work if we don't act).
           if (documentDeleteQueue.checkIfEmpty(n) == false)
           {
-            LCF.sleep(100L);
+            ACF.sleep(100L);
             continue;
           }
 
@@ -107,7 +107,7 @@ public class DocumentDeleteStufferThread
           if (descs.length == 0)
           {
             Logging.threads.debug("Document delete stuffer thread found nothing to do");
-            LCF.sleep(1000L);       // 1 second
+            ACF.sleep(1000L);       // 1 second
             continue;
           }
 
@@ -128,12 +128,12 @@ public class DocumentDeleteStufferThread
           // If we don't wait here, the other threads don't have a chance to queue anything else up.
           yield();
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             break;
 
-          if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+          if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
           {
             resetManager.noteEvent();
             documentDeleteQueue.reset();
@@ -142,7 +142,7 @@ public class DocumentDeleteStufferThread
             try
             {
               // Give the database a chance to catch up/wake up
-              LCF.sleep(10000L);
+              ACF.sleep(10000L);
             }
             catch (InterruptedException se)
             {
@@ -154,7 +154,7 @@ public class DocumentDeleteStufferThread
           // Log it, but keep the thread alive
           Logging.threads.error("Exception tossed: "+e.getMessage(),e);
 
-          if (e.getErrorCode() == LCFException.SETUP_ERROR)
+          if (e.getErrorCode() == ACFException.SETUP_ERROR)
           {
             // Shut the whole system down!
             System.exit(1);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/DocumentDeleteThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/DocumentDeleteThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/DocumentDeleteThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/DocumentDeleteThread.java Mon Aug 23 18:08:32 2010
@@ -54,7 +54,7 @@ public class DocumentDeleteThread extend
   *@param id is the worker thread id.
   */
   public DocumentDeleteThread(String id, DocumentDeleteQueue documentDeleteQueue, DocDeleteResetManager resetManager)
-    throws LCFException
+    throws ACFException
   {
     super();
     this.id = id;
@@ -187,7 +187,7 @@ public class DocumentDeleteThread extend
                     long waittime = amt-now;
                     if (waittime <= 0L)
                       waittime = 300000L;
-                    LCF.sleep(waittime);
+                    ACF.sleep(waittime);
                   }
                 }
 
@@ -233,12 +233,12 @@ public class DocumentDeleteThread extend
             }
           }
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             break;
 
-          if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+          if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
           {
             resetManager.noteEvent();
             documentDeleteQueue.reset();
@@ -247,7 +247,7 @@ public class DocumentDeleteThread extend
             try
             {
               // Give the database a chance to catch up/wake up
-              LCF.sleep(10000L);
+              ACF.sleep(10000L);
             }
             catch (InterruptedException se)
             {
@@ -259,7 +259,7 @@ public class DocumentDeleteThread extend
           // Log it, but keep the thread alive
           Logging.threads.error("Exception tossed: "+e.getMessage(),e);
 
-          if (e.getErrorCode() == LCFException.SETUP_ERROR)
+          if (e.getErrorCode() == ACFException.SETUP_ERROR)
           {
             // Shut the whole system down!
             System.exit(1);
@@ -328,9 +328,9 @@ public class DocumentDeleteThread extend
     */
     public void recordActivity(Long startTime, String activityType, Long dataSize,
       String entityURI, String resultCode, String resultDescription)
-      throws LCFException
+      throws ACFException
     {
-      connMgr.recordHistory(connectionName,startTime,LCF.qualifyOutputActivityName(activityType,outputConnectionName),dataSize,entityURI,resultCode,
+      connMgr.recordHistory(connectionName,startTime,ACF.qualifyOutputActivityName(activityType,outputConnectionName),dataSize,entityURI,resultCode,
         resultDescription,null);
     }
   }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/ExpireStufferThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/ExpireStufferThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/ExpireStufferThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/ExpireStufferThread.java Mon Aug 23 18:08:32 2010
@@ -46,7 +46,7 @@ public class ExpireStufferThread extends
   * number of documents to be done at once!
   */
   public ExpireStufferThread(DocumentDeleteQueue documentQueue, int n, WorkerResetManager resetManager)
-    throws LCFException
+    throws ACFException
   {
     super();
     this.documentQueue = documentQueue;
@@ -82,9 +82,9 @@ public class ExpireStufferThread extends
       HashMap jobDescriptionMap = new HashMap();
 
       IDBInterface database = DBInterfaceFactory.make(threadContext,
-        LCF.getMasterDatabaseName(),
-        LCF.getMasterDatabaseUsername(),
-        LCF.getMasterDatabasePassword());
+        ACF.getMasterDatabaseName(),
+        ACF.getMasterDatabaseUsername(),
+        ACF.getMasterDatabasePassword());
 
       int deleteChunkSize = database.getMaxInClause();
 
@@ -95,7 +95,7 @@ public class ExpireStufferThread extends
         try
         {
           if (Thread.currentThread().isInterrupted())
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
 
           // Check if we're okay
           resetManager.waitForReset(threadContext);
@@ -118,7 +118,7 @@ public class ExpireStufferThread extends
           DocumentDescription[] descs = jobManager.getExpiredDocuments(deleteChunkSize,currentTime);
 
           if (Thread.currentThread().isInterrupted())
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
 
           if (Logging.threads.isDebugEnabled())
           {
@@ -129,7 +129,7 @@ public class ExpireStufferThread extends
           // The theory is that we need to allow stuff to accumulate.
           if (descs.length == 0)
           {
-            LCF.sleep(60000L);      // 1 minute
+            ACF.sleep(60000L);      // 1 minute
             continue;
           }
 
@@ -145,14 +145,14 @@ public class ExpireStufferThread extends
           documentQueue.addDocuments(set);
 
           // If we don't wait here, the other threads don't seem to have a chance to queue anything else up.
-          LCF.sleep(1000L);
+          ACF.sleep(1000L);
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             break;
 
-          if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+          if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
           {
             resetManager.noteEvent();
             documentQueue.reset();
@@ -161,7 +161,7 @@ public class ExpireStufferThread extends
             try
             {
               // Give the database a chance to catch up/wake up
-              LCF.sleep(10000L);
+              ACF.sleep(10000L);
             }
             catch (InterruptedException se)
             {
@@ -173,7 +173,7 @@ public class ExpireStufferThread extends
           // Log it, but keep the thread alive
           Logging.threads.error("Exception tossed: "+e.getMessage(),e);
 
-          if (e.getErrorCode() == LCFException.SETUP_ERROR)
+          if (e.getErrorCode() == ACFException.SETUP_ERROR)
           {
             System.exit(1);
           }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/ExpireThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/ExpireThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/ExpireThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/ExpireThread.java Mon Aug 23 18:08:32 2010
@@ -45,7 +45,7 @@ public class ExpireThread extends Thread
   *@param id is the expire thread id.
   */
   public ExpireThread(String id, DocumentDeleteQueue documentQueue, QueueTracker queueTracker, WorkerResetManager resetManager)
-    throws LCFException
+    throws ACFException
   {
     super();
     this.id = id;
@@ -77,7 +77,7 @@ public class ExpireThread extends Thread
         try
         {
           if (Thread.currentThread().isInterrupted())
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
 
           // Before we begin, conditionally reset
           resetManager.waitForReset(threadContext);
@@ -92,7 +92,7 @@ public class ExpireThread extends Thread
             continue;
 
           if (Thread.currentThread().isInterrupted())
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
 
           try
           {
@@ -223,7 +223,7 @@ public class ExpireThread extends Thread
                         long waittime = amt-now;
                         if (waittime <= 0L)
                           waittime = 300000L;
-                        LCF.sleep(waittime);
+                        ACF.sleep(waittime);
                       }
                     }
 
@@ -242,7 +242,7 @@ public class ExpireThread extends Thread
                       String[] legalLinkTypes = (String[])arrayRelationshipTypes.get(index);
                       DocumentDescription[] requeueCandidates = jobManager.markDocumentDeleted(jobID,legalLinkTypes,ddd,hopcountMethod);
                       // Use the common method for doing the requeuing
-                      LCF.requeueDocumentsDueToCarrydown(jobManager,requeueCandidates,
+                      ACF.requeueDocumentsDueToCarrydown(jobManager,requeueCandidates,
                         connector,connection,queueTracker,currentTime);
                       // Finally, completed expiration of the document.
                       dqd.setProcessed();
@@ -256,9 +256,9 @@ public class ExpireThread extends Thread
                   RepositoryConnectorFactory.release(connector);
                 }
               }
-              catch (LCFException e)
+              catch (ACFException e)
               {
-                if (e.getErrorCode() == LCFException.REPOSITORY_CONNECTION_ERROR)
+                if (e.getErrorCode() == ACFException.REPOSITORY_CONNECTION_ERROR)
                 {
                   // This error can only come from grabbing the connections.  So, if this occurs it means that
                   // all the documents we've been handed have to be stuffed back onto the queue for processing at a later time.
@@ -271,12 +271,12 @@ public class ExpireThread extends Thread
               }
             }
           }
-          catch (LCFException e)
+          catch (ACFException e)
           {
-            if (e.getErrorCode() == LCFException.INTERRUPTED)
+            if (e.getErrorCode() == ACFException.INTERRUPTED)
               break;
 
-            if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+            if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
               throw e;
 
             Logging.threads.error("Exception tossed: "+e.getMessage(),e);
@@ -299,12 +299,12 @@ public class ExpireThread extends Thread
             }
           }
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             break;
 
-          if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+          if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
           {
             // Note the failure, which will cause a reset to occur
             resetManager.noteEvent();
@@ -315,7 +315,7 @@ public class ExpireThread extends Thread
             try
             {
               // Give the database a chance to catch up/wake up
-              LCF.sleep(10000L);
+              ACF.sleep(10000L);
             }
             catch (InterruptedException se)
             {
@@ -393,9 +393,9 @@ public class ExpireThread extends Thread
     */
     public void recordActivity(Long startTime, String activityType, Long dataSize,
       String entityURI, String resultCode, String resultDescription)
-      throws LCFException
+      throws ACFException
     {
-      connMgr.recordHistory(connectionName,startTime,LCF.qualifyOutputActivityName(activityType,outputConnectionName),dataSize,entityURI,resultCode,
+      connMgr.recordHistory(connectionName,startTime,ACF.qualifyOutputActivityName(activityType,outputConnectionName),dataSize,entityURI,resultCode,
         resultDescription,null);
     }
   }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/FinisherThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/FinisherThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/FinisherThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/FinisherThread.java Mon Aug 23 18:08:32 2010
@@ -36,7 +36,7 @@ public class FinisherThread extends Thre
   /** Constructor.
   */
   public FinisherThread()
-    throws LCFException
+    throws ACFException
   {
     super();
     setName("Finisher thread");
@@ -72,20 +72,20 @@ public class FinisherThread extends Thre
               desc.getID().toString()+"("+desc.getDescription()+")",null,null,null);
           }
           Logging.threads.debug("Done cleaning up completed jobs");
-          LCF.sleep(10000L);
+          ACF.sleep(10000L);
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             break;
 
-          if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+          if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
           {
             Logging.threads.error("Finisher thread aborting and restarting due to database connection reset: "+e.getMessage(),e);
             try
             {
               // Give the database a chance to catch up/wake up
-              LCF.sleep(10000L);
+              ACF.sleep(10000L);
             }
             catch (InterruptedException se)
             {
@@ -97,7 +97,7 @@ public class FinisherThread extends Thre
           // Log it, but keep the thread alive
           Logging.threads.error("Exception tossed: "+e.getMessage(),e);
 
-          if (e.getErrorCode() == LCFException.SETUP_ERROR)
+          if (e.getErrorCode() == ACFException.SETUP_ERROR)
           {
             // Shut the whole system down!
             System.exit(1);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/IdleCleanupThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/IdleCleanupThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/IdleCleanupThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/IdleCleanupThread.java Mon Aug 23 18:08:32 2010
@@ -38,7 +38,7 @@ public class IdleCleanupThread extends T
   /** Constructor.
   */
   public IdleCleanupThread()
-    throws LCFException
+    throws ACFException
   {
     super();
     setName("Idle cleanup thread");
@@ -64,20 +64,20 @@ public class IdleCleanupThread extends T
           OutputConnectorFactory.pollAllConnectors(threadContext);
 
           // Sleep for the retry interval.
-          LCF.sleep(15000L);
+          ACF.sleep(15000L);
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             break;
 
-          if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+          if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
           {
             Logging.threads.error("Idle cleanup thread aborting and restarting due to database connection reset: "+e.getMessage(),e);
             try
             {
               // Give the database a chance to catch up/wake up
-              LCF.sleep(10000L);
+              ACF.sleep(10000L);
             }
             catch (InterruptedException se)
             {
@@ -89,7 +89,7 @@ public class IdleCleanupThread extends T
           // Log it, but keep the thread alive
           Logging.threads.error("Exception tossed: "+e.getMessage(),e);
 
-          if (e.getErrorCode() == LCFException.SETUP_ERROR)
+          if (e.getErrorCode() == ACFException.SETUP_ERROR)
           {
             // Shut the whole system down!
             System.exit(1);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/JobDeleteThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/JobDeleteThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/JobDeleteThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/JobDeleteThread.java Mon Aug 23 18:08:32 2010
@@ -39,7 +39,7 @@ public class JobDeleteThread extends Thr
   /** Constructor.
   */
   public JobDeleteThread()
-    throws LCFException
+    throws ACFException
   {
     super();
     setName("Job delete thread");
@@ -72,20 +72,20 @@ public class JobDeleteThread extends Thr
           jobManager.deleteJobsReadyForDelete();
 
           // Sleep for the retry interval.
-          LCF.sleep(waitTime);
+          ACF.sleep(waitTime);
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             break;
 
-          if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+          if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
           {
             Logging.threads.error("Job delete thread aborting and restarting due to database connection reset: "+e.getMessage(),e);
             try
             {
               // Give the database a chance to catch up/wake up
-              LCF.sleep(10000L);
+              ACF.sleep(10000L);
             }
             catch (InterruptedException se)
             {
@@ -97,7 +97,7 @@ public class JobDeleteThread extends Thr
           // Log it, but keep the thread alive
           Logging.threads.error("Exception tossed: "+e.getMessage(),e);
 
-          if (e.getErrorCode() == LCFException.SETUP_ERROR)
+          if (e.getErrorCode() == ACFException.SETUP_ERROR)
           {
             // Shut the whole system down!
             System.exit(1);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/JobResetThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/JobResetThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/JobResetThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/JobResetThread.java Mon Aug 23 18:08:32 2010
@@ -38,7 +38,7 @@ public class JobResetThread extends Thre
   /** Constructor.
   */
   public JobResetThread(QueueTracker queueTracker)
-    throws LCFException
+    throws ACFException
   {
     super();
     setName("Job reset thread");
@@ -110,7 +110,7 @@ public class JobResetThread extends Thre
                   break;
 
                 // Calculate new priorities for all these documents
-                LCF.writeDocumentPriorities(threadContext,connectionManager,jobManager,docs,connectionMap,jobDescriptionMap,queueTracker,currentTime);
+                ACF.writeDocumentPriorities(threadContext,connectionManager,jobManager,docs,connectionMap,jobDescriptionMap,queueTracker,currentTime);
 
                 Logging.threads.debug("Reprioritized "+Integer.toString(docs.length)+" not-yet-processed documents in "+new Long(System.currentTimeMillis()-startTime)+" ms");
               }
@@ -124,20 +124,20 @@ public class JobResetThread extends Thre
 
           }
 
-          LCF.sleep(10000L);
+          ACF.sleep(10000L);
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             break;
 
-          if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+          if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
           {
             Logging.threads.error("Job reset thread aborting and restarting due to database connection reset: "+e.getMessage(),e);
             try
             {
               // Give the database a chance to catch up/wake up
-              LCF.sleep(10000L);
+              ACF.sleep(10000L);
             }
             catch (InterruptedException se)
             {
@@ -149,7 +149,7 @@ public class JobResetThread extends Thre
           // Log it, but keep the thread alive
           Logging.threads.error("Exception tossed: "+e.getMessage(),e);
 
-          if (e.getErrorCode() == LCFException.SETUP_ERROR)
+          if (e.getErrorCode() == ACFException.SETUP_ERROR)
           {
             // Shut the whole system down!
             System.exit(1);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/JobStartThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/JobStartThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/JobStartThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/JobStartThread.java Mon Aug 23 18:08:32 2010
@@ -33,7 +33,7 @@ public class JobStartThread extends Thre
   /** Constructor.
   */
   public JobStartThread()
-    throws LCFException
+    throws ACFException
   {
     super();
     setName("Job start thread");
@@ -89,20 +89,20 @@ public class JobStartThread extends Thre
               desc.getID().toString()+"("+desc.getDescription()+")",null,null,null);
           }
           // Loop around again, after resting a while
-          LCF.sleep(10000L);
+          ACF.sleep(10000L);
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             break;
 
-          if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+          if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
           {
             Logging.threads.error("Job start thread aborting and restarting due to database connection reset: "+e.getMessage(),e);
             try
             {
               // Give the database a chance to catch up/wake up
-              LCF.sleep(10000L);
+              ACF.sleep(10000L);
             }
             catch (InterruptedException se)
             {
@@ -114,7 +114,7 @@ public class JobStartThread extends Thre
           // Log it, but keep the thread alive
           Logging.threads.error("Exception tossed: "+e.getMessage(),e);
 
-          if (e.getErrorCode() == LCFException.SETUP_ERROR)
+          if (e.getErrorCode() == ACFException.SETUP_ERROR)
           {
             // Shut the whole system down!
             System.exit(1);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/ResetManager.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/ResetManager.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/ResetManager.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/ResetManager.java Mon Aug 23 18:08:32 2010
@@ -72,7 +72,7 @@ public abstract class ResetManager
   * @return false if no reset took place, or true if one did.
   */
   public synchronized boolean waitForReset(IThreadContext tc)
-    throws LCFException, InterruptedException
+    throws ACFException, InterruptedException
   {
     if (resetRequired == false)
       return false;
@@ -112,7 +112,7 @@ public abstract class ResetManager
   /** Do the reset logic.
   */
   protected abstract void performResetLogic(IThreadContext tc)
-    throws LCFException;
+    throws ACFException;
 
 
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/SeedingActivity.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/SeedingActivity.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/SeedingActivity.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/SeedingActivity.java Mon Aug 23 18:08:32 2010
@@ -86,7 +86,7 @@ public class SeedingActivity implements 
   *@param prereqEventNames is the list of prerequisite events required for this document, or null if none.
   */
   public void addSeedDocument(String documentIdentifier, String[] prereqEventNames)
-    throws LCFException
+    throws ACFException
   {
     if (documentCount == MAX_COUNT)
     {
@@ -94,7 +94,7 @@ public class SeedingActivity implements 
       writeSeedDocuments(documentHashList,documentList,documentPrereqList);
       documentCount = 0;
     }
-    documentHashList[documentCount] = LCF.hash(documentIdentifier);
+    documentHashList[documentCount] = ACF.hash(documentIdentifier);
     documentList[documentCount] = documentIdentifier;
     if (prereqEventNames != null)
       documentPrereqList[documentCount] = prereqEventNames;
@@ -117,7 +117,7 @@ public class SeedingActivity implements 
   *@param documentIdentifier is the identifier of the document to add to the "pending" queue.
   */
   public void addSeedDocument(String documentIdentifier)
-    throws LCFException
+    throws ACFException
   {
     addSeedDocument(documentIdentifier,null);
   }
@@ -134,7 +134,7 @@ public class SeedingActivity implements 
   * "pending" queue.
   */
   public void addUnqueuedSeedDocument(String documentIdentifier)
-    throws LCFException
+    throws ACFException
   {
     if (remainingDocumentCount == MAX_COUNT)
     {
@@ -142,12 +142,12 @@ public class SeedingActivity implements 
       jobManager.addRemainingDocumentsInitial(jobID,legalLinkTypes,remainingDocumentHashList,hopcountMethod);
       remainingDocumentCount = 0;
     }
-    remainingDocumentHashList[remainingDocumentCount++] = LCF.hash(documentIdentifier);
+    remainingDocumentHashList[remainingDocumentCount++] = ACF.hash(documentIdentifier);
   }
 
   /** Finish a seeding pass */
   public void doneSeeding(boolean isPartial)
-    throws LCFException
+    throws ACFException
   {
     if (documentCount > 0)
     {
@@ -200,7 +200,7 @@ public class SeedingActivity implements 
   */
   public void recordActivity(Long startTime, String activityType, Long dataSize,
     String entityIdentifier, String resultCode, String resultDescription, String[] childIdentifiers)
-    throws LCFException
+    throws ACFException
   {
     connManager.recordHistory(connectionName,startTime,activityType,dataSize,entityIdentifier,resultCode,
       resultDescription,childIdentifiers);
@@ -208,7 +208,7 @@ public class SeedingActivity implements 
 
   /** Write specified documents after calculating their priorities */
   protected void writeSeedDocuments(String[] docIDHashes, String[] docIDs, String[][] prereqEventNames)
-    throws LCFException
+    throws ACFException
   {
     // First, prioritize the documents using the queue tracker
     long prioritizationTime = System.currentTimeMillis();
@@ -252,7 +252,7 @@ public class SeedingActivity implements 
   * caller, will signal that the current seeding activity remains incomplete and must be retried when the job is resumed.
   */
   public void checkJobStillActive()
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     if (jobManager.checkJobActive(jobID) == false)
       throw new ServiceInterruption("Job no longer active",System.currentTimeMillis());
@@ -264,7 +264,7 @@ public class SeedingActivity implements 
   */
   public String createGlobalString(String simpleString)
   {
-    return LCF.createGlobalString(simpleString);
+    return ACF.createGlobalString(simpleString);
   }
 
   /** Create a connection-specific string from a simple string.
@@ -273,7 +273,7 @@ public class SeedingActivity implements 
   */
   public String createConnectionSpecificString(String simpleString)
   {
-    return LCF.createConnectionSpecificString(connection.getName(),simpleString);
+    return ACF.createConnectionSpecificString(connection.getName(),simpleString);
   }
 
   /** Create a job-based string from a simple string.
@@ -282,7 +282,7 @@ public class SeedingActivity implements 
   */
   public String createJobSpecificString(String simpleString)
   {
-    return LCF.createJobSpecificString(jobID,simpleString);
+    return ACF.createJobSpecificString(jobID,simpleString);
   }
 
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/SeedingThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/SeedingThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/SeedingThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/SeedingThread.java Mon Aug 23 18:08:32 2010
@@ -47,7 +47,7 @@ public class SeedingThread extends Threa
   /** Constructor.
   */
   public SeedingThread(QueueTracker queueTracker)
-    throws LCFException
+    throws ACFException
   {
     super();
     setName("Seeding thread");
@@ -67,9 +67,9 @@ public class SeedingThread extends Threa
       IRepositoryConnectionManager connectionMgr = RepositoryConnectionManagerFactory.make(threadContext);
 
       IDBInterface database = DBInterfaceFactory.make(threadContext,
-        LCF.getMasterDatabaseName(),
-        LCF.getMasterDatabaseUsername(),
-        LCF.getMasterDatabasePassword());
+        ACF.getMasterDatabaseName(),
+        ACF.getMasterDatabaseUsername(),
+        ACF.getMasterDatabasePassword());
 
       String[] identifiers = new String[MAX_COUNT];
       // Loop
@@ -102,7 +102,7 @@ public class SeedingThread extends Threa
             if (seedJobs.length == 0)
             {
               Logging.threads.debug("Seeding thread found nothing to do");
-              LCF.sleep(waitTime);
+              ACF.sleep(waitTime);
               continue;
             }
 
@@ -183,13 +183,13 @@ public class SeedingThread extends Threa
                 jsr.noteStarted();
 
               }
-              catch (LCFException e)
+              catch (ACFException e)
               {
-                if (e.getErrorCode() == LCFException.INTERRUPTED)
+                if (e.getErrorCode() == ACFException.INTERRUPTED)
                   throw new InterruptedException();
-                if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+                if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
                   throw e;
-                if (e.getErrorCode() == LCFException.REPOSITORY_CONNECTION_ERROR)
+                if (e.getErrorCode() == ACFException.REPOSITORY_CONNECTION_ERROR)
                 {
                   Logging.threads.warn("Seeding thread: Ignoring connection error: "+e.getMessage(),e);
                   continue;
@@ -204,7 +204,7 @@ public class SeedingThread extends Threa
           finally
           {
             // Clean up all jobs that did not seed
-            LCFException exception = null;
+            ACFException exception = null;
             int i = 0;
             while (i < seedJobs.length)
             {
@@ -219,7 +219,7 @@ public class SeedingThread extends Threa
                 {
                   jobManager.resetSeedJob(jsr.getJobID());
                 }
-                catch (LCFException e)
+                catch (ACFException e)
                 {
                   exception = e;
                 }
@@ -230,14 +230,14 @@ public class SeedingThread extends Threa
           }
 
           // Sleep for the retry interval.
-          LCF.sleep(waitTime);
+          ACF.sleep(waitTime);
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             break;
 
-          if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+          if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
           {
             resetManager.noteEvent();
 
@@ -245,7 +245,7 @@ public class SeedingThread extends Threa
             try
             {
               // Give the database a chance to catch up/wake up
-              LCF.sleep(10000L);
+              ACF.sleep(10000L);
             }
             catch (InterruptedException se)
             {
@@ -257,7 +257,7 @@ public class SeedingThread extends Threa
           // Log it, but keep the thread alive
           Logging.threads.error("Exception tossed: "+e.getMessage(),e);
 
-          if (e.getErrorCode() == LCFException.SETUP_ERROR)
+          if (e.getErrorCode() == ACFException.SETUP_ERROR)
           {
             // Shut the whole system down!
             System.exit(1);
@@ -307,7 +307,7 @@ public class SeedingThread extends Threa
 
     /** Reset */
     protected void performResetLogic(IThreadContext tc)
-      throws LCFException
+      throws ACFException
     {
       IJobManager jobManager = JobManagerFactory.make(tc);
       jobManager.resetSeedingWorkerStatus();

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/SetPriorityThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/SetPriorityThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/SetPriorityThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/SetPriorityThread.java Mon Aug 23 18:08:32 2010
@@ -49,7 +49,7 @@ public class SetPriorityThread extends T
   *@param qt is the queue tracker object.
   */
   public SetPriorityThread(QueueTracker qt, int workerThreadCount, BlockingDocuments blockingDocuments)
-    throws LCFException
+    throws ACFException
   {
     super();
     this.queueTracker = qt;
@@ -87,7 +87,7 @@ public class SetPriorityThread extends T
         try
         {
           if (Thread.currentThread().isInterrupted())
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
 
           Logging.threads.debug("Set priority thread woke up");
 
@@ -113,7 +113,7 @@ public class SetPriorityThread extends T
           while (true)
           {
             if (Thread.currentThread().isInterrupted())
-              throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+              throw new ACFException("Interrupted",ACFException.INTERRUPTED);
 
             if (processedCount >= cycleCount)
             {
@@ -126,7 +126,7 @@ public class SetPriorityThread extends T
             DocumentDescription desc = blockingDocuments.getBlockingDocument();
             if (desc != null)
             {
-              LCF.writeDocumentPriorities(threadContext,mgr,jobManager,new DocumentDescription[]{desc},connectionMap,jobDescriptionMap,queueTracker,currentTime);
+              ACF.writeDocumentPriorities(threadContext,mgr,jobManager,new DocumentDescription[]{desc},connectionMap,jobDescriptionMap,queueTracker,currentTime);
               processedCount++;
               continue;
             }
@@ -145,24 +145,24 @@ public class SetPriorityThread extends T
             }
             */
             Logging.threads.debug("Done reprioritizing because no more documents to reprioritize");
-            LCF.sleep(30000L);
+            ACF.sleep(30000L);
             break;
 
           }
 
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             break;
 
-          if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+          if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
           {
             Logging.threads.error("Set priority thread aborting and restarting due to database connection reset: "+e.getMessage(),e);
             try
             {
               // Give the database a chance to catch up/wake up
-              LCF.sleep(10000L);
+              ACF.sleep(10000L);
             }
             catch (InterruptedException se)
             {
@@ -174,7 +174,7 @@ public class SetPriorityThread extends T
           // Log it, but keep the thread alive
           Logging.threads.error("Exception tossed: "+e.getMessage(),e);
 
-          if (e.getErrorCode() == LCFException.SETUP_ERROR)
+          if (e.getErrorCode() == ACFException.SETUP_ERROR)
           {
             System.exit(1);
           }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/StartupThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/StartupThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/StartupThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/StartupThread.java Mon Aug 23 18:08:32 2010
@@ -44,7 +44,7 @@ public class StartupThread extends Threa
   /** Constructor.
   */
   public StartupThread(QueueTracker queueTracker)
-    throws LCFException
+    throws ACFException
   {
     super();
     setName("Startup thread");
@@ -64,9 +64,9 @@ public class StartupThread extends Threa
       IRepositoryConnectionManager connectionMgr = RepositoryConnectionManagerFactory.make(threadContext);
 
       IDBInterface database = DBInterfaceFactory.make(threadContext,
-        LCF.getMasterDatabaseName(),
-        LCF.getMasterDatabaseUsername(),
-        LCF.getMasterDatabasePassword());
+        ACF.getMasterDatabaseName(),
+        ACF.getMasterDatabaseUsername(),
+        ACF.getMasterDatabasePassword());
 
       String[] identifiers = new String[MAX_COUNT];
 
@@ -95,7 +95,7 @@ public class StartupThread extends Threa
 
             if (startupJobs.length == 0)
             {
-              LCF.sleep(waitTime);
+              ACF.sleep(waitTime);
               continue;
             }
 
@@ -207,13 +207,13 @@ public class StartupThread extends Threa
                 jobManager.noteJobStarted(jobID,currentTime);
                 jsr.noteStarted();
               }
-              catch (LCFException e)
+              catch (ACFException e)
               {
-                if (e.getErrorCode() == LCFException.INTERRUPTED)
+                if (e.getErrorCode() == ACFException.INTERRUPTED)
                   throw new InterruptedException();
-                if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+                if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
                   throw e;
-                if (e.getErrorCode() == LCFException.REPOSITORY_CONNECTION_ERROR)
+                if (e.getErrorCode() == ACFException.REPOSITORY_CONNECTION_ERROR)
                 {
                   Logging.threads.warn("Startup thread: connection error; continuing: "+e.getMessage(),e);
                   continue;
@@ -228,7 +228,7 @@ public class StartupThread extends Threa
           finally
           {
             // Clean up all jobs that did not start
-            LCFException exception = null;
+            ACFException exception = null;
             int i = 0;
             while (i < startupJobs.length)
             {
@@ -240,7 +240,7 @@ public class StartupThread extends Threa
                 {
                   jobManager.resetStartupJob(jsr.getJobID());
                 }
-                catch (LCFException e)
+                catch (ACFException e)
                 {
                   exception = e;
                 }
@@ -251,14 +251,14 @@ public class StartupThread extends Threa
           }
 
           // Sleep for the retry interval.
-          LCF.sleep(waitTime);
+          ACF.sleep(waitTime);
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             break;
 
-          if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+          if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
           {
             resetManager.noteEvent();
 
@@ -266,7 +266,7 @@ public class StartupThread extends Threa
             try
             {
               // Give the database a chance to catch up/wake up
-              LCF.sleep(10000L);
+              ACF.sleep(10000L);
             }
             catch (InterruptedException se)
             {
@@ -278,7 +278,7 @@ public class StartupThread extends Threa
           // Log it, but keep the thread alive
           Logging.threads.error("Exception tossed: "+e.getMessage(),e);
 
-          if (e.getErrorCode() == LCFException.SETUP_ERROR)
+          if (e.getErrorCode() == ACFException.SETUP_ERROR)
           {
             // Shut the whole system down!
             System.exit(1);
@@ -327,7 +327,7 @@ public class StartupThread extends Threa
 
     /** Reset */
     protected void performResetLogic(IThreadContext tc)
-      throws LCFException
+      throws ACFException
     {
       IJobManager jobManager = JobManagerFactory.make(tc);
       jobManager.resetStartupWorkerStatus();

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/StufferThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/StufferThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/StufferThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/StufferThread.java Mon Aug 23 18:08:32 2010
@@ -55,7 +55,7 @@ public class StufferThread extends Threa
   */
   public StufferThread(DocumentQueue documentQueue, int n, WorkerResetManager resetManager, QueueTracker qt,
     BlockingDocuments blockingDocuments, float lowWaterFactor, float stuffSizeFactor)
-    throws LCFException
+    throws ACFException
   {
     super();
     this.documentQueue = documentQueue;
@@ -118,7 +118,7 @@ public class StufferThread extends Threa
         try
         {
           if (Thread.currentThread().isInterrupted())
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
 
           // Check if we're okay
           resetManager.waitForReset(threadContext);
@@ -128,7 +128,7 @@ public class StufferThread extends Threa
           boolean isEmpty = documentQueue.checkIfEmpty(lowWaterMark);
           if (isEmpty == false)
           {
-            LCF.sleep(1000L);
+            ACF.sleep(1000L);
             continue;
           }
           long queueNeededTime = System.currentTimeMillis();
@@ -160,7 +160,7 @@ public class StufferThread extends Threa
           lastQueueFullResults = (descs.length == stuffAmt);
 
           if (Thread.currentThread().isInterrupted())
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
 
           queueTracker.assessMinimumDepth(depthStatistics.getBins());
 
@@ -175,7 +175,7 @@ public class StufferThread extends Threa
           // The theory is that we need to allow stuff to accumulate.
           if (descs.length == 0)
           {
-            LCF.sleep(2000L);       // 2 seconds
+            ACF.sleep(2000L);       // 2 seconds
             continue;
           }
 
@@ -269,15 +269,15 @@ public class StufferThread extends Threa
                 }
               }
             }
-            catch (LCFException e)
+            catch (ACFException e)
             {
               // If we were interrupted, then we are allowed to leave, because the process is terminating, but that's the only exception to the rule
-              if (e.getErrorCode() == LCFException.INTERRUPTED)
+              if (e.getErrorCode() == ACFException.INTERRUPTED)
                 throw e;
 
               // Note: We really should never leave this block by throwing an exception, since that could easily leave dangling
               // active jobqueue entries around.  Instead, log the error and continue IN ALL CASES.
-              Logging.threads.error("Stuffer thread LCF Exception thrown: "+e.getMessage()+" - continuing",
+              Logging.threads.error("Stuffer thread ACF Exception thrown: "+e.getMessage()+" - continuing",
                 e);
               maxDocuments = 1;
               binNames = new String[]{""};
@@ -345,12 +345,12 @@ public class StufferThread extends Threa
           // If we don't wait here, the other threads don't seem to have a chance to queue anything else up.
           //Thread.yield();
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             break;
 
-          if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+          if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
           {
             resetManager.noteEvent();
             documentQueue.reset();
@@ -359,7 +359,7 @@ public class StufferThread extends Threa
             try
             {
               // Give the database a chance to catch up/wake up
-              LCF.sleep(10000L);
+              ACF.sleep(10000L);
             }
             catch (InterruptedException se)
             {
@@ -371,7 +371,7 @@ public class StufferThread extends Threa
           // Log it, but keep the thread alive
           Logging.threads.error("Exception tossed: "+e.getMessage(),e);
 
-          if (e.getErrorCode() == LCFException.SETUP_ERROR)
+          if (e.getErrorCode() == ACFException.SETUP_ERROR)
           {
             System.exit(1);
           }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/WorkerResetManager.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/WorkerResetManager.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/WorkerResetManager.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/WorkerResetManager.java Mon Aug 23 18:08:32 2010
@@ -42,7 +42,7 @@ public class WorkerResetManager extends 
 
   /** Reset */
   protected void performResetLogic(IThreadContext tc)
-    throws LCFException
+    throws ACFException
   {
     IJobManager jobManager = JobManagerFactory.make(tc);
     jobManager.resetDocumentWorkerStatus();

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/WorkerThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/WorkerThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/WorkerThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/system/WorkerThread.java Mon Aug 23 18:08:32 2010
@@ -47,7 +47,7 @@ public class WorkerThread extends Thread
   *@param id is the worker thread id.
   */
   public WorkerThread(String id, DocumentQueue documentQueue, WorkerResetManager resetManager, QueueTracker queueTracker)
-    throws LCFException
+    throws ACFException
   {
     super();
     this.id = id;
@@ -104,7 +104,7 @@ public class WorkerThread extends Thread
         try
         {
           if (Thread.currentThread().isInterrupted())
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
 
           // Before we begin, conditionally reset
           resetManager.waitForReset(threadContext);
@@ -123,7 +123,7 @@ public class WorkerThread extends Thread
             // System.out.println("Got a document set");
 
             if (Thread.currentThread().isInterrupted())
-              throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+              throw new ACFException("Interrupted",ACFException.INTERRUPTED);
 
             // First of all: find out if the job for these documents has been aborted, paused, etc.
             // If so, we requeue the documents immediately.
@@ -324,7 +324,7 @@ public class WorkerThread extends Thread
                     {
 
                       if (Thread.currentThread().isInterrupted())
-                        throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+                        throw new ACFException("Interrupted",ACFException.INTERRUPTED);
 
                       HashMap abortSet = new HashMap();
                       ProcessActivity activity;
@@ -378,7 +378,7 @@ public class WorkerThread extends Thread
                           {
                             // Treat this as a hard failure.
                             if (e.isAbortOnFail())
-                              throw new LCFException("Repeated service interruptions - failure getting document version"+((e.getCause()!=null)?": "+e.getCause().getMessage():""),e.getCause());
+                              throw new ACFException("Repeated service interruptions - failure getting document version"+((e.getCause()!=null)?": "+e.getCause().getMessage():""),e.getCause());
                             // We want this particular document to be not included in the
                             // reprocessing.  Therefore, we do the same thing as we would
                             // if we got back a null version.
@@ -577,7 +577,7 @@ public class WorkerThread extends Thread
                             try
                             {
                               if (Thread.currentThread().isInterrupted())
-                                throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+                                throw new ACFException("Interrupted",ACFException.INTERRUPTED);
 
                               if (Logging.threads.isDebugEnabled())
                                 Logging.threads.debug("Worker thread about to process "+Integer.toString(processIDs.length)+" documents");
@@ -590,7 +590,7 @@ public class WorkerThread extends Thread
                               // "Finish" the documents (removing unneeded carrydown info, etc.)
                               DocumentDescription[] requeueCandidates = jobManager.finishDocuments(job.getID(),legalLinkTypes,processIDHashes,job.getHopcountMode());
 
-                              LCF.requeueDocumentsDueToCarrydown(jobManager,requeueCandidates,connector,connection,queueTracker,currentTime);
+                              ACF.requeueDocumentsDueToCarrydown(jobManager,requeueCandidates,connector,connection,queueTracker,currentTime);
 
                               if (Logging.threads.isDebugEnabled())
                                 Logging.threads.debug("Worker thread done processing "+Integer.toString(processIDs.length)+" documents");
@@ -627,7 +627,7 @@ public class WorkerThread extends Thread
                                 {
                                   // Treat this as a hard failure.
                                   if (e.isAbortOnFail())
-                                    throw new LCFException("Repeated service interruptions - failure processing document"+((e.getCause()!=null)?": "+e.getCause().getMessage():""),e.getCause());
+                                    throw new ACFException("Repeated service interruptions - failure processing document"+((e.getCause()!=null)?": "+e.getCause().getMessage():""),e.getCause());
                                   // We want this particular document to be not included in the
                                   // reprocessing.  Therefore, we do the same thing as we would
                                   // if we got back a null version.
@@ -824,7 +824,7 @@ public class WorkerThread extends Thread
                               }
                               break;
                             default:
-                              throw new LCFException("Unexpected value for job type: '"+Integer.toString(job.getType())+"'");
+                              throw new ACFException("Unexpected value for job type: '"+Integer.toString(job.getType())+"'");
                             }
 
                             // Finally, if we're still alive, mark everything as "processed".
@@ -861,10 +861,10 @@ public class WorkerThread extends Thread
                     }
                   }
                 }
-                catch (LCFException e)
+                catch (ACFException e)
                 {
 
-                  if (e.getErrorCode() == LCFException.REPOSITORY_CONNECTION_ERROR)
+                  if (e.getErrorCode() == ACFException.REPOSITORY_CONNECTION_ERROR)
                   {
                     // Couldn't establish a connection.
                     // This basically means none of the documents handed to this thread can be
@@ -897,12 +897,12 @@ public class WorkerThread extends Thread
               qds.endProcessing(queueTracker);
             }
           }
-          catch (LCFException e)
+          catch (ACFException e)
           {
-            if (e.getErrorCode() == LCFException.INTERRUPTED)
+            if (e.getErrorCode() == ACFException.INTERRUPTED)
               break;
 
-            if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+            if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
               throw e;
 
             if (jobManager.errorAbort(qds.getJobDescription().getID(),e.getMessage()))
@@ -929,12 +929,12 @@ public class WorkerThread extends Thread
             }
           }
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             break;
 
-          if (e.getErrorCode() == LCFException.DATABASE_CONNECTION_ERROR)
+          if (e.getErrorCode() == ACFException.DATABASE_CONNECTION_ERROR)
           {
             // Note the failure, which will cause a reset to occur
             resetManager.noteEvent();
@@ -945,7 +945,7 @@ public class WorkerThread extends Thread
             try
             {
               // Give the database a chance to catch up/wake up
-              LCF.sleep(10000L);
+              ACF.sleep(10000L);
             }
             catch (InterruptedException se)
             {
@@ -1015,7 +1015,7 @@ public class WorkerThread extends Thread
     IIncrementalIngester ingester, ArrayList ingesterDeleteList, ArrayList ingesterDeleteListUnhashed,
     Long jobID, String[] legalLinkTypes, OutputActivity ingestLogger,
     int hopcountMethod, QueueTracker queueTracker, long currentTime)
-    throws LCFException
+    throws ACFException
   {
     String connectionName = connection.getName();
 
@@ -1051,11 +1051,11 @@ public class WorkerThread extends Thread
             waittime = 300000L;
           try
           {
-            LCF.sleep(waittime);
+            ACF.sleep(waittime);
           }
           catch (InterruptedException e2)
           {
-            throw new LCFException("Interrupted: "+e2.getMessage(),e2,LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted: "+e2.getMessage(),e2,ACFException.INTERRUPTED);
           }
         }
       }
@@ -1077,7 +1077,7 @@ public class WorkerThread extends Thread
       DocumentDescription[] requeueCandidates = jobManager.markDocumentDeletedMultiple(jobID,legalLinkTypes,deleteDescriptions,hopcountMethod);
 
       // Requeue those documents that had carrydown data modifications
-      LCF.requeueDocumentsDueToCarrydown(jobManager,requeueCandidates,connector,connection,queueTracker,currentTime);
+      ACF.requeueDocumentsDueToCarrydown(jobManager,requeueCandidates,connector,connection,queueTracker,currentTime);
 
       // Mark all these as done
       i = 0;
@@ -1097,7 +1097,7 @@ public class WorkerThread extends Thread
   *@param failCount is the number of retries allowed until hard failure.
   */
   protected static void requeueDocuments(IJobManager jobManager, ArrayList requeueList, long retryTime, long failTime, int failCount)
-    throws LCFException
+    throws ACFException
   {
     if (requeueList.size() > 0)
     {
@@ -1159,7 +1159,7 @@ public class WorkerThread extends Thread
     *@return true if the mime type is indexable.
     */
     public boolean checkMimeTypeIndexable(String mimeType)
-      throws LCFException, ServiceInterruption
+      throws ACFException, ServiceInterruption
     {
       return ingester.checkMimeTypeIndexable(job.getOutputConnectionName(),mimeType);
     }
@@ -1169,7 +1169,7 @@ public class WorkerThread extends Thread
     *@return true if the document is indexable.
     */
     public boolean checkDocumentIndexable(File localFile)
-      throws LCFException, ServiceInterruption
+      throws ACFException, ServiceInterruption
     {
       return ingester.checkDocumentIndexable(job.getOutputConnectionName(),localFile);
     }
@@ -1192,7 +1192,7 @@ public class WorkerThread extends Thread
     */
     public void recordActivity(Long startTime, String activityType, Long dataSize,
       String entityIdentifier, String resultCode, String resultDescription, String[] childIdentifiers)
-      throws LCFException
+      throws ACFException
     {
       connMgr.recordHistory(connectionName,startTime,activityType,dataSize,entityIdentifier,resultCode,
         resultDescription,childIdentifiers);
@@ -1204,9 +1204,9 @@ public class WorkerThread extends Thread
     *@return an array containing the unique data values passed from ALL parents.  Note that these are in no particular order, and there will not be any duplicates.
     */
     public String[] retrieveParentData(String localIdentifier, String dataName)
-      throws LCFException
+      throws ACFException
     {
-      return jobManager.retrieveParentData(job.getID(),LCF.hash(localIdentifier),dataName);
+      return jobManager.retrieveParentData(job.getID(),ACF.hash(localIdentifier),dataName);
     }
 
     /** Retrieve data passed from parents to a specified child document.
@@ -1215,9 +1215,9 @@ public class WorkerThread extends Thread
     *@return an array containing the unique data values passed from ALL parents.  Note that these are in no particular order, and there will not be any duplicates.
     */
     public CharacterInput[] retrieveParentDataAsFiles(String localIdentifier, String dataName)
-      throws LCFException
+      throws ACFException
     {
-      return jobManager.retrieveParentDataAsFiles(job.getID(),LCF.hash(localIdentifier),dataName);
+      return jobManager.retrieveParentDataAsFiles(job.getID(),ACF.hash(localIdentifier),dataName);
     }
 
     /** Check whether current job is still active.
@@ -1226,7 +1226,7 @@ public class WorkerThread extends Thread
     * caller, will signal that the current versioning activity remains incomplete and must be retried when the job is resumed.
     */
     public void checkJobStillActive()
-      throws LCFException, ServiceInterruption
+      throws ACFException, ServiceInterruption
     {
       if (jobManager.checkJobActive(job.getID()) == false)
         throw new ServiceInterruption("Job no longer active",System.currentTimeMillis());
@@ -1240,7 +1240,7 @@ public class WorkerThread extends Thread
     *@return false if the event is already in the "pending" state.
     */
     public boolean beginEventSequence(String eventName)
-      throws LCFException
+      throws ACFException
     {
       return jobManager.beginEventSequence(eventName);
     }
@@ -1253,7 +1253,7 @@ public class WorkerThread extends Thread
     *@param eventName is the event name.
     */
     public void completeEventSequence(String eventName)
-      throws LCFException
+      throws ACFException
     {
       jobManager.completeEventSequence(eventName);
     }
@@ -1265,7 +1265,7 @@ public class WorkerThread extends Thread
     *@param localIdentifier is the document identifier to requeue
     */
     public void retryDocumentProcessing(String localIdentifier)
-      throws LCFException
+      throws ACFException
     {
       // Accumulate aborts
       abortSet.put(localIdentifier,localIdentifier);
@@ -1277,7 +1277,7 @@ public class WorkerThread extends Thread
     */
     public String createGlobalString(String simpleString)
     {
-      return LCF.createGlobalString(simpleString);
+      return ACF.createGlobalString(simpleString);
     }
 
     /** Create a connection-specific string from a simple string.
@@ -1286,7 +1286,7 @@ public class WorkerThread extends Thread
     */
     public String createConnectionSpecificString(String simpleString)
     {
-      return LCF.createConnectionSpecificString(connectionName,simpleString);
+      return ACF.createConnectionSpecificString(connectionName,simpleString);
     }
 
     /** Create a job-based string from a simple string.
@@ -1295,7 +1295,7 @@ public class WorkerThread extends Thread
     */
     public String createJobSpecificString(String simpleString)
     {
-      return LCF.createJobSpecificString(jobID,simpleString);
+      return ACF.createJobSpecificString(jobID,simpleString);
     }
 
   }
@@ -1357,7 +1357,7 @@ public class WorkerThread extends Thread
 
     /** Clean up any dangling information, before abandoning this process activity object */
     public void discard()
-      throws LCFException
+      throws ACFException
     {
       Iterator iter = referenceList.keySet().iterator();
       while (iter.hasNext())
@@ -1384,12 +1384,12 @@ public class WorkerThread extends Thread
     */
     public void addDocumentReference(String localIdentifier, String parentIdentifier, String relationshipType,
       String[] dataNames, Object[][] dataValues, Long originationTime, String[] prereqEventNames)
-      throws LCFException
+      throws ACFException
     {
-      String localIdentifierHash = LCF.hash(localIdentifier);
+      String localIdentifierHash = ACF.hash(localIdentifier);
       String parentIdentifierHash = null;
       if (parentIdentifier != null && parentIdentifier.length() > 0)
-        parentIdentifierHash = LCF.hash(parentIdentifier);
+        parentIdentifierHash = ACF.hash(parentIdentifier);
 
       if (Logging.threads.isDebugEnabled())
         Logging.threads.debug("Adding document reference, from "+((parentIdentifier==null)?"no parent":"'"+parentIdentifier+"'")
@@ -1482,7 +1482,7 @@ public class WorkerThread extends Thread
     */
     public void addDocumentReference(String localIdentifier, String parentIdentifier, String relationshipType,
       String[] dataNames, Object[][] dataValues, Long originationTime)
-      throws LCFException
+      throws ACFException
     {
       addDocumentReference(localIdentifier,parentIdentifier,relationshipType,dataNames,dataValues,originationTime,null);
     }
@@ -1500,7 +1500,7 @@ public class WorkerThread extends Thread
     */
     public void addDocumentReference(String localIdentifier, String parentIdentifier, String relationshipType,
       String[] dataNames, Object[][] dataValues)
-      throws LCFException
+      throws ACFException
     {
       addDocumentReference(localIdentifier,parentIdentifier,relationshipType,dataNames,dataValues,null);
     }
@@ -1515,7 +1515,7 @@ public class WorkerThread extends Thread
     * "getRelationshipTypes()".  May be null.
     */
     public void addDocumentReference(String localIdentifier, String parentIdentifier, String relationshipType)
-      throws LCFException
+      throws ACFException
     {
       addDocumentReference(localIdentifier,parentIdentifier,relationshipType,null,null);
     }
@@ -1526,7 +1526,7 @@ public class WorkerThread extends Thread
     * fetched the document).
     */
     public void addDocumentReference(String localIdentifier)
-      throws LCFException
+      throws ACFException
     {
       addDocumentReference(localIdentifier,null,null,null,null);
     }
@@ -1537,9 +1537,9 @@ public class WorkerThread extends Thread
     *@return an array containing the unique data values passed from ALL parents.  Note that these are in no particular order, and there will not be any duplicates.
     */
     public String[] retrieveParentData(String localIdentifier, String dataName)
-      throws LCFException
+      throws ACFException
     {
-      return jobManager.retrieveParentData(job.getID(),LCF.hash(localIdentifier),dataName);
+      return jobManager.retrieveParentData(job.getID(),ACF.hash(localIdentifier),dataName);
     }
 
     /** Retrieve data passed from parents to a specified child document.
@@ -1548,9 +1548,9 @@ public class WorkerThread extends Thread
     *@return an array containing the unique data values passed from ALL parents.  Note that these are in no particular order, and there will not be any duplicates.
     */
     public CharacterInput[] retrieveParentDataAsFiles(String localIdentifier, String dataName)
-      throws LCFException
+      throws ACFException
     {
-      return jobManager.retrieveParentDataAsFiles(job.getID(),LCF.hash(localIdentifier),dataName);
+      return jobManager.retrieveParentDataAsFiles(job.getID(),ACF.hash(localIdentifier),dataName);
     }
 
     /** Record a document version, but don't ingest it.
@@ -1559,9 +1559,9 @@ public class WorkerThread extends Thread
     *@param version is the document version.
     */
     public void recordDocument(String documentIdentifier, String version)
-      throws LCFException, ServiceInterruption
+      throws ACFException, ServiceInterruption
     {
-      String documentIdentifierHash = LCF.hash(documentIdentifier);
+      String documentIdentifierHash = ACF.hash(documentIdentifier);
       ingester.documentRecord(job.getOutputConnectionName(),job.getConnectionName(),documentIdentifierHash,version,currentTime,ingestLogger);
     }
 
@@ -1574,13 +1574,13 @@ public class WorkerThread extends Thread
     *@param data is the document data.  The data is closed after ingestion is complete.
     */
     public void ingestDocument(String documentIdentifier, String version, String documentURI, RepositoryDocument data)
-      throws LCFException, ServiceInterruption
+      throws ACFException, ServiceInterruption
     {
       // We should not get called here if versions agree, unless the repository
       // connector cannot distinguish between versions - in which case it must
       // always ingest (essentially)
 
-      String documentIdentifierHash = LCF.hash(documentIdentifier);
+      String documentIdentifierHash = ACF.hash(documentIdentifier);
 
       // First, we need to add into the metadata the stuff from the job description.
       ingester.documentIngest(job.getOutputConnectionName(),
@@ -1596,9 +1596,9 @@ public class WorkerThread extends Thread
     *@param documentIdentifier is the document's local identifier.
     */
     public void deleteDocument(String documentIdentifier)
-      throws LCFException, ServiceInterruption
+      throws ACFException, ServiceInterruption
     {
-      String documentIdentifierHash = LCF.hash(documentIdentifier);
+      String documentIdentifierHash = ACF.hash(documentIdentifier);
       ingester.documentDelete(job.getOutputConnectionName(),
         job.getConnectionName(),documentIdentifierHash,
         ingestLogger);
@@ -1617,7 +1617,7 @@ public class WorkerThread extends Thread
     public void setDocumentScheduleBounds(String localIdentifier,
       Long lowerRecrawlBoundTime, Long upperRecrawlBoundTime,
       Long lowerExpireBoundTime, Long upperExpireBoundTime)
-      throws LCFException
+      throws ACFException
     {
       if (lowerRecrawlBoundTime != null)
         lowerRescheduleBounds.put(localIdentifier,lowerRecrawlBoundTime);
@@ -1644,7 +1644,7 @@ public class WorkerThread extends Thread
     */
     public void setDocumentOriginationTime(String localIdentifier,
       Long originationTime)
-      throws LCFException
+      throws ACFException
     {
       if (originationTime == null)
         originationTimes.remove(localIdentifier);
@@ -1765,7 +1765,7 @@ public class WorkerThread extends Thread
     */
     public void recordActivity(Long startTime, String activityType, Long dataSize,
       String entityIdentifier, String resultCode, String resultDescription, String[] childIdentifiers)
-      throws LCFException
+      throws ACFException
     {
       connMgr.recordHistory(connection.getName(),startTime,activityType,dataSize,entityIdentifier,resultCode,
         resultDescription,childIdentifiers);
@@ -1774,7 +1774,7 @@ public class WorkerThread extends Thread
     /** Flush the outstanding references into the database.
     */
     public void flush()
-      throws LCFException
+      throws ACFException
     {
       processDocumentReferences();
     }
@@ -1782,7 +1782,7 @@ public class WorkerThread extends Thread
     /** Process outstanding document references, in batch.
     */
     protected void processDocumentReferences()
-      throws LCFException
+      throws ACFException
     {
       if (referenceList.size() == 0)
         return;
@@ -1831,7 +1831,7 @@ public class WorkerThread extends Thread
           eventNames[j] = dr.getPrerequisiteEventNames();
 
           // Calculate desired document priority based on current queuetracker status.
-          String[] bins = LCF.calculateBins(connector,dr.getLocalIdentifier());
+          String[] bins = ACF.calculateBins(connector,dr.getLocalIdentifier());
 
 
           binNames[j] = bins;
@@ -1871,7 +1871,7 @@ public class WorkerThread extends Thread
     * caller, will signal that the current processing activity remains incomplete and must be retried when the job is resumed.
     */
     public void checkJobStillActive()
-      throws LCFException, ServiceInterruption
+      throws ACFException, ServiceInterruption
     {
       if (jobManager.checkJobActive(job.getID()) == false)
         throw new ServiceInterruption("Job no longer active",System.currentTimeMillis());
@@ -1885,7 +1885,7 @@ public class WorkerThread extends Thread
     *@return false if the event is already in the "pending" state.
     */
     public boolean beginEventSequence(String eventName)
-      throws LCFException
+      throws ACFException
     {
       return jobManager.beginEventSequence(eventName);
     }
@@ -1898,7 +1898,7 @@ public class WorkerThread extends Thread
     *@param eventName is the event name.
     */
     public void completeEventSequence(String eventName)
-      throws LCFException
+      throws ACFException
     {
       jobManager.completeEventSequence(eventName);
     }
@@ -1910,7 +1910,7 @@ public class WorkerThread extends Thread
     *@param localIdentifier is the document identifier to requeue
     */
     public void retryDocumentProcessing(String localIdentifier)
-      throws LCFException
+      throws ACFException
     {
       // Accumulate aborts
       abortSet.put(localIdentifier,localIdentifier);
@@ -1921,7 +1921,7 @@ public class WorkerThread extends Thread
     *@return true if the mime type is indexable.
     */
     public boolean checkMimeTypeIndexable(String mimeType)
-      throws LCFException, ServiceInterruption
+      throws ACFException, ServiceInterruption
     {
       return ingester.checkMimeTypeIndexable(job.getOutputConnectionName(),mimeType);
     }
@@ -1931,7 +1931,7 @@ public class WorkerThread extends Thread
     *@return true if the document is indexable.
     */
     public boolean checkDocumentIndexable(File localFile)
-      throws LCFException, ServiceInterruption
+      throws ACFException, ServiceInterruption
     {
       return ingester.checkDocumentIndexable(job.getOutputConnectionName(),localFile);
     }
@@ -1942,7 +1942,7 @@ public class WorkerThread extends Thread
     */
     public String createGlobalString(String simpleString)
     {
-      return LCF.createGlobalString(simpleString);
+      return ACF.createGlobalString(simpleString);
     }
 
     /** Create a connection-specific string from a simple string.
@@ -1951,7 +1951,7 @@ public class WorkerThread extends Thread
     */
     public String createConnectionSpecificString(String simpleString)
     {
-      return LCF.createConnectionSpecificString(connection.getName(),simpleString);
+      return ACF.createConnectionSpecificString(connection.getName(),simpleString);
     }
 
     /** Create a job-based string from a simple string.
@@ -1960,7 +1960,7 @@ public class WorkerThread extends Thread
     */
     public String createJobSpecificString(String simpleString)
     {
-      return LCF.createJobSpecificString(job.getID(),simpleString);
+      return ACF.createJobSpecificString(job.getID(),simpleString);
     }
 
   }
@@ -2044,7 +2044,7 @@ public class WorkerThread extends Thread
 
     /** Close all object data references.  This should be called whenever a DocumentReference object is abandoned. */
     public void discard()
-      throws LCFException
+      throws ACFException
     {
       Iterator iter = data.keySet().iterator();
       while (iter.hasNext())
@@ -2264,9 +2264,9 @@ public class WorkerThread extends Thread
     */
     public void recordActivity(Long startTime, String activityType, Long dataSize,
       String entityURI, String resultCode, String resultDescription)
-      throws LCFException
+      throws ACFException
     {
-      connMgr.recordHistory(connectionName,startTime,LCF.qualifyOutputActivityName(activityType,outputConnectionName),dataSize,entityURI,resultCode,
+      connMgr.recordHistory(connectionName,startTime,ACF.qualifyOutputActivityName(activityType,outputConnectionName),dataSize,entityURI,resultCode,
         resultDescription,null);
     }
 
@@ -2277,7 +2277,7 @@ public class WorkerThread extends Thread
     *@return the properly qualified access token.
     */
     public String qualifyAccessToken(String authorityNameString, String accessToken)
-      throws LCFException
+      throws ACFException
     {
       try
       {
@@ -2287,7 +2287,7 @@ public class WorkerThread extends Thread
       }
       catch (java.io.UnsupportedEncodingException e)
       {
-        throw new LCFException(e.getMessage(),e);
+        throw new ACFException(e.getMessage(),e);
       }
     }
 

Modified: incubator/lcf/trunk/modules/framework/tests/ThreadLockSpinner.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/tests/ThreadLockSpinner.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/tests/ThreadLockSpinner.java (original)
+++ incubator/lcf/trunk/modules/framework/tests/ThreadLockSpinner.java Mon Aug 23 18:08:32 2010
@@ -16,7 +16,7 @@
 */
 
 import org.apache.acf.core.interfaces.*;
-import org.apache.acf.core.system.LCF;
+import org.apache.acf.core.system.ACF;
 
 public class ThreadLockSpinner
 {
@@ -26,7 +26,7 @@ public class ThreadLockSpinner
   public static void main(String[] argv)
     throws Exception
   {
-    LCF.initializeEnvironment();
+    ACF.initializeEnvironment();
 
     // Start up multiple threads of each kind
     int t1instanceCount = 25;

Modified: incubator/lcf/trunk/modules/framework/tests/org/apache/acf/agents/tests/Sanity.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/tests/org/apache/acf/agents/tests/Sanity.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/tests/org/apache/acf/agents/tests/Sanity.java (original)
+++ incubator/lcf/trunk/modules/framework/tests/org/apache/acf/agents/tests/Sanity.java Mon Aug 23 18:08:32 2010
@@ -20,7 +20,7 @@ package org.apache.acf.agents.tests;
 
 import org.apache.acf.core.interfaces.*;
 import org.apache.acf.agents.interfaces.*;
-import org.apache.acf.agents.system.LCF;
+import org.apache.acf.agents.system.ACF;
 
 import java.io.*;
 import java.util.*;

Modified: incubator/lcf/trunk/modules/framework/tests/org/apache/acf/agents/tests/TestBase.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/tests/org/apache/acf/agents/tests/TestBase.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/tests/org/apache/acf/agents/tests/TestBase.java (original)
+++ incubator/lcf/trunk/modules/framework/tests/org/apache/acf/agents/tests/TestBase.java Mon Aug 23 18:08:32 2010
@@ -20,7 +20,7 @@ package org.apache.acf.agents.tests;
 
 import org.apache.acf.core.interfaces.*;
 import org.apache.acf.agents.interfaces.*;
-import org.apache.acf.agents.system.LCF;
+import org.apache.acf.agents.system.ACF;
 
 import java.io.*;
 import java.util.*;
@@ -60,9 +60,9 @@ public class TestBase extends org.apache
     
     // Install the agents tables
     initialize();
-    LCF.initializeEnvironment();
+    ACF.initializeEnvironment();
     IThreadContext tc = ThreadContextFactory.make();
-    LCF.installTables(tc);
+    ACF.installTables(tc);
   }
   
   @After
@@ -87,13 +87,13 @@ public class TestBase extends org.apache
     if (isInitialized())
     {
       // Test the uninstall
-      LCF.initializeEnvironment();
+      ACF.initializeEnvironment();
       IThreadContext tc = ThreadContextFactory.make();
       
       Exception currentException = null;
       try
       {
-        LCF.deinstallTables(tc);
+        ACF.deinstallTables(tc);
       }
       catch (Exception e)
       {