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 [20/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/jobs/Jobs.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/Jobs.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/Jobs.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/Jobs.java Mon Aug 23 18:08:32 2010
@@ -190,7 +190,7 @@ public class Jobs extends org.apache.acf
   *@param database is the database handle.
   */
   public Jobs(IThreadContext threadContext, IDBInterface database)
-    throws LCFException
+    throws ACFException
   {
     super(database,"jobs");
     this.threadContext = threadContext;
@@ -205,7 +205,7 @@ public class Jobs extends org.apache.acf
   /** Install or upgrade this table.
   */
   public void install(String outputTableName, String outputNameField, String connectionTableName, String connectionNameField)
-    throws LCFException
+    throws ACFException
   {
     // Standard practice: Have a loop around everything, in case upgrade needs it.
     while (true)
@@ -276,7 +276,7 @@ public class Jobs extends org.apache.acf
   /** Uninstall.
   */
   public void deinstall()
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -285,7 +285,7 @@ public class Jobs extends org.apache.acf
       scheduleManager.deinstall();
       performDrop(null);
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -305,7 +305,7 @@ public class Jobs extends org.apache.acf
   *@return the time, in minutes.
   */
   public int getAnalyzeTime()
-    throws LCFException
+    throws ACFException
   {
     // Since we never expect jobs to grow rapidly, every 24hrs should always be fine
     return 24 * 60;
@@ -314,7 +314,7 @@ public class Jobs extends org.apache.acf
   /** Analyze job tables that need analysis.
   */
   public void analyzeTables()
-    throws LCFException
+    throws ACFException
   {
     analyzeTable();
   }
@@ -322,7 +322,7 @@ public class Jobs extends org.apache.acf
   /** Read schedule records for a specified set of jobs.  Cannot use caching!
   */
   public ScheduleRecord[][] readScheduleRecords(Long[] jobIDs)
-    throws LCFException
+    throws ACFException
   {
     Map uniqueIDs = new HashMap();
     int i = 0;
@@ -364,7 +364,7 @@ public class Jobs extends org.apache.acf
       signalRollback();
       throw e;
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -403,7 +403,7 @@ public class Jobs extends org.apache.acf
   *@return the array of all jobs.
   */
   public IJobDescription[] getAll()
-    throws LCFException
+    throws ACFException
   {
     // Begin transaction
     beginTransaction();
@@ -431,7 +431,7 @@ public class Jobs extends org.apache.acf
       }
       return loadMultiple(ids,readOnlies);
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -451,7 +451,7 @@ public class Jobs extends org.apache.acf
   *@return a resultset with "jobid" and "connectionname" fields.
   */
   public IResultSet getActiveJobConnections()
-    throws LCFException
+    throws ACFException
   {
     return performQuery("SELECT "+idField+" AS jobid,"+connectionNameField+" AS connectionname FROM "+getTableName()+" WHERE "+
       statusField+" IN ("+
@@ -463,7 +463,7 @@ public class Jobs extends org.apache.acf
   *@return the array of connection names corresponding to active jobs.
   */
   public String[] getActiveConnectionNames()
-    throws LCFException
+    throws ACFException
   {
     IResultSet set = performQuery("SELECT DISTINCT "+connectionNameField+" FROM "+getTableName()+" WHERE "+
       statusField+" IN ("+
@@ -482,7 +482,7 @@ public class Jobs extends org.apache.acf
 
   /** Are there any jobs that have a specified priority level */
   public boolean hasPriorityJobs(int priority)
-    throws LCFException
+    throws ACFException
   {
     IResultSet set = performQuery("SELECT * FROM "+getTableName()+" WHERE "+priorityField+"="+Integer.toString(priority)+
       " AND "+
@@ -495,7 +495,7 @@ public class Jobs extends org.apache.acf
   /** Create a job.
   */
   public IJobDescription create()
-    throws LCFException
+    throws ACFException
   {
     JobDescription rval = new JobDescription();
     rval.setIsNew(true);
@@ -507,7 +507,7 @@ public class Jobs extends org.apache.acf
   *@param id is the job id.
   */
   public void delete(Long id)
-    throws LCFException
+    throws ACFException
   {
     StringSetBuffer ssb = new StringSetBuffer();
     ssb.add(getJobsKey());
@@ -523,7 +523,7 @@ public class Jobs extends org.apache.acf
       params.add(id);
       performDelete("WHERE "+idField+"=?",params,cacheKeys);
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -544,7 +544,7 @@ public class Jobs extends org.apache.acf
   *@return the editable job description.
   */
   public IJobDescription load(Long id, boolean readOnly)
-    throws LCFException
+    throws ACFException
   {
     return loadMultiple(new Long[]{id}, new boolean[]{readOnly})[0];
   }
@@ -555,7 +555,7 @@ public class Jobs extends org.apache.acf
   *@return the array of objects, in order.
   */
   public IJobDescription[] loadMultiple(Long[] ids, boolean[] readOnlies)
-    throws LCFException
+    throws ACFException
   {
     // Build description objects
     JobObjectDescription[] objectDescriptions = new JobObjectDescription[ids.length];
@@ -578,7 +578,7 @@ public class Jobs extends org.apache.acf
   *@param jobDescription is the job description.
   */
   public void save(IJobDescription jobDescription)
-    throws LCFException
+    throws ACFException
   {
     // The invalidation keys for this are both the general and the specific.
     Long id = jobDescription.getID();
@@ -672,7 +672,7 @@ public class Jobs extends org.apache.acf
 
         cacheManager.invalidateKeys(ch);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
         signalRollback();
         throw e;
@@ -696,7 +696,7 @@ public class Jobs extends org.apache.acf
   /** This method is called on a restart.
   */
   public void restart()
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -758,7 +758,7 @@ public class Jobs extends org.apache.acf
       // No need to do anything to the queue; it looks like it can take care of
       // itself.
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -779,7 +779,7 @@ public class Jobs extends org.apache.acf
   *@param oldStatusValue is the current status value for the job.
   */
   public void noteOutputConnectorDeregistration(Long jobID, int oldStatusValue)
-    throws LCFException
+    throws ACFException
   {
     int newStatusValue;
     // The following states are special, in that when the underlying connector goes away, the jobs
@@ -826,7 +826,7 @@ public class Jobs extends org.apache.acf
   *@param oldStatusValue is the current status value for the job.
   */
   public void noteOutputConnectorRegistration(Long jobID, int oldStatusValue)
-    throws LCFException
+    throws ACFException
   {
     int newStatusValue;
     // The following states are special, in that when the underlying connector returns, the jobs
@@ -869,7 +869,7 @@ public class Jobs extends org.apache.acf
   *@param oldStatusValue is the current status value for the job.
   */
   public void noteConnectorDeregistration(Long jobID, int oldStatusValue)
-    throws LCFException
+    throws ACFException
   {
     int newStatusValue;
     // The following states are special, in that when the underlying connector goes away, the jobs
@@ -913,7 +913,7 @@ public class Jobs extends org.apache.acf
   *@param oldStatusValue is the current status value for the job.
   */
   public void noteConnectorRegistration(Long jobID, int oldStatusValue)
-    throws LCFException
+    throws ACFException
   {
     int newStatusValue;
     // The following states are special, in that when the underlying connector returns, the jobs
@@ -953,7 +953,7 @@ public class Jobs extends org.apache.acf
   * is signalled.
   */
   public void noteConnectionChange(String connectionName)
-    throws LCFException
+    throws ACFException
   {
     // No cache keys need invalidation, since we're changing the start time, not the status.
     HashMap newValues = new HashMap();
@@ -968,7 +968,7 @@ public class Jobs extends org.apache.acf
   * is signalled.
   */
   public void noteOutputConnectionChange(String connectionName)
-    throws LCFException
+    throws ACFException
   {
     // No cache keys need invalidation, since we're changing the start time, not the status.
     HashMap newValues = new HashMap();
@@ -981,7 +981,7 @@ public class Jobs extends org.apache.acf
   /** Check whether a job's status indicates that it is in ACTIVE or ACTIVESEEDING state.
   */
   public boolean checkJobActive(Long jobID)
-    throws LCFException
+    throws ACFException
   {
     StringSet cacheKeys = new StringSet(getJobStatusKey());
     ArrayList list = new ArrayList();
@@ -1000,7 +1000,7 @@ public class Jobs extends org.apache.acf
   /** Reset startup worker thread status.
   */
   public void resetStartupWorkerStatus()
-    throws LCFException
+    throws ACFException
   {
     // We have to handle all states that the startup thread would resolve, and change them to something appropriate.
 
@@ -1025,7 +1025,7 @@ public class Jobs extends org.apache.acf
   /** Reset as part of restoring seeding worker threads.
   */
   public void resetSeedingWorkerStatus()
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -1072,7 +1072,7 @@ public class Jobs extends org.apache.acf
       performUpdate(map,"WHERE "+statusField+"=?",list,invKey);
 
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -1095,7 +1095,7 @@ public class Jobs extends org.apache.acf
   *@param windowEnd is the window end time, if any
   */
   public void startJob(Long jobID, Long windowEnd)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(jobID);
@@ -1113,7 +1113,7 @@ public class Jobs extends org.apache.acf
   *@param startTime is the current time in milliseconds from start of epoch.
   */
   public void noteJobStarted(Long jobID, long startTime)
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -1123,7 +1123,7 @@ public class Jobs extends org.apache.acf
       IResultSet set = performQuery("SELECT "+statusField+","+connectionNameField+","+outputNameField+" FROM "+getTableName()+" WHERE "+
         idField+"=? FOR UPDATE",list,null,null);
       if (set.getRowCount() == 0)
-        throw new LCFException("Can't find job "+jobID.toString());
+        throw new ACFException("Can't find job "+jobID.toString());
       IResultRow row = set.getRow(0);
       int status = stringToStatus((String)row.getValue(statusField));
       int newStatus;
@@ -1153,7 +1153,7 @@ public class Jobs extends org.apache.acf
         break;
       default:
         // Complain!
-        throw new LCFException("Unexpected job status encountered: "+Integer.toString(status));
+        throw new ACFException("Unexpected job status encountered: "+Integer.toString(status));
       }
 
       HashMap map = new HashMap();
@@ -1165,7 +1165,7 @@ public class Jobs extends org.apache.acf
       map.put(lastCheckTimeField,new Long(startTime));
       performUpdate(map,"WHERE "+idField+"=?",list,new StringSet(getJobStatusKey()));
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -1186,7 +1186,7 @@ public class Jobs extends org.apache.acf
   *@param seedTime is the job seed time.
   */
   public void noteJobSeeded(Long jobID, long seedTime)
-    throws LCFException
+    throws ACFException
   {
     // We have to convert the current status to the non-seeding equivalent
     beginTransaction();
@@ -1197,7 +1197,7 @@ public class Jobs extends org.apache.acf
       IResultSet set = performQuery("SELECT "+statusField+" FROM "+getTableName()+" WHERE "+
         idField+"=? FOR UPDATE",list,null,null);
       if (set.getRowCount() == 0)
-        throw new LCFException("Can't find job "+jobID.toString());
+        throw new ACFException("Can't find job "+jobID.toString());
       IResultRow row = set.getRow(0);
       int status = stringToStatus((String)row.getValue(statusField));
       int newStatus;
@@ -1231,7 +1231,7 @@ public class Jobs extends org.apache.acf
         newStatus = STATUS_ABORTINGFORRESTART;
         break;
       default:
-        throw new LCFException("Unexpected job status encountered: "+Integer.toString(status));
+        throw new ACFException("Unexpected job status encountered: "+Integer.toString(status));
       }
       HashMap map = new HashMap();
       map.put(statusField,statusToString(newStatus));
@@ -1243,7 +1243,7 @@ public class Jobs extends org.apache.acf
       signalRollback();
       throw e;
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -1261,7 +1261,7 @@ public class Jobs extends org.apache.acf
   *@param windowEnd is the window end time, if any.
   */
   public void unwaitJob(Long jobID, int newStatus, Long windowEnd)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(jobID);
@@ -1277,7 +1277,7 @@ public class Jobs extends org.apache.acf
   *  STATUS_ACTIVEWAITSEEDING or STATUS_PAUSEDWAITSEEDING)
   */
   public void waitJob(Long jobID, int newStatus)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(jobID);
@@ -1293,7 +1293,7 @@ public class Jobs extends org.apache.acf
   *@return true if there wasn't an abort already logged for this job.
   */
   public boolean abortJob(Long jobID, String errorText)
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -1304,7 +1304,7 @@ public class Jobs extends org.apache.acf
       IResultSet set = performQuery("SELECT "+statusField+" FROM "+getTableName()+
         " WHERE "+idField+"=? FOR UPDATE",list,null,null);
       if (set.getRowCount() == 0)
-        throw new LCFException("Job does not exist: "+jobID);
+        throw new ACFException("Job does not exist: "+jobID);
       IResultRow row = set.getRow(0);
       int status = stringToStatus(row.getValue(statusField).toString());
       if (status == STATUS_ABORTING || status == STATUS_ABORTINGSEEDING || status == STATUS_ABORTINGSTARTINGUP)
@@ -1338,7 +1338,7 @@ public class Jobs extends org.apache.acf
         newStatus = STATUS_ABORTINGSEEDING;
         break;
       default:
-        throw new LCFException("Job "+jobID+" is not active");
+        throw new ACFException("Job "+jobID+" is not active");
       }
       // Pause the job
       HashMap map = new HashMap();
@@ -1347,7 +1347,7 @@ public class Jobs extends org.apache.acf
       performUpdate(map,"WHERE "+idField+"=?",list,new StringSet(getJobStatusKey()));
       return true;
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -1367,7 +1367,7 @@ public class Jobs extends org.apache.acf
   *@param jobID is the job id.
   */
   public void abortRestartJob(Long jobID)
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -1378,7 +1378,7 @@ public class Jobs extends org.apache.acf
       IResultSet set = performQuery("SELECT "+statusField+" FROM "+getTableName()+
         " WHERE "+idField+"=? FOR UPDATE",list,null,null);
       if (set.getRowCount() == 0)
-        throw new LCFException("Job does not exist: "+jobID);
+        throw new ACFException("Job does not exist: "+jobID);
       IResultRow row = set.getRow(0);
       int status = stringToStatus(row.getValue(statusField).toString());
       if (status == STATUS_ABORTINGFORRESTART || status == STATUS_ABORTINGFORRESTARTSEEDING || status == STATUS_ABORTINGSTARTINGUPFORRESTART)
@@ -1409,14 +1409,14 @@ public class Jobs extends org.apache.acf
         newStatus = STATUS_ABORTINGFORRESTARTSEEDING;
         break;
       default:
-        throw new LCFException("Job "+jobID+" is not restartable");
+        throw new ACFException("Job "+jobID+" is not restartable");
       }
       // reset the job
       HashMap map = new HashMap();
       map.put(statusField,statusToString(newStatus));
       performUpdate(map,"WHERE "+idField+"=?",list,new StringSet(getJobStatusKey()));
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -1436,7 +1436,7 @@ public class Jobs extends org.apache.acf
   *@param jobID is the job id.
   */
   public void pauseJob(Long jobID)
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -1447,7 +1447,7 @@ public class Jobs extends org.apache.acf
       IResultSet set = performQuery("SELECT "+statusField+" FROM "+getTableName()+
         " WHERE "+idField+"=? FOR UPDATE",list,null,null);
       if (set.getRowCount() == 0)
-        throw new LCFException("Job does not exist: "+jobID);
+        throw new ACFException("Job does not exist: "+jobID);
       IResultRow row = set.getRow(0);
       int status = stringToStatus(row.getValue(statusField).toString());
       int newStatus;
@@ -1472,14 +1472,14 @@ public class Jobs extends org.apache.acf
         newStatus = STATUS_PAUSEDWAITSEEDING;
         break;
       default:
-        throw new LCFException("Job "+jobID+" is not active");
+        throw new ACFException("Job "+jobID+" is not active");
       }
       // Pause the job
       HashMap map = new HashMap();
       map.put(statusField,statusToString(newStatus));
       performUpdate(map,"WHERE "+idField+"=?",list,new StringSet(getJobStatusKey()));
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -1499,7 +1499,7 @@ public class Jobs extends org.apache.acf
   *@param jobID is the job id.
   */
   public void restartJob(Long jobID)
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -1510,7 +1510,7 @@ public class Jobs extends org.apache.acf
       IResultSet set = performQuery("SELECT "+statusField+","+connectionNameField+","+outputNameField+" FROM "+getTableName()+
         " WHERE "+idField+"=? FOR UPDATE",list,null,null);
       if (set.getRowCount() == 0)
-        throw new LCFException("Job does not exist: "+jobID);
+        throw new ACFException("Job does not exist: "+jobID);
       IResultRow row = set.getRow(0);
       int status = stringToStatus(row.getValue(statusField).toString());
       String connectionName = (String)row.getValue(connectionNameField);
@@ -1557,14 +1557,14 @@ public class Jobs extends org.apache.acf
         newStatus = STATUS_ACTIVEWAITSEEDING;
         break;
       default:
-        throw new LCFException("Job "+jobID+" is not paused");
+        throw new ACFException("Job "+jobID+" is not paused");
       }
       // Pause the job
       HashMap map = new HashMap();
       map.put(statusField,statusToString(newStatus));
       performUpdate(map,"WHERE "+idField+"=?",list,new StringSet(getJobStatusKey()));
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -1586,7 +1586,7 @@ public class Jobs extends org.apache.acf
   *@param reseedTime is the reseed time.
   */
   public void writeStatus(Long jobID, int status, Long reseedTime)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(jobID);
@@ -1601,7 +1601,7 @@ public class Jobs extends org.apache.acf
   *@param status is the desired status.
   */
   public void writeStatus(Long jobID, int status)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(jobID);
@@ -1615,7 +1615,7 @@ public class Jobs extends org.apache.acf
   *@param currentTime is the current time.
   */
   public void updateLastTime(Long jobID, long currentTime)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(jobID);
@@ -1630,7 +1630,7 @@ public class Jobs extends org.apache.acf
   *@param finishTime is the finish time.
   */
   public void finishJob(Long jobID, long finishTime)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(jobID);
@@ -1649,7 +1649,7 @@ public class Jobs extends org.apache.acf
   *@param jobID is the job id.
   */
   public void finishAbortJob(Long jobID, long abortTime)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(jobID);
@@ -1668,7 +1668,7 @@ public class Jobs extends org.apache.acf
   *@return true if there is a reference, false otherwise.
   */
   public boolean checkIfReference(String connectionName)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(connectionName);
@@ -1682,7 +1682,7 @@ public class Jobs extends org.apache.acf
   *@return true if there is a reference, false otherwise.
   */
   public boolean checkIfOutputReference(String connectionName)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(connectionName);
@@ -1696,7 +1696,7 @@ public class Jobs extends org.apache.acf
   *@return the set of job id's associated with that connection.
   */
   public IJobDescription[] findJobsForConnection(String connectionName)
-    throws LCFException
+    throws ACFException
   {
     // Begin transaction
     beginTransaction();
@@ -1725,7 +1725,7 @@ public class Jobs extends org.apache.acf
       }
       return loadMultiple(ids,readOnlies);
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -1748,7 +1748,7 @@ public class Jobs extends org.apache.acf
   *@return true if such jobs exist.
   */
   public boolean deletingJobsPresent()
-    throws LCFException
+    throws ACFException
   {
     IResultSet set = performQuery("SELECT "+idField+" FROM "+getTableName()+" WHERE "+
       statusField+" IN ("+quoteSQLString(statusToString(STATUS_READYFORDELETE))+","+
@@ -1763,7 +1763,7 @@ public class Jobs extends org.apache.acf
   *@return true if such jobs exist.
   */
   public boolean activeJobsPresent()
-    throws LCFException
+    throws ACFException
   {
     // To improve the postgres CPU usage of the system at rest, we do a *fast* check to be
     // sure there are ANY jobs in an active state.
@@ -1782,11 +1782,11 @@ public class Jobs extends org.apache.acf
   *@return the status value.
   */
   public static int stringToStatus(String value)
-    throws LCFException
+    throws ACFException
   {
     Integer x = (Integer)statusMap.get(value);
     if (x == null)
-      throw new LCFException("Bad status value: '"+value+"'");
+      throw new ACFException("Bad status value: '"+value+"'");
     return x.intValue();
   }
 
@@ -1795,7 +1795,7 @@ public class Jobs extends org.apache.acf
   *@return the string.
   */
   public static String statusToString(int status)
-    throws LCFException
+    throws ACFException
   {
     switch (status)
     {
@@ -1853,7 +1853,7 @@ public class Jobs extends org.apache.acf
       return "D";
 
     default:
-      throw new LCFException("Bad status value: "+Integer.toString(status));
+      throw new ACFException("Bad status value: "+Integer.toString(status));
     }
   }
 
@@ -1862,11 +1862,11 @@ public class Jobs extends org.apache.acf
   *@return the type value.
   */
   public static int stringToType(String value)
-    throws LCFException
+    throws ACFException
   {
     Integer x = (Integer)typeMap.get(value);
     if (x == null)
-      throw new LCFException("Bad type value: '"+value+"'");
+      throw new ACFException("Bad type value: '"+value+"'");
     return x.intValue();
   }
 
@@ -1875,7 +1875,7 @@ public class Jobs extends org.apache.acf
   *@return the string.
   */
   public static String typeToString(int type)
-    throws LCFException
+    throws ACFException
   {
     switch (type)
     {
@@ -1884,27 +1884,27 @@ public class Jobs extends org.apache.acf
     case TYPE_SPECIFIED:
       return "S";
     default:
-      throw new LCFException("Bad type: "+Integer.toString(type));
+      throw new ACFException("Bad type: "+Integer.toString(type));
     }
   }
 
   /** Go from string to hopcount mode.
   */
   public static int stringToHopcountMode(String value)
-    throws LCFException
+    throws ACFException
   {
     if (value == null || value.length() == 0)
       return HOPCOUNT_ACCURATE;
     Integer x = (Integer)hopmodeMap.get(value);
     if (x == null)
-      throw new LCFException("Bad hopcount mode value: '"+value+"'");
+      throw new ACFException("Bad hopcount mode value: '"+value+"'");
     return x.intValue();
   }
 
   /** Go from hopcount mode to string.
   */
   public static String hopcountModeToString(int value)
-    throws LCFException
+    throws ACFException
   {
     switch(value)
     {
@@ -1915,7 +1915,7 @@ public class Jobs extends org.apache.acf
     case HOPCOUNT_NEVERDELETE:
       return "V";
     default:
-      throw new LCFException("Unknown hopcount mode value "+Integer.toString(value));
+      throw new ACFException("Unknown hopcount mode value "+Integer.toString(value));
     }
   }
 
@@ -1924,11 +1924,11 @@ public class Jobs extends org.apache.acf
   *@return the start method value.
   */
   public static int stringToStartMethod(String value)
-    throws LCFException
+    throws ACFException
   {
     Integer x = (Integer)startMap.get(value);
     if (x == null)
-      throw new LCFException("Bad start method value: '"+value+"'");
+      throw new ACFException("Bad start method value: '"+value+"'");
     return x.intValue();
   }
 
@@ -1937,7 +1937,7 @@ public class Jobs extends org.apache.acf
   *@return a string.
   */
   public static String startMethodToString(int startMethod)
-    throws LCFException
+    throws ACFException
   {
     switch(startMethod)
     {
@@ -1948,7 +1948,7 @@ public class Jobs extends org.apache.acf
     case START_DISABLE:
       return "D";
     default:
-      throw new LCFException("Bad start method: "+Integer.toString(startMethod));
+      throw new ACFException("Bad start method: "+Integer.toString(startMethod));
     }
   }
 
@@ -1958,7 +1958,7 @@ public class Jobs extends org.apache.acf
   *@return the enumerated value.
   */
   public static EnumeratedValues stringToEnumeratedValue(String value)
-    throws LCFException
+    throws ACFException
   {
     if (value == null)
       return null;
@@ -1984,7 +1984,7 @@ public class Jobs extends org.apache.acf
     }
     catch (NumberFormatException e)
     {
-      throw new LCFException("Bad number: '"+value+"'",e);
+      throw new ACFException("Bad number: '"+value+"'",e);
     }
 
   }
@@ -2036,7 +2036,7 @@ public class Jobs extends org.apache.acf
   *@return the corresponding job descriptions.
   */
   protected JobDescription[] getJobsMultiple(Long[] ids)
-    throws LCFException
+    throws ACFException
   {
     // Fetch all the jobs, but only once for each ID.  Then, assign each one by id into the final array.
     HashMap uniqueIDs = new HashMap();
@@ -2078,7 +2078,7 @@ public class Jobs extends org.apache.acf
       signalRollback();
       throw e;
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -2109,7 +2109,7 @@ public class Jobs extends org.apache.acf
   *@param params is the set of parameters.
   */
   protected void getJobsChunk(Map returnValues, String idList, ArrayList params)
-    throws LCFException
+    throws ACFException
   {
     try
     {
@@ -2150,7 +2150,7 @@ public class Jobs extends org.apache.acf
     }
     catch (NumberFormatException e)
     {
-      throw new LCFException("Bad number",e);
+      throw new ACFException("Bad number",e);
     }
   }
 
@@ -2257,7 +2257,7 @@ public class Jobs extends org.apache.acf
     * @return the newly created objects to cache, or null, if any object cannot be created.
     *  The order of the returned objects must correspond to the order of the object descriptinos.
     */
-    public Object[] create(ICacheDescription[] objectDescriptions) throws LCFException
+    public Object[] create(ICacheDescription[] objectDescriptions) throws ACFException
     {
       // Turn the object descriptions into the parameters for the ToolInstance requests
       Long[] ids = new Long[objectDescriptions.length];
@@ -2280,7 +2280,7 @@ public class Jobs extends org.apache.acf
     * @param objectDescription is the unique identifier of the object.
     * @param cachedObject is the cached object.
     */
-    public void exists(ICacheDescription objectDescription, Object cachedObject) throws LCFException
+    public void exists(ICacheDescription objectDescription, Object cachedObject) throws ACFException
     {
       // Cast what came in as what it really is
       JobObjectDescription objectDesc = (JobObjectDescription)objectDescription;
@@ -2296,7 +2296,7 @@ public class Jobs extends org.apache.acf
     /** Perform the desired operation.  This method is called after either createGetObject()
     * or exists() is called for every requested object.
     */
-    public void execute() throws LCFException
+    public void execute() throws ACFException
     {
       // Does nothing; we only want to fetch objects in this cacher.
     }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/PrereqEventManager.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/PrereqEventManager.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/PrereqEventManager.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/PrereqEventManager.java Mon Aug 23 18:08:32 2010
@@ -50,7 +50,7 @@ public class PrereqEventManager extends 
   *@param database is the database handle.
   */
   public PrereqEventManager(IDBInterface database)
-    throws LCFException
+    throws ACFException
   {
     super(database,"prereqevents");
   }
@@ -58,7 +58,7 @@ public class PrereqEventManager extends 
   /** Install or upgrade this table.
   */
   public void install(String ownerTableName, String ownerColumn)
-    throws LCFException
+    throws ACFException
   {
     // Standard practice: Outer loop for upgrade support.
     while (true)
@@ -105,14 +105,14 @@ public class PrereqEventManager extends 
   /** Uninstall.
   */
   public void deinstall()
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
     {
       performDrop(null);
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -130,7 +130,7 @@ public class PrereqEventManager extends 
 
   /** Delete specified rows, based on jobqueue criteria. */
   public void deleteRows(String parentTableName, String joinField, String parentCriteria, ArrayList list)
-    throws LCFException
+    throws ACFException
   {
     StringBuffer sb = new StringBuffer();
     sb.append("WHERE EXISTS(SELECT 'x' FROM ").append(parentTableName).append(" WHERE ").append(joinField).append("=")
@@ -144,7 +144,7 @@ public class PrereqEventManager extends 
 
   /** Delete specified rows, as directly specified without a join. */
   public void deleteRows(String ownerQueryPart, ArrayList list)
-    throws LCFException
+    throws ACFException
   {
     performDelete("WHERE "+ownerField+" IN("+ownerQueryPart+")",list,null);
     reindexTracker.noteEvent();
@@ -152,7 +152,7 @@ public class PrereqEventManager extends 
 
   /** Delete rows pertaining to a single entry */
   public void deleteRows(Long recordID)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(recordID);
@@ -162,7 +162,7 @@ public class PrereqEventManager extends 
 
   /** Add rows pertaining to a single entry */
   public void addRows(Long recordID, String[] eventNames)
-    throws LCFException
+    throws ACFException
   {
     if (eventNames != null)
     {
@@ -181,7 +181,7 @@ public class PrereqEventManager extends 
   /** Conditionally do analyze operation.
   */
   public void conditionallyMaintainTables()
-    throws LCFException
+    throws ACFException
   {
     if (tracker.checkAction())
     {

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/ScheduleManager.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/ScheduleManager.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/ScheduleManager.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/ScheduleManager.java Mon Aug 23 18:08:32 2010
@@ -48,7 +48,7 @@ public class ScheduleManager extends org
   *@param database is the database instance.
   */
   public ScheduleManager(IThreadContext threadContext, IDBInterface database)
-    throws LCFException
+    throws ACFException
   {
     super(database,"schedules");
   }
@@ -58,7 +58,7 @@ public class ScheduleManager extends org
   *@param owningTablePrimaryKey is the primary key of the owning table.
   */
   public void install(String ownerTable, String owningTablePrimaryKey)
-    throws LCFException
+    throws ACFException
   {
     // Standard practice: Outer loop to support upgrades
     while (true)
@@ -125,7 +125,7 @@ public class ScheduleManager extends org
   /** Uninstall.
   */
   public void deinstall()
-    throws LCFException
+    throws ACFException
   {
     performDrop(null);
   }
@@ -136,7 +136,7 @@ public class ScheduleManager extends org
   *@param ownerIDParams is the corresponding set of owner id parameters.
   */
   public void getRows(Map returnValues, String ownerIDList, ArrayList ownerIDParams)
-    throws LCFException
+    throws ACFException
   {
     IResultSet set = performQuery("SELECT * FROM "+getTableName()+" WHERE "+ownerIDField+" IN ("+ownerIDList+") ORDER BY "+ordinalField+" ASC",ownerIDParams,
       null,null);
@@ -164,7 +164,7 @@ public class ScheduleManager extends org
   *@param ownerIDParams is the corresponding set of owner id parameters.
   */
   public void getRowsAlternate(Map returnValues, String ownerIDList, ArrayList ownerIDParams)
-    throws LCFException
+    throws ACFException
   {
     IResultSet set = performQuery("SELECT * FROM "+getTableName()+" WHERE "+ownerIDField+" IN ("+ownerIDList+") ORDER BY "+ordinalField+" ASC",ownerIDParams,
       null,null);
@@ -197,7 +197,7 @@ public class ScheduleManager extends org
   *@param list is the job description that is the source of the schedule.
   */
   public void writeRows(Long ownerID, IJobDescription list)
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -222,7 +222,7 @@ public class ScheduleManager extends org
         i++;
       }
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -242,7 +242,7 @@ public class ScheduleManager extends org
   *@param ownerID is the owner whose rows to delete.
   */
   public void deleteRows(Long ownerID)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(ownerID);
@@ -254,7 +254,7 @@ public class ScheduleManager extends org
   *@return the enumerated value.
   */
   public static EnumeratedValues stringToEnumeratedValue(String value)
-    throws LCFException
+    throws ACFException
   {
     if (value == null)
       return null;
@@ -280,7 +280,7 @@ public class ScheduleManager extends org
     }
     catch (NumberFormatException e)
     {
-      throw new LCFException("Bad number: '"+value+"'",e);
+      throw new ACFException("Bad number: '"+value+"'",e);
     }
 
   }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/repository/RepositoryConnectionManager.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/repository/RepositoryConnectionManager.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/repository/RepositoryConnectionManager.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/repository/RepositoryConnectionManager.java Mon Aug 23 18:08:32 2010
@@ -23,7 +23,7 @@ import org.apache.acf.core.interfaces.*;
 import org.apache.acf.crawler.interfaces.*;
 import org.apache.acf.authorities.interfaces.*;
 import org.apache.acf.crawler.interfaces.CacheKeyFactory;
-import org.apache.acf.crawler.system.LCF;
+import org.apache.acf.crawler.system.ACF;
 
 
 /** This class is the manager of the repository connection description.  Inside, multiple database tables are managed,
@@ -60,7 +60,7 @@ public class RepositoryConnectionManager
   *@param threadContext is the thread context.
   */
   public RepositoryConnectionManager(IThreadContext threadContext, IDBInterface database)
-    throws LCFException
+    throws ACFException
   {
     super(database,"repoconnections");
 
@@ -73,7 +73,7 @@ public class RepositoryConnectionManager
   /** Install the manager.
   */
   public void install()
-    throws LCFException
+    throws ACFException
   {
     // First, get the authority manager table name and name column
     IAuthorityConnectionManager authMgr = AuthorityConnectionManagerFactory.make(threadContext);
@@ -113,7 +113,7 @@ public class RepositoryConnectionManager
   /** Uninstall the manager.
   */
   public void deinstall()
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -122,7 +122,7 @@ public class RepositoryConnectionManager
       historyManager.deinstall();
       performDrop(null);
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -140,62 +140,62 @@ public class RepositoryConnectionManager
 
   /** Export configuration */
   public void exportConfiguration(java.io.OutputStream os)
-    throws java.io.IOException, LCFException
+    throws java.io.IOException, ACFException
   {
     // Write a version indicator
-    LCF.writeDword(os,1);
+    ACF.writeDword(os,1);
     // Get the authority list
     IRepositoryConnection[] list = getAllConnections();
     // Write the number of authorities
-    LCF.writeDword(os,list.length);
+    ACF.writeDword(os,list.length);
     // Loop through the list and write the individual repository connection info
     int i = 0;
     while (i < list.length)
     {
       IRepositoryConnection conn = list[i++];
-      LCF.writeString(os,conn.getName());
-      LCF.writeString(os,conn.getDescription());
-      LCF.writeString(os,conn.getClassName());
-      LCF.writeString(os,conn.getConfigParams().toXML());
-      LCF.writeString(os,conn.getACLAuthority());
-      LCF.writeDword(os,conn.getMaxConnections());
+      ACF.writeString(os,conn.getName());
+      ACF.writeString(os,conn.getDescription());
+      ACF.writeString(os,conn.getClassName());
+      ACF.writeString(os,conn.getConfigParams().toXML());
+      ACF.writeString(os,conn.getACLAuthority());
+      ACF.writeDword(os,conn.getMaxConnections());
       String[] throttles = conn.getThrottles();
-      LCF.writeDword(os,throttles.length);
+      ACF.writeDword(os,throttles.length);
       int j = 0;
       while (j < throttles.length)
       {
         String throttleName = throttles[j++];
-        LCF.writeString(os,throttleName);
-        LCF.writeString(os,conn.getThrottleDescription(throttleName));
-        LCF.writefloat(os,conn.getThrottleValue(throttleName));
+        ACF.writeString(os,throttleName);
+        ACF.writeString(os,conn.getThrottleDescription(throttleName));
+        ACF.writefloat(os,conn.getThrottleValue(throttleName));
       }
     }
   }
 
   /** Import configuration */
   public void importConfiguration(java.io.InputStream is)
-    throws java.io.IOException, LCFException
+    throws java.io.IOException, ACFException
   {
-    int version = LCF.readDword(is);
+    int version = ACF.readDword(is);
     if (version != 1)
       throw new java.io.IOException("Unknown repository connection configuration version: "+Integer.toString(version));
-    int count = LCF.readDword(is);
+    int count = ACF.readDword(is);
     int i = 0;
     while (i < count)
     {
       IRepositoryConnection conn = create();
-      conn.setName(LCF.readString(is));
-      conn.setDescription(LCF.readString(is));
-      conn.setClassName(LCF.readString(is));
-      conn.getConfigParams().fromXML(LCF.readString(is));
-      conn.setACLAuthority(LCF.readString(is));
-      conn.setMaxConnections(LCF.readDword(is));
-      int throttleCount = LCF.readDword(is);
+      conn.setName(ACF.readString(is));
+      conn.setDescription(ACF.readString(is));
+      conn.setClassName(ACF.readString(is));
+      conn.getConfigParams().fromXML(ACF.readString(is));
+      conn.setACLAuthority(ACF.readString(is));
+      conn.setMaxConnections(ACF.readDword(is));
+      int throttleCount = ACF.readDword(is);
       int j = 0;
       while (j < throttleCount)
       {
-        String throttleName = LCF.readString(is);
-        conn.addThrottleValue(throttleName,LCF.readString(is),LCF.readfloat(is));
+        String throttleName = ACF.readString(is);
+        conn.addThrottleValue(throttleName,ACF.readString(is),ACF.readfloat(is));
         j++;
       }
       // Attempt to save this connection
@@ -208,7 +208,7 @@ public class RepositoryConnectionManager
   *@return an array of connection objects.
   */
   public IRepositoryConnection[] getAllConnections()
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -229,7 +229,7 @@ public class RepositoryConnectionManager
       }
       return loadMultiple(names);
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -250,7 +250,7 @@ public class RepositoryConnectionManager
   *@return the loaded connection object, or null if not found.
   */
   public IRepositoryConnection load(String name)
-    throws LCFException
+    throws ACFException
   {
     return loadMultiple(new String[]{name})[0];
   }
@@ -260,7 +260,7 @@ public class RepositoryConnectionManager
   *@return the loaded connection objects.
   */
   public IRepositoryConnection[] loadMultiple(String[] names)
-    throws LCFException
+    throws ACFException
   {
     // Build description objects
     RepositoryConnectionDescription[] objectDescriptions = new RepositoryConnectionDescription[names.length];
@@ -283,7 +283,7 @@ public class RepositoryConnectionManager
   *@return the new object.
   */
   public IRepositoryConnection create()
-    throws LCFException
+    throws ACFException
   {
     RepositoryConnection rval = new RepositoryConnection();
     return rval;
@@ -293,7 +293,7 @@ public class RepositoryConnectionManager
   *@param object is the object to save.
   */
   public void save(IRepositoryConnection object)
-    throws LCFException
+    throws ACFException
   {
     StringSetBuffer ssb = new StringSetBuffer();
     ssb.add(getRepositoryConnectionsKey());
@@ -307,7 +307,7 @@ public class RepositoryConnectionManager
       {
         performLock();
         // Notify of a change to the configuration
-        LCF.noteConfigurationChange();
+        ACF.noteConfigurationChange();
         // See whether the instance exists
         ArrayList params = new ArrayList();
         params.add(object.getName());
@@ -355,7 +355,7 @@ public class RepositoryConnectionManager
 
         cacheManager.invalidateKeys(ch);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
         signalRollback();
         throw e;
@@ -381,7 +381,7 @@ public class RepositoryConnectionManager
   * name does not exist, no error is returned.
   */
   public void delete(String name)
-    throws LCFException
+    throws ACFException
   {
     // Grab a job manager handle.  We will need to check if any jobs refer to this connection.
     IJobManager jobManager = JobManagerFactory.make(threadContext);
@@ -398,8 +398,8 @@ public class RepositoryConnectionManager
       {
         // Check if any jobs refer to this connection name
         if (jobManager.checkIfReference(name))
-          throw new LCFException("Can't delete repository connection '"+name+"': existing jobs refer to it");
-        LCF.noteConfigurationChange();
+          throw new ACFException("Can't delete repository connection '"+name+"': existing jobs refer to it");
+        ACF.noteConfigurationChange();
         throttleSpecManager.deleteRows(name);
         historyManager.deleteOwner(name,null);
         ArrayList params = new ArrayList();
@@ -407,7 +407,7 @@ public class RepositoryConnectionManager
         performDelete("WHERE "+nameField+"=?",params,null);
         cacheManager.invalidateKeys(ch);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
         signalRollback();
         throw e;
@@ -434,7 +434,7 @@ public class RepositoryConnectionManager
   *@return true if referenced, false otherwise.
   */
   public boolean isReferenced(String authorityName)
-    throws LCFException
+    throws ACFException
   {
     StringSetBuffer ssb = new StringSetBuffer();
     ssb.add(getRepositoryConnectionsKey());
@@ -451,7 +451,7 @@ public class RepositoryConnectionManager
   *@return the repository connections that use that connector.
   */
   public String[] findConnectionsForConnector(String className)
-    throws LCFException
+    throws ACFException
   {
     StringSetBuffer ssb = new StringSetBuffer();
     ssb.add(getRepositoryConnectionsKey());
@@ -477,7 +477,7 @@ public class RepositoryConnectionManager
   *@return true if the underlying connector is registered.
   */
   public boolean checkConnectorExists(String name)
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -490,13 +490,13 @@ public class RepositoryConnectionManager
       IResultSet set = performQuery("SELECT "+classNameField+" FROM "+getTableName()+" WHERE "+nameField+"=?",params,
         localCacheKeys,null);
       if (set.getRowCount() == 0)
-        throw new LCFException("No such connection: '"+name+"'");
+        throw new ACFException("No such connection: '"+name+"'");
       IResultRow row = set.getRow(0);
       String className = (String)row.getValue(classNameField);
       IConnectorManager cm = ConnectorManagerFactory.make(threadContext);
       return cm.isInstalled(className);
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -548,7 +548,7 @@ public class RepositoryConnectionManager
   */
   public void recordHistory(String connectionName, Long startTime, String activityType, Long dataSize,
     String entityIdentifier, String resultCode, String resultDescription, String[] childIdentifiers)
-    throws LCFException
+    throws ACFException
   {
     long endTimeValue = System.currentTimeMillis();
     long startTimeValue;
@@ -580,7 +580,7 @@ public class RepositoryConnectionManager
   *@return the number of rows included by the criteria.
   */
   public long countHistoryRows(String connectionName, FilterCriteria criteria)
-    throws LCFException
+    throws ACFException
   {
     return historyManager.countHistoryRows(connectionName,criteria);
   }
@@ -596,7 +596,7 @@ public class RepositoryConnectionManager
   *@param maxRowCount is the maximum number of rows to include.
   */
   public IResultSet genHistorySimple(String connectionName, FilterCriteria criteria, SortOrder sort, int startRow, int maxRowCount)
-    throws LCFException
+    throws ACFException
   {
     return historyManager.simpleReport(connectionName,criteria,sort,startRow,maxRowCount);
   }
@@ -619,7 +619,7 @@ public class RepositoryConnectionManager
   */
   public IResultSet genHistoryActivityCount(String connectionName, FilterCriteria criteria, SortOrder sort, BucketDescription idBucket,
     long interval, int startRow, int maxRowCount)
-    throws LCFException
+    throws ACFException
   {
     return historyManager.maxActivityCountReport(connectionName,criteria,sort,idBucket,interval,startRow,maxRowCount);
   }
@@ -642,7 +642,7 @@ public class RepositoryConnectionManager
   */
   public IResultSet genHistoryByteCount(String connectionName, FilterCriteria criteria, SortOrder sort, BucketDescription idBucket,
     long interval, int startRow, int maxRowCount)
-    throws LCFException
+    throws ACFException
   {
     return historyManager.maxByteCountReport(connectionName,criteria,sort,idBucket,interval,startRow,maxRowCount);
   }
@@ -664,7 +664,7 @@ public class RepositoryConnectionManager
   */
   public IResultSet genHistoryResultCodes(String connectionName, FilterCriteria criteria, SortOrder sort,
     BucketDescription resultCodeBucket, BucketDescription idBucket, int startRow, int maxRowCount)
-    throws LCFException
+    throws ACFException
   {
     return historyManager.resultCodesReport(connectionName,criteria,sort,resultCodeBucket,idBucket,startRow,maxRowCount);
   }
@@ -696,7 +696,7 @@ public class RepositoryConnectionManager
   *@return the corresponding repository connection objects.
   */
   protected RepositoryConnection[] getRepositoryConnectionsMultiple(String[] connectionNames)
-    throws LCFException
+    throws ACFException
   {
     RepositoryConnection[] rval = new RepositoryConnection[connectionNames.length];
     HashMap returnIndex = new HashMap();
@@ -740,7 +740,7 @@ public class RepositoryConnectionManager
       signalRollback();
       throw e;
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -758,7 +758,7 @@ public class RepositoryConnectionManager
   *@param params is the set of parameters.
   */
   protected void getRepositoryConnectionsChunk(RepositoryConnection[] rval, Map returnIndex, String idList, ArrayList params)
-    throws LCFException
+    throws ACFException
   {
     IResultSet set;
     set = performQuery("SELECT * FROM "+getTableName()+" WHERE "+
@@ -883,7 +883,7 @@ public class RepositoryConnectionManager
     * @return the newly created objects to cache, or null, if any object cannot be created.
     *  The order of the returned objects must correspond to the order of the object descriptinos.
     */
-    public Object[] create(ICacheDescription[] objectDescriptions) throws LCFException
+    public Object[] create(ICacheDescription[] objectDescriptions) throws ACFException
     {
       // Turn the object descriptions into the parameters for the ToolInstance requests
       String[] connectionNames = new String[objectDescriptions.length];
@@ -906,7 +906,7 @@ public class RepositoryConnectionManager
     * @param objectDescription is the unique identifier of the object.
     * @param cachedObject is the cached object.
     */
-    public void exists(ICacheDescription objectDescription, Object cachedObject) throws LCFException
+    public void exists(ICacheDescription objectDescription, Object cachedObject) throws ACFException
     {
       // Cast what came in as what it really is
       RepositoryConnectionDescription objectDesc = (RepositoryConnectionDescription)objectDescription;
@@ -924,7 +924,7 @@ public class RepositoryConnectionManager
     /** Perform the desired operation.  This method is called after either createGetObject()
     * or exists() is called for every requested object.
     */
-    public void execute() throws LCFException
+    public void execute() throws ACFException
     {
       // Does nothing; we only want to fetch objects in this cacher.
     }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/repository/RepositoryHistoryManager.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/repository/RepositoryHistoryManager.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/repository/RepositoryHistoryManager.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/repository/RepositoryHistoryManager.java Mon Aug 23 18:08:32 2010
@@ -49,7 +49,7 @@ public class RepositoryHistoryManager ex
   *@param database is the database instance.
   */
   public RepositoryHistoryManager(IThreadContext tc, IDBInterface database)
-    throws LCFException
+    throws ACFException
   {
     super(database,"repohistory");
     this.threadContext = tc;
@@ -60,7 +60,7 @@ public class RepositoryHistoryManager ex
   *@param parentField is the parent field.
   */
   public void install(String parentTable, String parentField)
-    throws LCFException
+    throws ACFException
   {
     // Always have an outer loop, in case of upgrade
     while (true)
@@ -137,7 +137,7 @@ public class RepositoryHistoryManager ex
   /** Uninstall the table.
   */
   public void deinstall()
-    throws LCFException
+    throws ACFException
   {
     performDrop(null);
   }
@@ -147,7 +147,7 @@ public class RepositoryHistoryManager ex
   *@param invKeys are the invalidation keys.
   */
   public void deleteOwner(String owner, StringSet invKeys)
-    throws LCFException
+    throws ACFException
   {
     ArrayList params = new ArrayList();
     params.add(owner);
@@ -158,7 +158,7 @@ public class RepositoryHistoryManager ex
   */
   public Long addRow(String connectionName, long startTime, long endTime, long dataSize, String activityType,
     String entityIdentifier, String resultCode, String resultDescription)
-    throws LCFException
+    throws ACFException
   {
     Long id = new Long(IDFactory.make(threadContext));
     HashMap map = new HashMap();
@@ -254,7 +254,7 @@ public class RepositoryHistoryManager ex
   * The resultset returned should have the following columns: "activity","starttime","elapsedtime","resultcode","resultdesc","bytes","identifier".
   */
   public IResultSet simpleReport(String connectionName, FilterCriteria criteria, SortOrder sort, int startRow, int maxRowCount)
-    throws LCFException
+    throws ACFException
   {
     // Build the query.
     StringBuffer sb = new StringBuffer("SELECT ");
@@ -278,14 +278,14 @@ public class RepositoryHistoryManager ex
   *@return the number of rows included by the criteria.
   */
   public long countHistoryRows(String connectionName, FilterCriteria criteria)
-    throws LCFException
+    throws ACFException
   {
     StringBuffer sb = new StringBuffer("SELECT COUNT(*) AS countcol FROM ");
     sb.append(getTableName());
     addCriteria(sb,"",connectionName,criteria,false);
     IResultSet set = performQuery(sb.toString(),null,null,null);
     if (set.getRowCount() < 1)
-      throw new LCFException("Expected at least one row");
+      throw new ACFException("Expected at least one row");
     IResultRow row = set.getRow(0);
     Long value = (Long)row.getValue("countcol");
     return value.longValue();
@@ -298,7 +298,7 @@ public class RepositoryHistoryManager ex
   */
   public IResultSet maxActivityCountReport(String connectionName, FilterCriteria filterCriteria, SortOrder sort, BucketDescription idBucket,
     long interval, int startRow, int maxRowCount)
-    throws LCFException
+    throws ACFException
   {
     // The query we will generate here looks like this:
     // SELECT *
@@ -385,7 +385,7 @@ public class RepositoryHistoryManager ex
   */
   public IResultSet maxByteCountReport(String connectionName, FilterCriteria filterCriteria, SortOrder sort, BucketDescription idBucket,
     long interval, int startRow, int maxRowCount)
-    throws LCFException
+    throws ACFException
   {
     // The query we will generate here looks like this:
     // SELECT *
@@ -473,7 +473,7 @@ public class RepositoryHistoryManager ex
   */
   public IResultSet resultCodesReport(String connectionName, FilterCriteria filterCriteria, SortOrder sort,
     BucketDescription resultCodeBucket, BucketDescription idBucket, int startRow, int maxRowCount)
-    throws LCFException
+    throws ACFException
   {
     // The query we'll use here will be:
     //
@@ -649,7 +649,7 @@ public class RepositoryHistoryManager ex
   /** Conditionally do analyze operation.
   */
   protected void conditionallyAnalyzeInsert()
-    throws LCFException
+    throws ACFException
   {
     synchronized (tracker)
     {

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/repository/ThrottleSpecManager.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/repository/ThrottleSpecManager.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/repository/ThrottleSpecManager.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/repository/ThrottleSpecManager.java Mon Aug 23 18:08:32 2010
@@ -41,7 +41,7 @@ public class ThrottleSpecManager extends
   *@param database is the database instance.
   */
   public ThrottleSpecManager(IDBInterface database)
-    throws LCFException
+    throws ACFException
   {
     super(database,"throttlespec");
   }
@@ -51,7 +51,7 @@ public class ThrottleSpecManager extends
   *@param owningTablePrimaryKey is the primary key of the owning table.
   */
   public void install(String ownerTable, String owningTablePrimaryKey)
-    throws LCFException
+    throws ACFException
   {
     // Always use a loop, in case upgrade needs it.
     while (true)
@@ -111,7 +111,7 @@ public class ThrottleSpecManager extends
   /** Uninstall.
   */
   public void deinstall()
-    throws LCFException
+    throws ACFException
   {
     performDrop(null);
   }
@@ -121,7 +121,7 @@ public class ThrottleSpecManager extends
   *@return a list, with columns: "description", "match", and "value".
   */
   public IResultSet readRows(String name)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(name);
@@ -136,7 +136,7 @@ public class ThrottleSpecManager extends
   *@param ownerNameParams is the corresponding set of connection name parameters.
   */
   public void getRows(IRepositoryConnection[] connections, Map indexMap, String ownerNameList, ArrayList ownerNameParams)
-    throws LCFException
+    throws ACFException
   {
     IResultSet set = performQuery("SELECT * FROM "+getTableName()+" WHERE "+ownerNameField+" IN ("+ownerNameList+")",ownerNameParams,
       null,null);
@@ -159,7 +159,7 @@ public class ThrottleSpecManager extends
   *@param connection is the connection to write throttle specs for.
   */
   public void writeRows(String owner, IRepositoryConnection connection)
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -181,7 +181,7 @@ public class ThrottleSpecManager extends
         performInsert(map,null);
       }
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -201,7 +201,7 @@ public class ThrottleSpecManager extends
   *@param owner is the owner whose rows to delete.
   */
   public void deleteRows(String owner)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(owner);