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 [17/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/interfaces/IJobManager.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IJobManager.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IJobManager.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IJobManager.java Mon Aug 23 18:08:32 2010
@@ -54,46 +54,46 @@ public interface IJobManager
   /** Install the job manager's tables.
   */
   public void install()
-    throws LCFException;
+    throws ACFException;
 
   /** Uninstall the job manager's tables.
   */
   public void deinstall()
-    throws LCFException;
+    throws ACFException;
 
   /** Export configuration */
   public void exportConfiguration(java.io.OutputStream os)
-    throws java.io.IOException, LCFException;
+    throws java.io.IOException, ACFException;
 
   /** Import configuration */
   public void importConfiguration(java.io.InputStream is)
-    throws java.io.IOException, LCFException;
+    throws java.io.IOException, ACFException;
 
   /** Load a sorted list of job descriptions.
   *@return the list, sorted by description.
   */
   public IJobDescription[] getAllJobs()
-    throws LCFException;
+    throws ACFException;
 
   /** Create a new job.
   *@return the new job.
   */
   public IJobDescription createJob()
-    throws LCFException;
+    throws ACFException;
 
   /** Delete a job.
   *@param id is the job's identifier.  This method will purge all the records belonging to the job from the database, as
   * well as remove all documents indexed by the job from the index.
   */
   public void deleteJob(Long id)
-    throws LCFException;
+    throws ACFException;
 
   /** Load a job for editing.
   *@param id is the job's identifier.
   *@return null if the job doesn't exist.
   */
   public IJobDescription load(Long id)
-    throws LCFException;
+    throws ACFException;
 
   /** Load a job.
   *@param id is the job's identifier.
@@ -101,34 +101,34 @@ public interface IJobManager
   *@return null if the job doesn't exist.
   */
   public IJobDescription load(Long id, boolean readOnly)
-    throws LCFException;
+    throws ACFException;
 
   /** Save a job.
   *@param jobDescription is the job description.
   */
   public void save(IJobDescription jobDescription)
-    throws LCFException;
+    throws ACFException;
 
   /** See if there's a reference to a connection name.
   *@param connectionName is the name of the connection.
   *@return true if there is a reference, false otherwise.
   */
   public boolean checkIfReference(String connectionName)
-    throws LCFException;
+    throws ACFException;
 
   /** See if there's a reference to an output connection name.
   *@param connectionName is the name of the connection.
   *@return true if there is a reference, false otherwise.
   */
   public boolean checkIfOutputReference(String connectionName)
-    throws LCFException;
+    throws ACFException;
 
   /** Get the job IDs associated with a given connection name.
   *@param connectionName is the name of the connection.
   *@return the set of job id's associated with that connection.
   */
   public IJobDescription[] findJobsForConnection(String connectionName)
-    throws LCFException;
+    throws ACFException;
 
   // These methods cover activities that require interaction with the job queue.
   // The job queue is maintained underneath this interface, and all threads that perform
@@ -141,27 +141,27 @@ public interface IJobManager
   * state.
   */
   public void prepareForStart()
-    throws LCFException;
+    throws ACFException;
 
   /** Reset as part of restoring document worker threads.
   */
   public void resetDocumentWorkerStatus()
-    throws LCFException;
+    throws ACFException;
 
   /** Reset as part of restoring seeding threads.
   */
   public void resetSeedingWorkerStatus()
-    throws LCFException;
+    throws ACFException;
 
   /** Reset as part of restoring doc delete threads.
   */
   public void resetDocDeleteWorkerStatus()
-    throws LCFException;
+    throws ACFException;
 
   /** Reset as part of restoring startup threads.
   */
   public void resetStartupWorkerStatus()
-    throws LCFException;
+    throws ACFException;
 
   // These methods support the "set doc priority" thread
 
@@ -173,7 +173,7 @@ public interface IJobManager
   *@return the document descriptions.
   */
   public DocumentDescription[] getNextAlreadyProcessedReprioritizationDocuments(long currentTime, int n)
-    throws LCFException;
+    throws ACFException;
 
   /** Get a list of not-yet-processed documents to reprioritize.  Documents in all jobs will be
   * returned by this method.  Up to n document descriptions will be returned.
@@ -183,7 +183,7 @@ public interface IJobManager
   *@return the document descriptions.
   */
   public DocumentDescription[] getNextNotYetProcessedReprioritizationDocuments(long currentTime, int n)
-    throws LCFException;
+    throws ACFException;
 
   /** Save a set of document priorities.  In the case where a document was eligible to have its
   * priority set, but it no longer is eligible, then the provided priority will not be written.
@@ -192,7 +192,7 @@ public interface IJobManager
   *@param priorities are the desired priorities.
   */
   public void writeDocumentPriorities(long currentTime, DocumentDescription[] descriptions, double[] priorities)
-    throws LCFException;
+    throws ACFException;
 
   // This method supports the "expiration" thread
 
@@ -206,7 +206,7 @@ public interface IJobManager
   *@return the array of document descriptions to expire.
   */
   public DocumentDescription[] getExpiredDocuments(int n, long currentTime)
-    throws LCFException;
+    throws ACFException;
 
   // This method supports the "queue stuffer" thread
 
@@ -229,7 +229,7 @@ public interface IJobManager
   public DocumentDescription[] getNextDocuments(int n, long currentTime, long interval,
     BlockingDocuments blockingDocuments, PerformanceStatistics statistics,
     DepthStatistics scanRecord)
-    throws LCFException;
+    throws ACFException;
 
   // These methods support the individual fetch/process threads.
 
@@ -239,25 +239,25 @@ public interface IJobManager
   *@return true if the job is in one of the "active" states.
   */
   public boolean checkJobActive(Long jobID)
-    throws LCFException;
+    throws ACFException;
 
   /** Verify if a job is still processing documents, or no longer has any outstanding active documents */
   public boolean checkJobBusy(Long jobID)
-    throws LCFException;
+    throws ACFException;
 
   /** Note completion of document processing by a job thread of a document.
   * This method causes the state of the document to be marked as "completed".
   *@param documentDescriptions are the description objects for the documents that were processed.
   */
   public void markDocumentCompletedMultiple(DocumentDescription[] documentDescriptions)
-    throws LCFException;
+    throws ACFException;
 
   /** Note completion of document processing by a job thread of a document.
   * This method causes the state of the document to be marked as "completed".
   *@param documentDescription is the description object for the document that was processed.
   */
   public void markDocumentCompleted(DocumentDescription documentDescription)
-    throws LCFException;
+    throws ACFException;
 
   /** Note deletion as result of document processing by a job thread of a document.
   *@param documentDescriptions are the set of description objects for the documents that were processed.
@@ -267,7 +267,7 @@ public interface IJobManager
   */
   public DocumentDescription[] markDocumentDeletedMultiple(Long jobID, String[] legalLinkTypes, DocumentDescription[] documentDescriptions,
     int hopcountMethod)
-    throws LCFException;
+    throws ACFException;
 
   /** Note deletion as result of document processing by a job thread of a document.
   *@param documentDescription is the description object for the document that was processed.
@@ -277,7 +277,7 @@ public interface IJobManager
   */
   public DocumentDescription[] markDocumentDeleted(Long jobID, String[] legalLinkTypes, DocumentDescription documentDescription,
     int hopcountMethod)
-    throws LCFException;
+    throws ACFException;
 
   /** Requeue a document set because of carrydown changes.
   * This method is called when carrydown data is modified for a set of documents.  The documents must be requeued for immediate reprocessing, even to the
@@ -287,7 +287,7 @@ public interface IJobManager
   *@return a flag for each document priority, true if it was used, false otherwise.
   */
   public boolean[] carrydownChangeDocumentMultiple(DocumentDescription[] documentDescriptions, long currentTime, double[] docPriorities)
-    throws LCFException;
+    throws ACFException;
 
   /** Requeue a document because of carrydown changes.
   * This method is called when carrydown data is modified for a document.  The document must be requeued for immediate reprocessing, even to the
@@ -297,7 +297,7 @@ public interface IJobManager
   *@return a flag for the document priority, true if it was used, false otherwise.
   */
   public boolean carrydownChangeDocument(DocumentDescription documentDescription, long currentTime, double docPriority)
-    throws LCFException;
+    throws ACFException;
 
   /** Requeue a document for further processing in the future.
   * This method is called after a document is processed, when the job is a "continuous" one.
@@ -309,7 +309,7 @@ public interface IJobManager
   */
   public void requeueDocumentMultiple(DocumentDescription[] documentDescriptions, Long[] executeTimes,
     int[] actions)
-    throws LCFException;
+    throws ACFException;
 
 
   /** Requeue a document for further processing in the future.
@@ -322,7 +322,7 @@ public interface IJobManager
   */
   public void requeueDocument(DocumentDescription documentDescription, Long executeTime,
     int action)
-    throws LCFException;
+    throws ACFException;
 
   /** Reset documents for further processing in the future.
   * This method is called after a service interruption is thrown.
@@ -334,7 +334,7 @@ public interface IJobManager
   */
   public void resetDocumentMultiple(DocumentDescription[] documentDescriptions, long executeTime,
     int action, long failTime, int failCount)
-    throws LCFException;
+    throws ACFException;
 
   /** Reset an active document back to its former state.
   * This gets done when there's a service interruption and the document cannot be processed yet.
@@ -346,7 +346,7 @@ public interface IJobManager
   */
   public void resetDocument(DocumentDescription documentDescription, long executeTime, int action, long failTime,
     int failCount)
-    throws LCFException;
+    throws ACFException;
 
   /** Reset a set of deleting documents for further processing in the future.
   * This method is called after some unknown number of the documents were deleted, but then an ingestion service interruption occurred.
@@ -357,13 +357,13 @@ public interface IJobManager
   *@param documentDescriptions is the set of description objects for the document that was processed.
   */
   public void resetDeletingDocumentMultiple(DocumentDescription[] documentDescriptions)
-    throws LCFException;
+    throws ACFException;
 
   /** Reset a deleting document back to its former state.
   * This gets done when a deleting thread sees a service interruption, etc., from the ingestion system.
   */
   public void resetDeletingDocument(DocumentDescription documentDescription)
-    throws LCFException;
+    throws ACFException;
 
   /** Add an initial set of documents to the queue.
   * This method is called during job startup, when the queue is being loaded.
@@ -384,7 +384,7 @@ public interface IJobManager
     String[] docIDHashes, String[] docIDs, boolean overrideSchedule,
     int hopcountMethod, long currentTime, double[] documentPriorities,
     String[][] prereqEventNames)
-    throws LCFException;
+    throws ACFException;
 
   /** Add an initial set of remaining documents to the queue.
   * This method is called during job startup, when the queue is being loaded, to list documents that
@@ -398,7 +398,7 @@ public interface IJobManager
   public void addRemainingDocumentsInitial(Long jobID, String[] legalLinkTypes,
     String[] docIDHashes,
     int hopcountMethod)
-    throws LCFException;
+    throws ACFException;
 
   /** Signal that a seeding pass has been done.
   * Call this method at the end of a seeding pass.  It is used to perform the bookkeeping necessary to
@@ -411,20 +411,20 @@ public interface IJobManager
   */
   public void doneDocumentsInitial(Long jobID, String[] legalLinkTypes, boolean isPartial,
     int hopcountMethod)
-    throws LCFException;
+    throws ACFException;
 
   /** Begin an event sequence.
   *@param eventName is the name of the event.
   *@return true if the event could be created, or false if it's already there.
   */
   public boolean beginEventSequence(String eventName)
-    throws LCFException;
+    throws ACFException;
 
   /** Complete an event sequence.
   *@param eventName is the name of the event.
   */
   public void completeEventSequence(String eventName)
-    throws LCFException;
+    throws ACFException;
 
   /** Get the specified hop counts, with the limit as described.
   *@param jobID is the job identifier.
@@ -438,7 +438,7 @@ public interface IJobManager
   */
   public boolean[] findHopCounts(Long jobID, String[] legalLinkTypes, String[] docIDHashes, String linkType, int limit,
     int hopcountMethod)
-    throws LCFException;
+    throws ACFException;
 
   /** Get all the current seeds.
   * Returns the seed document identifiers for a job.
@@ -446,7 +446,7 @@ public interface IJobManager
   *@return the document identifier hashes that are currently considered to be seeds.
   */
   public String[] getAllSeeds(Long jobID)
-    throws LCFException;
+    throws ACFException;
 
   /** Add a document to the queue.
   * This method is called during document processing, when a document reference is discovered.
@@ -473,7 +473,7 @@ public interface IJobManager
     String relationshipType,
     int hopcountMethod, String[] dataNames, Object[][] dataValues,
     long currentTime, double priority, String[] prereqEventNames)
-    throws LCFException;
+    throws ACFException;
 
   /** Add documents to the queue in bulk.
   * This method is called during document processing, when a set of document references are discovered.
@@ -502,7 +502,7 @@ public interface IJobManager
     int hopcountMethod, String[][] dataNames, Object[][][] dataValues,
     long currentTime, double[] priorities,
     String[][] prereqEventNames)
-    throws LCFException;
+    throws ACFException;
 
   /** Complete adding child documents to the queue, for a set of documents.
   * This method is called at the end of document processing, to help the hopcount tracking engine do its bookkeeping.
@@ -515,7 +515,7 @@ public interface IJobManager
   */
   public DocumentDescription[] finishDocuments(Long jobID, String[] legalLinkTypes,
     String[] parentIdentifierHashes, int hopcountMethod)
-    throws LCFException;
+    throws ACFException;
 
   /** Retrieve specific parent data for a given document.
   *@param jobID is the job identifier.
@@ -524,7 +524,7 @@ public interface IJobManager
   *@return the unique data values.
   */
   public String[] retrieveParentData(Long jobID, String docIDHash, String dataName)
-    throws LCFException;
+    throws ACFException;
 
   /** Retrieve specific parent data for a given document.
   *@param jobID is the job identifier.
@@ -533,7 +533,7 @@ public interface IJobManager
   *@return the unique data values.
   */
   public CharacterInput[] retrieveParentDataAsFiles(Long jobID, String docIDHash, String dataName)
-    throws LCFException;
+    throws ACFException;
 
   // These methods support the job threads (which start jobs and end jobs)
   // There is one thread that starts jobs.  It simply looks for jobs which are ready to
@@ -547,40 +547,40 @@ public interface IJobManager
   *@param jobID is the ID of the job to start.
   */
   public void manualStart(Long jobID)
-    throws LCFException;
+    throws ACFException;
 
   /** Manually abort a running job.  The job will be permanently stopped, and will not run again until
   * automatically started based on schedule, or manually started.
   *@param jobID is the job to abort.
   */
   public void manualAbort(Long jobID)
-    throws LCFException;
+    throws ACFException;
 
   /** Manually restart a running job.  The job will be stopped and restarted.  Any schedule affinity will be lost,
   * until the job finishes on its own.
   *@param jobID is the job to abort.
   */
   public void manualAbortRestart(Long jobID)
-    throws LCFException;
+    throws ACFException;
 
   /** Pause a job.
   *@param jobID is the job identifier to pause.
   */
   public void pauseJob(Long jobID)
-    throws LCFException;
+    throws ACFException;
 
   /** Restart a paused job.
   *@param jobID is the job identifier to restart.
   */
   public void restartJob(Long jobID)
-    throws LCFException;
+    throws ACFException;
 
   /** Reset job schedule.  This re-evaluates whether the job should be started now.  This method would typically
   * be called after a job's scheduling window has been changed.
   *@param jobID is the job identifier.
   */
   public void resetJobSchedule(Long jobID)
-    throws LCFException;
+    throws ACFException;
 
   // These methods are called by automatic processes
 
@@ -591,7 +591,7 @@ public interface IJobManager
   *@param unwaitList is filled in with the set of job id's that were resumed (Long's).
   */
   public void startJobs(long currentTime, ArrayList unwaitList)
-    throws LCFException;
+    throws ACFException;
 
 
   /** Put active or paused jobs in wait state, if they've exceeded their window.
@@ -599,7 +599,7 @@ public interface IJobManager
   *@param waitList is filled in with the set of job id's that were put into a wait state (Long's).
   */
   public void waitJobs(long currentTime, ArrayList waitList)
-    throws LCFException;
+    throws ACFException;
 
   /** Get the list of jobs that are ready for seeding.
   *@param currentTime is the current time in milliseconds since epoch.
@@ -607,54 +607,54 @@ public interface IJobManager
   * based on what the connector says should be added to the queue.
   */
   public JobStartRecord[] getJobsReadyForSeeding(long currentTime)
-    throws LCFException;
+    throws ACFException;
 
   /** Reset a seeding job back to "active" state.
   *@param jobID is the job id.
   */
   public void resetSeedJob(Long jobID)
-    throws LCFException;
+    throws ACFException;
 
   /** Get the list of jobs that are ready for startup.
   *@return jobs that were in the "readyforstartup" state.  These will be marked as being in the "starting up" state.
   */
   public JobStartRecord[] getJobsReadyForStartup()
-    throws LCFException;
+    throws ACFException;
 
 
   /** Reset a starting job back to "ready for startup" state.
   *@param jobID is the job id.
   */
   public void resetStartupJob(Long jobID)
-    throws LCFException;
+    throws ACFException;
 
   /** Prepare for a full scan.
   *@param jobID is the job id.
   *@param hopcountMethod describes how to handle deletions for hopcount purposes.
   */
   public void prepareFullScan(Long jobID, String[] legalLinkTypes, int hopcountMethod)
-    throws LCFException;
+    throws ACFException;
 
   /** Prepare for an incremental scan.
   *@param jobID is the job id.
   *@param hopcountMethod describes how to handle deletions for hopcount purposes.
   */
   public void prepareIncrementalScan(Long jobID, String[] legalLinkTypes, int hopcountMethod)
-    throws LCFException;
+    throws ACFException;
 
   /** Note job started.
   *@param jobID is the job id.
   *@param startTime is the job start time.
   */
   public void noteJobStarted(Long jobID, long startTime)
-    throws LCFException;
+    throws ACFException;
 
   /** Note job seeded.
   *@param jobID is the job id.
   *@param startTime is the job seed time.
   */
   public void noteJobSeeded(Long jobID, long startTime)
-    throws LCFException;
+    throws ACFException;
 
   /**  Note the deregistration of a connector used by the specified connections.
   * This method will be called when the connector is deregistered.  Jobs that use these connections
@@ -662,7 +662,7 @@ public interface IJobManager
   *@param connectionNames is the set of connection names.
   */
   public void noteConnectorDeregistration(String[] connectionNames)
-    throws LCFException;
+    throws ACFException;
 
   /** Note the registration of a connector used by the specified connections.
   * This method will be called when a connector is registered, on which the specified
@@ -670,14 +670,14 @@ public interface IJobManager
   *@param connectionNames is the set of connection names.
   */
   public void noteConnectorRegistration(String[] connectionNames)
-    throws LCFException;
+    throws ACFException;
 
   /** Note a change in connection configuration.
   * This method will be called whenever a connection's configuration is modified, or when an external repository change
   * is signalled.
   */
   public void noteConnectionChange(String connectionName)
-    throws LCFException;
+    throws ACFException;
     
   /**  Note the deregistration of an output connector used by the specified connections.
   * This method will be called when the connector is deregistered.  Jobs that use these connections
@@ -685,7 +685,7 @@ public interface IJobManager
   *@param connectionNames is the set of connection names.
   */
   public void noteOutputConnectorDeregistration(String[] connectionNames)
-    throws LCFException;
+    throws ACFException;
 
   /** Note the registration of an output connector used by the specified connections.
   * This method will be called when a connector is registered, on which the specified
@@ -693,20 +693,20 @@ public interface IJobManager
   *@param connectionNames is the set of connection names.
   */
   public void noteOutputConnectorRegistration(String[] connectionNames)
-    throws LCFException;
+    throws ACFException;
 
   /** Note a change in output connection configuration.
   * This method will be called whenever a connection's configuration is modified, or when an external output target change
   * is signalled.
   */
   public void noteOutputConnectionChange(String connectionName)
-    throws LCFException;
+    throws ACFException;
 
   /** Delete jobs in need of being deleted (which are marked "ready for delete").
   * This method is meant to be called periodically to perform delete processing on jobs.
   */
   public void deleteJobsReadyForDelete()
-    throws LCFException;
+    throws ACFException;
 
   /** Get list of deletable document descriptions.  This list will take into account
   * multiple jobs that may own the same document.
@@ -714,7 +714,7 @@ public interface IJobManager
   *@return the document descriptions for these documents.
   */
   public DocumentDescription[] getNextDeletableDocuments(int n)
-    throws LCFException;
+    throws ACFException;
 
   /** Delete ingested document identifiers (as part of deleting the owning job).
   * The number of identifiers specified is guaranteed to be less than the maxInClauseCount
@@ -722,7 +722,7 @@ public interface IJobManager
   *@param identifiers is the set of document identifiers.
   */
   public void deleteIngestedDocumentIdentifiers(DocumentDescription[] identifiers)
-    throws LCFException;
+    throws ACFException;
 
   /** Abort a running job due to a fatal error condition.
   *@param jobID is the job to abort.
@@ -730,27 +730,27 @@ public interface IJobManager
   *@return true if this is the first abort for the job.
   */
   public boolean errorAbort(Long jobID, String errorText)
-    throws LCFException;
+    throws ACFException;
 
   /** Complete the sequence that aborts jobs and makes them runnable again.
   *@param timestamp is the current time in milliseconds since epoch.
   *@param abortJobs is filled in with the set of IJobDescription objects that were aborted.
   */
   public void finishJobAborts(long timestamp, ArrayList abortJobs)
-    throws LCFException;
+    throws ACFException;
 
   /** Put all eligible jobs in the "shutting down" state.
   *@param finishList is filled in with the set of IJobDescription objects that were completed.
   */
   public void finishJobs(ArrayList finishList)
-    throws LCFException;
+    throws ACFException;
 
   /** Reset eligible jobs back to "inactive" state.  This method is used to pick up all jobs in the shutting down state
   * whose purgatory records have been all cleaned up.
   *@param currentTime is the current time in milliseconds since epoch.
   */
   public void resetJobs(long currentTime)
-    throws LCFException;
+    throws ACFException;
 
 
   // Status reports
@@ -759,25 +759,25 @@ public interface IJobManager
   *@return the status object for the specified job.
   */
   public JobStatus getStatus(Long jobID)
-    throws LCFException;
+    throws ACFException;
 
   /** Get a list of all jobs, and their status information.
   *@return an ordered array of job status objects.
   */
   public JobStatus[] getAllStatus()
-    throws LCFException;
+    throws ACFException;
 
   /** Get a list of running jobs.  This is for status reporting.
   *@return an array of the job status objects.
   */
   public JobStatus[] getRunningJobs()
-    throws LCFException;
+    throws ACFException;
 
   /** Get a list of completed jobs, and their statistics.
   *@return an array of the job status objects.
   */
   public JobStatus[] getFinishedJobs()
-    throws LCFException;
+    throws ACFException;
 
   // The following commands generate reports based on the queue.
 
@@ -792,7 +792,7 @@ public interface IJobManager
   */
   public IResultSet genDocumentStatus(String connectionName, StatusFilterCriteria filterCriteria, SortOrder sortOrder,
     int startRow, int rowCount)
-    throws LCFException;
+    throws ACFException;
 
   /** Run a 'queue status' report.
   *@param connectionName is the name of the connection.
@@ -806,5 +806,5 @@ public interface IJobManager
   */
   public IResultSet genQueueStatus(String connectionName, StatusFilterCriteria filterCriteria, SortOrder sortOrder,
     BucketDescription idBucketDescription, int startRow, int rowCount)
-    throws LCFException;
+    throws ACFException;
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IProcessActivity.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IProcessActivity.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IProcessActivity.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IProcessActivity.java Mon Aug 23 18:08:32 2010
@@ -44,7 +44,7 @@ public interface IProcessActivity extend
   */
   public void addDocumentReference(String localIdentifier, String parentIdentifier, String relationshipType,
     String[] dataNames, Object[][] dataValues, Long originationTime, String[] prereqEventNames)
-    throws LCFException;
+    throws ACFException;
 
   /** Add a document description to the current job's queue.
   *@param localIdentifier is the local document identifier to add (for the connector that
@@ -61,7 +61,7 @@ public interface IProcessActivity extend
   */
   public void addDocumentReference(String localIdentifier, String parentIdentifier, String relationshipType,
     String[] dataNames, Object[][] dataValues, Long originationTime)
-    throws LCFException;
+    throws ACFException;
 
 
   /** Add a document description to the current job's queue.
@@ -78,7 +78,7 @@ public interface IProcessActivity extend
   */
   public void addDocumentReference(String localIdentifier, String parentIdentifier, String relationshipType,
     String[] dataNames, Object[][] dataValues)
-    throws LCFException;
+    throws ACFException;
 
   /** Add a document description to the current job's queue.
   *@param localIdentifier is the local document identifier to add (for the connector that
@@ -90,7 +90,7 @@ public interface IProcessActivity extend
   * "getRelationshipTypes()".  May be null.
   */
   public void addDocumentReference(String localIdentifier, String parentIdentifier, String relationshipType)
-    throws LCFException;
+    throws ACFException;
 
   /** Add a document description to the current job's queue.  This method is equivalent to
   * addDocumentReference(localIdentifier,null,null).
@@ -98,7 +98,7 @@ public interface IProcessActivity extend
   * fetched the document).
   */
   public void addDocumentReference(String localIdentifier)
-    throws LCFException;
+    throws ACFException;
 
   /** Retrieve data passed from parents to a specified child document.
   *@param localIdentifier is the document identifier of the document we want the recorded data for.
@@ -106,7 +106,7 @@ public interface IProcessActivity extend
   *@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;
 
   /** Retrieve data passed from parents to a specified child document.
   *@param localIdentifier is the document identifier of the document we want the recorded data for.
@@ -114,14 +114,14 @@ public interface IProcessActivity extend
   *@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;
 
   /** Record a document version, but don't ingest it.
   *@param localIdentifier is the document identifier.
   *@param version is the document version.
   */
   public void recordDocument(String localIdentifier, String version)
-    throws LCFException, ServiceInterruption;
+    throws ACFException, ServiceInterruption;
 
   /** Ingest the current document.
   *@param localIdentifier is the document's local identifier.
@@ -132,13 +132,13 @@ public interface IProcessActivity extend
   *@param data is the document data.  The data is closed after ingestion is complete.
   */
   public void ingestDocument(String localIdentifier, String version, String documentURI, RepositoryDocument data)
-    throws LCFException, ServiceInterruption;
+    throws ACFException, ServiceInterruption;
 
   /** Delete the current document from the search engine index.
   *@param localIdentifier is the document's local identifier.
   */
   public void deleteDocument(String localIdentifier)
-    throws LCFException, ServiceInterruption;
+    throws ACFException, ServiceInterruption;
 
   /** Override the schedule for the next time a document is crawled.
   * Calling this method allows you to set an upper recrawl bound, lower recrawl bound, upper expire bound, lower expire bound,
@@ -153,7 +153,7 @@ public interface IProcessActivity extend
   public void setDocumentScheduleBounds(String localIdentifier,
     Long lowerRecrawlBoundTime, Long upperRecrawlBoundTime,
     Long lowerExpireBoundTime, Long upperExpireBoundTime)
-    throws LCFException;
+    throws ACFException;
 
   /** Override a document's origination time.
   * Use this method to signal the framework that a document's origination time is something other than the first time it was crawled.
@@ -162,6 +162,6 @@ public interface IProcessActivity extend
   */
   public void setDocumentOriginationTime(String localIdentifier,
     Long originationTime)
-    throws LCFException;
+    throws ACFException;
 
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IRepositoryConnectionManager.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IRepositoryConnectionManager.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IRepositoryConnectionManager.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IRepositoryConnectionManager.java Mon Aug 23 18:08:32 2010
@@ -29,33 +29,33 @@ public interface IRepositoryConnectionMa
   /** Install the manager.
   */
   public void install()
-    throws LCFException;
+    throws ACFException;
 
   /** Uninstall the manager.
   */
   public void deinstall()
-    throws LCFException;
+    throws ACFException;
 
   /** Export configuration */
   public void exportConfiguration(java.io.OutputStream os)
-    throws java.io.IOException, LCFException;
+    throws java.io.IOException, ACFException;
 
   /** Import configuration */
   public void importConfiguration(java.io.InputStream is)
-    throws java.io.IOException, LCFException;
+    throws java.io.IOException, ACFException;
 
   /** Obtain a list of the repository connections, ordered by name.
   *@return an array of connection objects.
   */
   public IRepositoryConnection[] getAllConnections()
-    throws LCFException;
+    throws ACFException;
 
   /** Load a repository connection by name.
   *@param name is the name of the repository connection.
   *@return the loaded connection object, or null if not found.
   */
   public IRepositoryConnection load(String name)
-    throws LCFException;
+    throws ACFException;
 
   /** Load a set of repository connections.
   *@param names are the names of the repository connections.
@@ -63,47 +63,47 @@ public interface IRepositoryConnectionMa
   * values for those not found.
   */
   public IRepositoryConnection[] loadMultiple(String[] names)
-    throws LCFException;
+    throws ACFException;
 
   /** Create a new repository connection object.
   *@return the new object.
   */
   public IRepositoryConnection create()
-    throws LCFException;
+    throws ACFException;
 
   /** Save a repository connection object.
   *@param object is the object to save.
   */
   public void save(IRepositoryConnection object)
-    throws LCFException;
+    throws ACFException;
 
   /** Delete a repository connection.
   *@param name is the name of the connection to delete.  If the
   * name does not exist, no error is returned.
   */
   public void delete(String name)
-    throws LCFException;
+    throws ACFException;
 
   /** Return true if the specified authority name is referenced.
   *@param authorityName is the authority name.
   *@return true if referenced, false otherwise.
   */
   public boolean isReferenced(String authorityName)
-    throws LCFException;
+    throws ACFException;
 
   /** Get a list of repository connections that share the same connector.
   *@param className is the class name of the connector.
   *@return the repository connections that use that connector.
   */
   public String[] findConnectionsForConnector(String className)
-    throws LCFException;
+    throws ACFException;
 
   /** Check if underlying connector exists.
   *@param name is the name of the connection to check.
   *@return true if the underlying connector is registered.
   */
   public boolean checkConnectorExists(String name)
-    throws LCFException;
+    throws ACFException;
 
   // Schema related
 
@@ -162,7 +162,7 @@ public interface IRepositoryConnectionMa
   */
   public void recordHistory(String connectionName, Long startTime, String activityType, Long dataSize,
     String entityIdentifier, String resultCode, String resultDescription, String[] childIdentifiers)
-    throws LCFException;
+    throws ACFException;
 
   /** Generate a report, listing the start time, elapsed time, result code and description, number of bytes, and entity identifier.
   * The records selected for this report are based on the filtering criteria object passed into this method.
@@ -175,7 +175,7 @@ public interface IRepositoryConnectionMa
   *@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;
 
   /** Count the number of rows specified by a given set of criteria.  This can be used to make decisions
   * as to whether a query based on those rows will complete in an acceptable amount of time.
@@ -184,7 +184,7 @@ public interface IRepositoryConnectionMa
   *@return the number of rows included by the criteria.
   */
   public long countHistoryRows(String connectionName, FilterCriteria criteria)
-    throws LCFException;
+    throws ACFException;
 
   /** Generate a report, listing the start time, activity count, and identifier bucket, given
   * a time slice (interval) size.
@@ -204,7 +204,7 @@ public interface IRepositoryConnectionMa
   */
   public IResultSet genHistoryActivityCount(String connectionName, FilterCriteria criteria, SortOrder sort, BucketDescription idBucket,
     long interval, int startRow, int maxRowCount)
-    throws LCFException;
+    throws ACFException;
 
   /** Generate a report, listing the start time, bytes processed, and identifier bucket, given
   * a time slice (interval) size.
@@ -224,7 +224,7 @@ public interface IRepositoryConnectionMa
   */
   public IResultSet genHistoryByteCount(String connectionName, FilterCriteria criteria, SortOrder sort, BucketDescription idBucket,
     long interval, int startRow, int maxRowCount)
-    throws LCFException;
+    throws ACFException;
 
 
   /** Generate a report, listing the result bucket and identifier bucket.
@@ -243,7 +243,7 @@ public interface IRepositoryConnectionMa
   */
   public IResultSet genHistoryResultCodes(String connectionName, FilterCriteria criteria, SortOrder sort,
     BucketDescription resultCodeBucket, BucketDescription idBucket, int startRow, int maxRowCount)
-    throws LCFException;
+    throws ACFException;
 
 
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IRepositoryConnector.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IRepositoryConnector.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IRepositoryConnector.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IRepositoryConnector.java Mon Aug 23 18:08:32 2010
@@ -24,7 +24,7 @@ import org.apache.acf.agents.interfaces.
 import java.io.*;
 import java.util.*;
 
-/** This interface describes an instance of a connection between a repository and LCF's
+/** This interface describes an instance of a connection between a repository and ACF's
 * standard "pull" ingestion agent.
 *
 * Each instance of this interface is used in only one thread at a time.  Connection Pooling
@@ -48,14 +48,14 @@ import java.util.*;
 * It therefore establishes a space of document identifiers.  Each connector will only ever be
 * asked to deal with identifiers that have in some way originated from the connector.
 *
-* Documents are fetched by LCF in three stages.  First, the addSeedDocuments() method is called in the connector
-* implementation.  This method is meant to add a set of document identifiers to the queue.  When LCF is ready
+* Documents are fetched by ACF in three stages.  First, the addSeedDocuments() method is called in the connector
+* implementation.  This method is meant to add a set of document identifiers to the queue.  When ACF is ready
 * to process a document, the document identifier is used to obtain a current document version string, using the
 * getDocumentVersions() method (the second stage).  This version string is used to decide whether or not the
 * third stage need be called for the document or not.  The third stage is responsible for sending document content
 * to the output, and for extracting any references to additional documents, and consists of the processDocuments() method.
 *
-* All of these methods interact with LCF by means of an "activity" interface.  For example, an IVersionActivity object
+* All of these methods interact with ACF by means of an "activity" interface.  For example, an IVersionActivity object
 * is passed to the getDocumentVersions() method, and that object contains methods that are necessary for getDocumentVersions()
 * to do its job.  A similar architecture is used throughout the connector framework.
 */
@@ -130,7 +130,7 @@ public interface IRepositoryConnector ex
   *@param input is the request object.
   */
   public void executeCommand(Configuration output, String command, Configuration input)
-    throws LCFException;
+    throws ACFException;
 
   /** Queue "seed" documents.  Seed documents are the starting places for crawling activity.  Documents
   * are seeded when this method calls appropriate methods in the passed in ISeedingActivity object.
@@ -160,7 +160,7 @@ public interface IRepositoryConnector ex
   */
   public void addSeedDocuments(ISeedingActivity activities, DocumentSpecification spec,
     long startTime, long endTime, int jobMode)
-    throws LCFException, ServiceInterruption;
+    throws ACFException, ServiceInterruption;
 
   /** Get document versions given an array of document identifiers.
   * This method is called for EVERY document that is considered. It is
@@ -181,7 +181,7 @@ public interface IRepositoryConnector ex
   */
   public String[] getDocumentVersions(String[] documentIdentifiers, String[] oldVersions, IVersionActivity activities,
     DocumentSpecification spec, int jobMode, boolean usesDefaultAuthority)
-    throws LCFException, ServiceInterruption;
+    throws ACFException, ServiceInterruption;
 
   /** Process a set of documents.
   * This is the method that should cause each document to be fetched, processed, and the results either added
@@ -199,7 +199,7 @@ public interface IRepositoryConnector ex
   */
   public void processDocuments(String[] documentIdentifiers, String[] versions, IProcessActivity activities,
     DocumentSpecification spec, boolean[] scanOnly, int jobMode)
-    throws LCFException, ServiceInterruption;
+    throws ACFException, ServiceInterruption;
 
   /** Free a set of documents.  This method is called for all documents whose versions have been fetched using
   * the getDocumentVersions() method, including those that returned null versions.  It may be used to free resources
@@ -209,7 +209,7 @@ public interface IRepositoryConnector ex
   *@param versions is the corresponding set of version identifiers (individual identifiers may be null).
   */
   public void releaseDocumentVersions(String[] documentIdentifiers, String[] versions)
-    throws LCFException;
+    throws ACFException;
 
   /** Get the maximum number of documents to amalgamate together into one batch, for this connector.
   * The connector does not need to be connected for this method to be called.
@@ -234,7 +234,7 @@ public interface IRepositoryConnector ex
   *@param tabsArray is an array of tab names.  Add to this array any tab names that are specific to the connector.
   */
   public void outputSpecificationHeader(IHTTPOutput out, DocumentSpecification ds, ArrayList tabsArray)
-    throws LCFException, IOException;
+    throws ACFException, IOException;
   
   /** Output the specification body section.
   * This method is called in the body section of a job page which has selected a repository connection of the current type.  Its purpose is to present the required form elements for editing.
@@ -245,7 +245,7 @@ public interface IRepositoryConnector ex
   *@param tabName is the current tab name.
   */
   public void outputSpecificationBody(IHTTPOutput out, DocumentSpecification ds, String tabName)
-    throws LCFException, IOException;
+    throws ACFException, IOException;
   
   /** Process a specification post.
   * This method is called at the start of job's edit or view page, whenever there is a possibility that form data for a connection has been
@@ -256,7 +256,7 @@ public interface IRepositoryConnector ex
   *@return null if all is well, or a string error message if there is an error that should prevent saving of the job (and cause a redirection to an error page).
   */
   public String processSpecificationPost(IPostParameters variableContext, DocumentSpecification ds)
-    throws LCFException;
+    throws ACFException;
   
   /** View specification.
   * This method is called in the body section of a job's view page.  Its purpose is to present the document specification information to the user.
@@ -265,7 +265,7 @@ public interface IRepositoryConnector ex
   *@param ds is the current document specification for this job.
   */
   public void viewSpecification(IHTTPOutput out, DocumentSpecification ds)
-    throws LCFException, IOException;
+    throws ACFException, IOException;
 
 }
 

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/ISeedingActivity.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/ISeedingActivity.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/ISeedingActivity.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/ISeedingActivity.java Mon Aug 23 18:08:32 2010
@@ -46,7 +46,7 @@ public interface ISeedingActivity extend
   *@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;
 
   /** Record a "seed" document identifier.
   * Seeds passed to this method will be loaded into the job's queue at the beginning of the
@@ -62,7 +62,7 @@ public interface ISeedingActivity extend
   *@param documentIdentifier is the identifier of the document to add to the "pending" queue.
   */
   public void addSeedDocument(String documentIdentifier)
-    throws LCFException;
+    throws ACFException;
 
   /** This method receives document identifiers that should be considered part of the seeds, but do not need to be
   * queued for processing at this time.  (This method is used to keep the hopcount tables up to date.)  It is
@@ -76,6 +76,6 @@ public interface ISeedingActivity extend
   * "pending" queue.
   */
   public void addUnqueuedSeedDocument(String documentIdentifier)
-    throws LCFException;
+    throws ACFException;
 
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IVersionActivity.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IVersionActivity.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IVersionActivity.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IVersionActivity.java Mon Aug 23 18:08:32 2010
@@ -35,7 +35,7 @@ public interface IVersionActivity extend
   *@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;
 
   /** Retrieve data passed from parents to a specified child document.
   *@param localIdentifier is the document identifier of the document we want the recorded data for.
@@ -43,6 +43,6 @@ public interface IVersionActivity extend
   *@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;
 
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/JobManagerFactory.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/JobManagerFactory.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/JobManagerFactory.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/JobManagerFactory.java Mon Aug 23 18:08:32 2010
@@ -39,15 +39,15 @@ public class JobManagerFactory
   *@return the handle.
   */
   public static IJobManager make(IThreadContext threadContext)
-    throws LCFException
+    throws ACFException
   {
     Object o = threadContext.get(jobManagerName);
     if (o == null || !(o instanceof IJobManager))
     {
       IDBInterface database = DBInterfaceFactory.make(threadContext,
-        LCF.getMasterDatabaseName(),
-        LCF.getMasterDatabaseUsername(),
-        LCF.getMasterDatabasePassword());
+        ACF.getMasterDatabaseName(),
+        ACF.getMasterDatabaseUsername(),
+        ACF.getMasterDatabasePassword());
 
       o = new org.apache.acf.crawler.jobs.JobManager(threadContext,database);
       threadContext.save(jobManagerName,o);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/RepositoryConnectionManagerFactory.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/RepositoryConnectionManagerFactory.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/RepositoryConnectionManagerFactory.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/RepositoryConnectionManagerFactory.java Mon Aug 23 18:08:32 2010
@@ -19,7 +19,7 @@
 package org.apache.acf.crawler.interfaces;
 
 import org.apache.acf.core.interfaces.*;
-import org.apache.acf.crawler.system.LCF;
+import org.apache.acf.crawler.system.ACF;
 
 /** Repository connection manager factory.
 */
@@ -39,15 +39,15 @@ public class RepositoryConnectionManager
   *@return the handle.
   */
   public static IRepositoryConnectionManager make(IThreadContext tc)
-    throws LCFException
+    throws ACFException
   {
     Object o = tc.get(objectName);
     if (o == null || !(o instanceof IRepositoryConnectionManager))
     {
       IDBInterface database = DBInterfaceFactory.make(tc,
-        LCF.getMasterDatabaseName(),
-        LCF.getMasterDatabaseUsername(),
-        LCF.getMasterDatabasePassword());
+        ACF.getMasterDatabaseName(),
+        ACF.getMasterDatabaseUsername(),
+        ACF.getMasterDatabasePassword());
 
       o = new org.apache.acf.crawler.repository.RepositoryConnectionManager(tc,database);
       tc.save(objectName,o);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/RepositoryConnectorFactory.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/RepositoryConnectorFactory.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/RepositoryConnectorFactory.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/RepositoryConnectorFactory.java Mon Aug 23 18:08:32 2010
@@ -21,7 +21,7 @@ package org.apache.acf.crawler.interface
 import org.apache.acf.core.interfaces.*;
 import org.apache.acf.agents.interfaces.*;
 import org.apache.acf.crawler.system.Logging;
-import org.apache.acf.crawler.system.LCF;
+import org.apache.acf.crawler.system.ACF;
 
 import java.util.*;
 import java.io.*;
@@ -47,7 +47,7 @@ public class RepositoryConnectorFactory
   *@param className is the class name.
   */
   public static void install(IThreadContext threadContext, String className)
-    throws LCFException
+    throws ACFException
   {
     IRepositoryConnector connector = getConnectorNoCheck(className);
     connector.install(threadContext);
@@ -57,7 +57,7 @@ public class RepositoryConnectorFactory
   *@param className is the class name.
   */
   public static void deinstall(IThreadContext threadContext, String className)
-    throws LCFException
+    throws ACFException
   {
     IRepositoryConnector connector = getConnectorNoCheck(className);
     connector.deinstall(threadContext);
@@ -68,7 +68,7 @@ public class RepositoryConnectorFactory
   *@return the list of activities.
   */
   public static String[] getActivitiesList(IThreadContext threadContext, String className)
-    throws LCFException
+    throws ACFException
   {
     IRepositoryConnector connector = getConnector(threadContext, className);
     if (connector == null)
@@ -83,7 +83,7 @@ public class RepositoryConnectorFactory
   *@return the list of link types, in sorted order.
   */
   public static String[] getRelationshipTypes(IThreadContext threadContext, String className)
-    throws LCFException
+    throws ACFException
   {
     IRepositoryConnector connector = getConnector(threadContext, className);
     if (connector == null)
@@ -98,7 +98,7 @@ public class RepositoryConnectorFactory
   *@return the connector operating model, as specified in IRepositoryConnector.
   */
   public static int getConnectorModel(IThreadContext threadContext, String className)
-    throws LCFException
+    throws ACFException
   {
     IRepositoryConnector connector = getConnector(threadContext, className);
     if (connector == null)
@@ -109,7 +109,7 @@ public class RepositoryConnectorFactory
   /** Output the configuration header section.
   */
   public static void outputConfigurationHeader(IThreadContext threadContext, String className, IHTTPOutput out, ConfigParams parameters, ArrayList tabsArray)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     IRepositoryConnector connector = getConnector(threadContext, className);
     if (connector == null)
@@ -120,7 +120,7 @@ public class RepositoryConnectorFactory
   /** Output the configuration body section.
   */
   public static void outputConfigurationBody(IThreadContext threadContext, String className, IHTTPOutput out, ConfigParams parameters, String tabName)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     IRepositoryConnector connector = getConnector(threadContext, className);
     if (connector == null)
@@ -131,7 +131,7 @@ public class RepositoryConnectorFactory
   /** Process configuration post data for a connector.
   */
   public static String processConfigurationPost(IThreadContext threadContext, String className, IPostParameters variableContext, ConfigParams configParams)
-    throws LCFException
+    throws ACFException
   {
     IRepositoryConnector connector = getConnector(threadContext, className);
     if (connector == null)
@@ -142,7 +142,7 @@ public class RepositoryConnectorFactory
   /** View connector configuration.
   */
   public static void viewConfiguration(IThreadContext threadContext, String className, IHTTPOutput out, ConfigParams configParams)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     IRepositoryConnector connector = getConnector(threadContext, className);
     // We want to be able to view connections even if they have unregistered connectors.
@@ -156,18 +156,18 @@ public class RepositoryConnectorFactory
   *@return the instance.
   */
   public static IRepositoryConnector getConnectorNoCheck(String className)
-    throws LCFException
+    throws ACFException
   {
     try
     {
-      Class theClass = LCF.findClass(className);
+      Class theClass = ACF.findClass(className);
       Class[] argumentClasses = new Class[0];
       // Look for a constructor
       Constructor c = theClass.getConstructor(argumentClasses);
       Object[] arguments = new Object[0];
       Object o = c.newInstance(arguments);
       if (!(o instanceof IRepositoryConnector))
-        throw new LCFException("Class '"+className+"' does not implement IRepositoryConnector.");
+        throw new ACFException("Class '"+className+"' does not implement IRepositoryConnector.");
       return (IRepositoryConnector)o;
     }
     catch (InvocationTargetException e)
@@ -176,41 +176,41 @@ public class RepositoryConnectorFactory
       if (z instanceof Error)
         throw (Error)z;
       else
-        throw (LCFException)z;
+        throw (ACFException)z;
     }
     catch (ClassNotFoundException e)
     {
-      throw new LCFException("No repository connector class '"+className+"' was found.",
+      throw new ACFException("No repository connector class '"+className+"' was found.",
         e);
     }
     catch (NoSuchMethodException e)
     {
-      throw new LCFException("No appropriate constructor for IRepositoryConnector implementation '"+
+      throw new ACFException("No appropriate constructor for IRepositoryConnector implementation '"+
         className+"'.  Need xxx(ConfigParams).",
         e);
     }
     catch (SecurityException e)
     {
-      throw new LCFException("Protected constructor for IRepositoryConnector implementation '"+className+"'",
+      throw new ACFException("Protected constructor for IRepositoryConnector implementation '"+className+"'",
         e);
     }
     catch (IllegalAccessException e)
     {
-      throw new LCFException("Unavailable constructor for IRepositoryConnector implementation '"+className+"'",
+      throw new ACFException("Unavailable constructor for IRepositoryConnector implementation '"+className+"'",
         e);
     }
     catch (IllegalArgumentException e)
     {
-      throw new LCFException("Shouldn't happen!!!",e);
+      throw new ACFException("Shouldn't happen!!!",e);
     }
     catch (InstantiationException e)
     {
-      throw new LCFException("InstantiationException for IRepositoryConnector implementation '"+className+"'",
+      throw new ACFException("InstantiationException for IRepositoryConnector implementation '"+className+"'",
         e);
     }
     catch (ExceptionInInitializerError e)
     {
-      throw new LCFException("ExceptionInInitializerError for IRepositoryConnector implementation '"+className+"'",
+      throw new ACFException("ExceptionInInitializerError for IRepositoryConnector implementation '"+className+"'",
         e);
     }
 
@@ -221,7 +221,7 @@ public class RepositoryConnectorFactory
   *@return the instance.
   */
   protected static IRepositoryConnector getConnector(IThreadContext threadContext, String className)
-    throws LCFException
+    throws ACFException
   {
     IConnectorManager connMgr = ConnectorManagerFactory.make(threadContext);
     if (connMgr.isInstalled(className) == false)
@@ -229,14 +229,14 @@ public class RepositoryConnectorFactory
 
     try
     {
-      Class theClass = LCF.findClass(className);
+      Class theClass = ACF.findClass(className);
       Class[] argumentClasses = new Class[0];
       // Look for a constructor
       Constructor c = theClass.getConstructor(argumentClasses);
       Object[] arguments = new Object[0];
       Object o = c.newInstance(arguments);
       if (!(o instanceof IRepositoryConnector))
-        throw new LCFException("Class '"+className+"' does not implement IRepositoryConnector.");
+        throw new ACFException("Class '"+className+"' does not implement IRepositoryConnector.");
       return (IRepositoryConnector)o;
     }
     catch (InvocationTargetException e)
@@ -245,7 +245,7 @@ public class RepositoryConnectorFactory
       if (z instanceof Error)
         throw (Error)z;
       else
-        throw (LCFException)z;
+        throw (ACFException)z;
     }
     catch (ClassNotFoundException e)
     {
@@ -254,37 +254,37 @@ public class RepositoryConnectorFactory
       if (connMgr.isInstalled(className) == false)
         return null;
 
-      throw new LCFException("No repository connector class '"+className+"' was found.",
+      throw new ACFException("No repository connector class '"+className+"' was found.",
         e);
     }
     catch (NoSuchMethodException e)
     {
-      throw new LCFException("No appropriate constructor for IRepositoryConnector implementation '"+
+      throw new ACFException("No appropriate constructor for IRepositoryConnector implementation '"+
         className+"'.  Need xxx(ConfigParams).",
         e);
     }
     catch (SecurityException e)
     {
-      throw new LCFException("Protected constructor for IRepositoryConnector implementation '"+className+"'",
+      throw new ACFException("Protected constructor for IRepositoryConnector implementation '"+className+"'",
         e);
     }
     catch (IllegalAccessException e)
     {
-      throw new LCFException("Unavailable constructor for IRepositoryConnector implementation '"+className+"'",
+      throw new ACFException("Unavailable constructor for IRepositoryConnector implementation '"+className+"'",
         e);
     }
     catch (IllegalArgumentException e)
     {
-      throw new LCFException("Shouldn't happen!!!",e);
+      throw new ACFException("Shouldn't happen!!!",e);
     }
     catch (InstantiationException e)
     {
-      throw new LCFException("InstantiationException for IRepositoryConnector implementation '"+className+"'",
+      throw new ACFException("InstantiationException for IRepositoryConnector implementation '"+className+"'",
         e);
     }
     catch (ExceptionInInitializerError e)
     {
-      throw new LCFException("ExceptionInInitializerError for IRepositoryConnector implementation '"+className+"'",
+      throw new ACFException("ExceptionInInitializerError for IRepositoryConnector implementation '"+className+"'",
         e);
     }
 
@@ -295,7 +295,7 @@ public class RepositoryConnectorFactory
   */
   public static IRepositoryConnector[] grabMultiple(IThreadContext threadContext,
     String[] orderingKeys, String[] classNames, ConfigParams[] configInfos, int[] maxPoolSizes)
-    throws LCFException
+    throws ACFException
   {
     IRepositoryConnector[] rval = new IRepositoryConnector[classNames.length];
     HashMap orderMap = new HashMap();
@@ -303,7 +303,7 @@ public class RepositoryConnectorFactory
     while (i < orderingKeys.length)
     {
       if (orderMap.get(orderingKeys[i]) != null)
-        throw new LCFException("Found duplicate order key");
+        throw new ACFException("Found duplicate order key");
       orderMap.put(orderingKeys[i],new Integer(i));
       i++;
     }
@@ -332,13 +332,13 @@ public class RepositoryConnectorFactory
           {
             release(rval[index]);
           }
-          catch (LCFException e2)
+          catch (ACFException e2)
           {
           }
         }
-        if (e instanceof LCFException)
+        if (e instanceof ACFException)
         {
-          throw (LCFException)e;
+          throw (ACFException)e;
         }
         throw (Error)e;
       }
@@ -356,7 +356,7 @@ public class RepositoryConnectorFactory
   */
   public static IRepositoryConnector grab(IThreadContext threadContext,
     String className, ConfigParams configInfo, int maxPoolSize)
-    throws LCFException
+    throws ACFException
   {
     // We want to get handles off the pool and use them.  But the
     // handles we fetch have to have the right config information.
@@ -392,10 +392,10 @@ public class RepositoryConnectorFactory
   /** Release multiple repository connectors.
   */
   public static void releaseMultiple(IRepositoryConnector[] connectors)
-    throws LCFException
+    throws ACFException
   {
     int i = 0;
-    LCFException currentException = null;
+    ACFException currentException = null;
     while (i < connectors.length)
     {
       IRepositoryConnector c = connectors[i++];
@@ -403,7 +403,7 @@ public class RepositoryConnectorFactory
       {
         release(c);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
         if (currentException == null)
           currentException = e;
@@ -417,7 +417,7 @@ public class RepositoryConnectorFactory
   *@param connector is the connector to release.
   */
   public static void release(IRepositoryConnector connector)
-    throws LCFException
+    throws ACFException
   {
     // If the connector is null, skip the release, because we never really got the connector in the first place.
     if (connector == null)
@@ -444,7 +444,7 @@ public class RepositoryConnectorFactory
   * This method polls all inactive handles.
   */
   public static void pollAllConnectors(IThreadContext threadContext)
-    throws LCFException
+    throws ACFException
   {
     // System.out.println("Pool stats:");
 
@@ -470,7 +470,7 @@ public class RepositoryConnectorFactory
   *@param threadContext is the local thread context.
   */
   public static void closeAllConnectors(IThreadContext threadContext)
-    throws LCFException
+    throws ACFException
   {
     // Go through the whole pool and clean it out
     synchronized (poolHash)
@@ -578,7 +578,7 @@ public class RepositoryConnectorFactory
     *@return the connector, or null if no connector could be connected.
     */
     public synchronized IRepositoryConnector getConnector(IThreadContext threadContext)
-      throws LCFException
+      throws ACFException
     {
       while (numFree == 0)
       {
@@ -588,7 +588,7 @@ public class RepositoryConnectorFactory
         }
         catch (InterruptedException e)
         {
-          throw new LCFException("Interrupted: "+e.getMessage(),e,LCFException.INTERRUPTED);
+          throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
         }
       }
 
@@ -604,14 +604,14 @@ public class RepositoryConnectorFactory
 
         try
         {
-          Class theClass = LCF.findClass(className);
+          Class theClass = ACF.findClass(className);
           Class[] argumentClasses = new Class[0];
           // Look for a constructor
           Constructor c = theClass.getConstructor(argumentClasses);
           Object[] arguments = new Object[0];
           Object o = c.newInstance(arguments);
           if (!(o instanceof IRepositoryConnector))
-            throw new LCFException("Class '"+className+"' does not implement IRepositoryConnector.");
+            throw new ACFException("Class '"+className+"' does not implement IRepositoryConnector.");
           rc = (IRepositoryConnector)o;
           rc.connect(configParams);
         }
@@ -621,7 +621,7 @@ public class RepositoryConnectorFactory
           if (z instanceof Error)
             throw (Error)z;
           else
-            throw (LCFException)z;
+            throw (ACFException)z;
         }
         catch (ClassNotFoundException e)
         {
@@ -631,37 +631,37 @@ public class RepositoryConnectorFactory
           if (connMgr.isInstalled(className) == false)
             return null;
 
-          throw new LCFException("No repository connector class '"+className+"' was found.",
+          throw new ACFException("No repository connector class '"+className+"' was found.",
             e);
         }
         catch (NoSuchMethodException e)
         {
-          throw new LCFException("No appropriate constructor for IRepositoryConnector implementation '"+
+          throw new ACFException("No appropriate constructor for IRepositoryConnector implementation '"+
             className+"'.  Need xxx(ConfigParams).",
             e);
         }
         catch (SecurityException e)
         {
-          throw new LCFException("Protected constructor for IRepositoryConnector implementation '"+className+"'",
+          throw new ACFException("Protected constructor for IRepositoryConnector implementation '"+className+"'",
             e);
         }
         catch (IllegalAccessException e)
         {
-          throw new LCFException("Unavailable constructor for IRepositoryConnector implementation '"+className+"'",
+          throw new ACFException("Unavailable constructor for IRepositoryConnector implementation '"+className+"'",
             e);
         }
         catch (IllegalArgumentException e)
         {
-          throw new LCFException("Shouldn't happen!!!",e);
+          throw new ACFException("Shouldn't happen!!!",e);
         }
         catch (InstantiationException e)
         {
-          throw new LCFException("InstantiationException for IRepositoryConnector implementation '"+className+"'",
+          throw new ACFException("InstantiationException for IRepositoryConnector implementation '"+className+"'",
             e);
         }
         catch (ExceptionInInitializerError e)
         {
-          throw new LCFException("ExceptionInInitializerError for IRepositoryConnector implementation '"+className+"'",
+          throw new ACFException("ExceptionInInitializerError for IRepositoryConnector implementation '"+className+"'",
             e);
         }
       }
@@ -678,7 +678,7 @@ public class RepositoryConnectorFactory
     *@param connector is the connector.
     */
     public synchronized void releaseConnector(IRepositoryConnector connector)
-      throws LCFException
+      throws ACFException
     {
       if (connector == null)
         return;
@@ -694,7 +694,7 @@ public class RepositoryConnectorFactory
     /** Notify all free connectors.
     */
     public synchronized void pollAll(IThreadContext threadContext)
-      throws LCFException
+      throws ACFException
     {
       int i = 0;
       while (i < stack.size())
@@ -710,7 +710,7 @@ public class RepositoryConnectorFactory
     /** Release all free connectors.
     */
     public synchronized void releaseAll(IThreadContext threadContext)
-      throws LCFException
+      throws ACFException
     {
       while (stack.size() > 0)
       {

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/SortOrder.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/SortOrder.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/SortOrder.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/SortOrder.java Mon Aug 23 18:08:32 2010
@@ -44,7 +44,7 @@ public class SortOrder
   /** Constructor from string representation.
   */
   public SortOrder(String rep)
-    throws LCFException
+    throws ACFException
   {
     ParseBuffer pb = new ParseBuffer(rep);
     StringBuffer numBuffer = new StringBuffer();
@@ -52,7 +52,7 @@ public class SortOrder
     {
       int x = pb.peekCharAt();
       if (x == -1)
-        throw new LCFException("Unexpected end");
+        throw new ACFException("Unexpected end");
       char y = (char)x;
       pb.next();
       if (y == ':')
@@ -72,7 +72,7 @@ public class SortOrder
     }
     catch (NumberFormatException e)
     {
-      throw new LCFException("Bad number",e);
+      throw new ACFException("Bad number",e);
     }
   }
 
@@ -190,25 +190,25 @@ public class SortOrder
     }
 
     public SortSpec(ParseBuffer pb)
-      throws LCFException
+      throws ACFException
     {
       int x = pb.peekCharAt();
       if (x == -1)
-        throw new LCFException("Unexpected end");
+        throw new ACFException("Unexpected end");
       char y = (char)x;
       if (y == '+')
         this.direction = SORT_ASCENDING;
       else if (y == '-')
         this.direction = SORT_DESCENDING;
       else
-        throw new LCFException("Bad direction");
+        throw new ACFException("Bad direction");
       pb.next();
       StringBuffer sb = new StringBuffer();
       while (true)
       {
         x = pb.peekCharAt();
         if (x == -1)
-          throw new LCFException("Unexpected end");
+          throw new ACFException("Unexpected end");
         y = (char)x;
         pb.next();
         if (y == '.')

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/Carrydown.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/Carrydown.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/Carrydown.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/Carrydown.java Mon Aug 23 18:08:32 2010
@@ -23,7 +23,7 @@ import java.util.*;
 import org.apache.acf.core.interfaces.*;
 import org.apache.acf.crawler.interfaces.*;
 import org.apache.acf.crawler.system.Logging;
-import org.apache.acf.crawler.system.LCF;
+import org.apache.acf.crawler.system.ACF;
 
 /** This class manages the table that keeps track of intrinsic relationships between documents.
 */
@@ -65,7 +65,7 @@ public class Carrydown extends org.apach
   *@param database is the database handle.
   */
   public Carrydown(IDBInterface database)
-    throws LCFException
+    throws ACFException
   {
     super(database,"carrydown");
   }
@@ -73,7 +73,7 @@ public class Carrydown extends org.apach
   /** Install or upgrade.
   */
   public void install(String jobsTable, String jobsColumn)
-    throws LCFException
+    throws ACFException
   {
     // Standard practice: Outer loop, to support upgrade requirements.
     while (true)
@@ -153,7 +153,7 @@ public class Carrydown extends org.apach
   /** Uninstall.
   */
   public void deinstall()
-    throws LCFException
+    throws ACFException
   {
     performDrop(null);
   }
@@ -161,7 +161,7 @@ public class Carrydown extends org.apach
   /** Analyze job tables that need analysis.
   */
   public void analyzeTables()
-    throws LCFException
+    throws ACFException
   {
     long startTime = System.currentTimeMillis();
     Logging.perf.debug("Beginning to analyze carrydown table");
@@ -172,7 +172,7 @@ public class Carrydown extends org.apach
   /** Delete an owning job (and clean up the corresponding carrydown rows).
   */
   public void deleteOwner(Long jobID)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(jobID);
@@ -192,7 +192,7 @@ public class Carrydown extends org.apach
   /** Reset, at startup time.
   */
   public void reset()
-    throws LCFException
+    throws ACFException
   {
     // Delete "new" rows
     HashMap map = new HashMap();
@@ -213,7 +213,7 @@ public class Carrydown extends org.apach
   */
   public boolean recordCarrydownData(Long jobID, String parentDocumentIDHash, String childDocumentIDHash,
     String[] documentDataNames, String[][] documentDataValueHashes, Object[][] documentDataValues)
-    throws LCFException
+    throws ACFException
   {
     return recordCarrydownDataMultiple(jobID,parentDocumentIDHash,new String[]{childDocumentIDHash},
       new String[][]{documentDataNames},new String[][][]{documentDataValueHashes},new Object[][][]{documentDataValues})[0];
@@ -223,7 +223,7 @@ public class Carrydown extends org.apach
   */
   public boolean[] recordCarrydownDataMultiple(Long jobID, String parentDocumentIDHash, String[] childDocumentIDHashes,
     String[][] dataNames, String[][][] dataValueHashes, Object[][][] dataValues)
-    throws LCFException
+    throws ACFException
   {
 
     // Need to go into a transaction because we need to distinguish between update and insert.
@@ -384,7 +384,7 @@ public class Carrydown extends org.apach
 
   /** Do the exists check, in batch. */
   protected void performExistsCheck(Map presentMap, String query, ArrayList list)
-    throws LCFException
+    throws ACFException
   {
     // Note well: presentMap is only checked for the *existence* of a record, so we do not need to populate the datavalue field!
     // This is crucial, because otherwise we'd either be using an undetermined amount of memory, or we'd need to read into a temporary file.
@@ -406,7 +406,7 @@ public class Carrydown extends org.apach
   * and delete the old (eliminated) child records.
   */
   public void restoreRecords(Long jobID, String[] parentDocumentIDHashes)
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -438,7 +438,7 @@ public class Carrydown extends org.apach
       if (k > 0)
         performRestoreRecords(sb.toString(),list);
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -455,7 +455,7 @@ public class Carrydown extends org.apach
   }
 
   protected void performRestoreRecords(String query, ArrayList list)
-    throws LCFException
+    throws ACFException
   {
     // Delete
     StringBuffer sb = new StringBuffer("WHERE (");
@@ -477,7 +477,7 @@ public class Carrydown extends org.apach
   /** Delete all records that mention a particular set of document identifiers.
   */
   public void deleteRecords(Long jobID, String[] documentIDHashes)
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
@@ -524,7 +524,7 @@ public class Carrydown extends org.apach
 
 
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -542,7 +542,7 @@ public class Carrydown extends org.apach
   }
 
   protected void performDeleteRecords(String query, String query2, ArrayList list, ArrayList list2)
-    throws LCFException
+    throws ACFException
   {
     performDelete("WHERE "+query,list,null);
     performDelete("WHERE "+query2,list2,null);
@@ -550,7 +550,7 @@ public class Carrydown extends org.apach
 
   /** Get unique values given a document identifier, data name, an job identifier */
   public String[] getDataValues(Long jobID, String documentIdentifierHash, String dataName)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(jobID);
@@ -575,7 +575,7 @@ public class Carrydown extends org.apach
 
   /** Get unique values given a document identifier, data name, an job identifier */
   public CharacterInput[] getDataValuesAsFiles(Long jobID, String documentIdentifierHash, String dataName)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(jobID);
@@ -624,7 +624,7 @@ public class Carrydown extends org.apach
   /** Conditionally do analyze operation.
   */
   public void conditionallyAnalyzeTables()
-    throws LCFException
+    throws ACFException
   {
     if (tracker.checkAnalyze())
     {
@@ -678,7 +678,7 @@ public class Carrydown extends org.apach
     *@return true if it should be included, false otherwise.
     */
     public boolean checkInclude(IResultRow row)
-      throws LCFException
+      throws ACFException
     {
       // Check to be sure that this row is different from the last; only then agree to include it.
       String value = (String)row.getValue(dataValueHashField);
@@ -696,7 +696,7 @@ public class Carrydown extends org.apach
     *@return true if we need to keep going, or false if we are done.
     */
     public boolean checkContinue()
-      throws LCFException
+      throws ACFException
     {
       return true;
     }
@@ -868,7 +868,7 @@ public class Carrydown extends org.apach
     *@return true if it should be included, false otherwise.
     */
     public boolean checkInclude(IResultRow row)
-      throws LCFException
+      throws ACFException
     {
       Long jobID = (Long)row.getValue(jobIDField);
       String parentIDHash = (String)row.getValue(parentIDHashField);
@@ -897,7 +897,7 @@ public class Carrydown extends org.apach
     *@return true if we need to keep going, or false if we are done.
     */
     public boolean checkContinue()
-      throws LCFException
+      throws ACFException
     {
       return true;
     }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/EventManager.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/EventManager.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/EventManager.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/jobs/EventManager.java Mon Aug 23 18:08:32 2010
@@ -39,7 +39,7 @@ public class EventManager extends org.ap
   *@param database is the database handle.
   */
   public EventManager(IDBInterface database)
-    throws LCFException
+    throws ACFException
   {
     super(database,"events");
   }
@@ -47,7 +47,7 @@ public class EventManager extends org.ap
   /** Install or upgrade this table.
   */
   public void install()
-    throws LCFException
+    throws ACFException
   {
     // Standard practice: outer loop for installs
     while (true)
@@ -73,14 +73,14 @@ public class EventManager extends org.ap
   /** Uninstall.
   */
   public void deinstall()
-    throws LCFException
+    throws ACFException
   {
     beginTransaction();
     try
     {
       performDrop(null);
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -99,7 +99,7 @@ public class EventManager extends org.ap
   /** Prepare for restart.
   */
   public void restart()
-    throws LCFException
+    throws ACFException
   {
     // Delete all rows in this table.
     performDelete("",null,null);
@@ -107,7 +107,7 @@ public class EventManager extends org.ap
 
   /** Atomically create an event - and return false if the event already exists */
   public void createEvent(String eventName)
-    throws LCFException
+    throws ACFException
   {
     HashMap map = new HashMap();
     map.put(eventNameField,eventName);
@@ -116,7 +116,7 @@ public class EventManager extends org.ap
 
   /** Destroy an event */
   public void destroyEvent(String eventName)
-    throws LCFException
+    throws ACFException
   {
     ArrayList list = new ArrayList();
     list.add(eventName);