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 [16/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...

Added: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/authorities/system/ACF.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/authorities/system/ACF.java?rev=988237&view=auto
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/authorities/system/ACF.java (added)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/authorities/system/ACF.java Mon Aug 23 18:08:32 2010
@@ -0,0 +1,238 @@
+/* $Id: ACF.java 953331 2010-06-10 14:22:50Z kwright $ */
+
+/**
+* Licensed to the Apache Software Foundation (ASF) under one or more
+* contributor license agreements. See the NOTICE file distributed with
+* this work for additional information regarding copyright ownership.
+* The ASF licenses this file to You under the Apache License, Version 2.0
+* (the "License"); you may not use this file except in compliance with
+* the License. You may obtain a copy of the License at
+*
+* http://www.apache.org/licenses/LICENSE-2.0
+*
+* Unless required by applicable law or agreed to in writing, software
+* distributed under the License is distributed on an "AS IS" BASIS,
+* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+* See the License for the specific language governing permissions and
+* limitations under the License.
+*/
+package org.apache.acf.authorities.system;
+
+import org.apache.acf.core.interfaces.*;
+import org.apache.acf.authorities.interfaces.*;
+import java.io.*;
+import java.util.*;
+
+public class ACF extends org.apache.acf.core.system.ACF
+{
+  // Initialization needed flag
+  protected static boolean authoritiesInitialized = false;
+  
+  // Threads
+  protected static IdleCleanupThread idleCleanupThread = null;
+  protected static AuthCheckThread[] authCheckThreads = null;
+
+  // Number of auth check threads
+  protected static int numAuthCheckThreads = 0;
+
+  protected static final String authCheckThreadCountProperty = "org.apache.acf.authorityservice.threads";
+
+  // Request queue
+  protected static RequestQueue requestQueue = null;
+
+  /** Initialize environment.
+  */
+  public static void initializeEnvironment()
+    throws ACFException
+  {
+    synchronized (initializeFlagLock)
+    {
+      if (authoritiesInitialized)
+        return;
+
+      org.apache.acf.core.system.ACF.initializeEnvironment();
+      Logging.initializeLoggers();
+      Logging.setLogLevels();
+      authoritiesInitialized = true;
+    }
+  }
+
+
+  /** Install all the authority manager system tables.
+  *@param threadcontext is the thread context.
+  */
+  public static void installSystemTables(IThreadContext threadcontext)
+    throws ACFException
+  {
+    IDBInterface mainDatabase = DBInterfaceFactory.make(threadcontext,
+      ACF.getMasterDatabaseName(),
+      ACF.getMasterDatabaseUsername(),
+      ACF.getMasterDatabasePassword());
+
+    IAuthorityConnectorManager connMgr = AuthorityConnectorManagerFactory.make(threadcontext);
+    IAuthorityConnectionManager authConnMgr = AuthorityConnectionManagerFactory.make(threadcontext);
+
+    mainDatabase.beginTransaction();
+    try
+    {
+      connMgr.install();
+      authConnMgr.install();
+    }
+    catch (ACFException e)
+    {
+      mainDatabase.signalRollback();
+      throw e;
+    }
+    catch (Error e)
+    {
+      mainDatabase.signalRollback();
+      throw e;
+    }
+    finally
+    {
+      mainDatabase.endTransaction();
+    }
+
+  }
+
+  /** Uninstall all the authority manager system tables.
+  *@param threadcontext is the thread context.
+  */
+  public static void deinstallSystemTables(IThreadContext threadcontext)
+    throws ACFException
+  {
+    IDBInterface mainDatabase = DBInterfaceFactory.make(threadcontext,
+      ACF.getMasterDatabaseName(),
+      ACF.getMasterDatabaseUsername(),
+      ACF.getMasterDatabasePassword());
+
+    ACFException se = null;
+
+    IAuthorityConnectorManager connMgr = AuthorityConnectorManagerFactory.make(threadcontext);
+    IAuthorityConnectionManager authConnMgr = AuthorityConnectionManagerFactory.make(threadcontext);
+
+    mainDatabase.beginTransaction();
+    try
+    {
+      authConnMgr.deinstall();
+      connMgr.deinstall();
+    }
+    catch (ACFException e)
+    {
+      mainDatabase.signalRollback();
+      throw e;
+    }
+    catch (Error e)
+    {
+      mainDatabase.signalRollback();
+      throw e;
+    }
+    finally
+    {
+      mainDatabase.endTransaction();
+    }
+    if (se != null)
+      throw se;
+
+  }
+
+  /** Start the authority system.
+  */
+  public static void startSystem(IThreadContext threadContext)
+    throws ACFException
+  {
+    // Read any parameters
+    String maxThreads = getProperty(authCheckThreadCountProperty);
+    if (maxThreads == null)
+      maxThreads = "10";
+    numAuthCheckThreads = new Integer(maxThreads).intValue();
+    if (numAuthCheckThreads < 1 || numAuthCheckThreads > 100)
+      throw new ACFException("Illegal value for the number of auth check threads");
+
+    // Start up threads
+    idleCleanupThread = new IdleCleanupThread();
+    idleCleanupThread.start();
+
+    requestQueue = new RequestQueue();
+
+    authCheckThreads = new AuthCheckThread[numAuthCheckThreads];
+    int i = 0;
+    while (i < numAuthCheckThreads)
+    {
+      authCheckThreads[i] = new AuthCheckThread(Integer.toString(i),requestQueue);
+      authCheckThreads[i].start();
+      i++;
+    }
+  }
+
+  /** Shut down the authority system.
+  */
+  public static void stopSystem(IThreadContext threadContext)
+    throws ACFException
+  {
+
+    while (idleCleanupThread != null || authCheckThreads != null)
+    {
+      if (idleCleanupThread != null)
+      {
+        idleCleanupThread.interrupt();
+      }
+      if (authCheckThreads != null)
+      {
+        int i = 0;
+        while (i < authCheckThreads.length)
+        {
+          Thread authCheckThread = authCheckThreads[i++];
+          if (authCheckThread != null)
+            authCheckThread.interrupt();
+        }
+      }
+
+      if (idleCleanupThread != null)
+      {
+        if (!idleCleanupThread.isAlive())
+          idleCleanupThread = null;
+      }
+      if (authCheckThreads != null)
+      {
+        int i = 0;
+        boolean isAlive = false;
+        while (i < authCheckThreads.length)
+        {
+          Thread authCheckThread = authCheckThreads[i];
+          if (authCheckThread != null)
+          {
+            if (!authCheckThread.isAlive())
+              authCheckThreads[i] = null;
+            else
+              isAlive = true;
+          }
+          i++;
+        }
+        if (!isAlive)
+          authCheckThreads = null;
+      }
+
+      try
+      {
+        ACF.sleep(1000);
+      }
+      catch (InterruptedException e)
+      {
+      }
+    }
+
+    // Release all authority connectors
+    AuthorityConnectorFactory.closeAllConnectors(threadContext);
+    numAuthCheckThreads = 0;
+    requestQueue = null;
+  }
+
+  /** Get the current request queue */
+  public static RequestQueue getRequestQueue()
+  {
+    return requestQueue;
+  }
+
+}
+

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/authorities/system/AuthCheckThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/authorities/system/AuthCheckThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/authorities/system/AuthCheckThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/authorities/system/AuthCheckThread.java Mon Aug 23 18:08:32 2010
@@ -38,7 +38,7 @@ public class AuthCheckThread extends Thr
   /** Constructor.
   */
   public AuthCheckThread(String id, RequestQueue requestQueue)
-    throws LCFException
+    throws ACFException
   {
     super();
     this.requestQueue = requestQueue;
@@ -58,7 +58,7 @@ public class AuthCheckThread extends Thr
       try
       {
         if (Thread.currentThread().isInterrupted())
-          throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+          throw new ACFException("Interrupted",ACFException.INTERRUPTED);
 
         // Wait for a request.
         AuthRequest theRequest = requestQueue.getRequest();
@@ -83,7 +83,7 @@ public class AuthCheckThread extends Thr
           try
           {
             if (connector == null)
-              exception = new LCFException("Authority connector "+theRequest.getClassName()+" is not registered.");
+              exception = new ACFException("Authority connector "+theRequest.getClassName()+" is not registered.");
             else
             {
               // Get the acl for the user
@@ -91,9 +91,9 @@ public class AuthCheckThread extends Thr
               {
                 response = connector.getAuthorizationResponse(theRequest.getUserID());
               }
-              catch (LCFException e)
+              catch (ACFException e)
               {
-                if (e.getErrorCode() == LCFException.INTERRUPTED)
+                if (e.getErrorCode() == ACFException.INTERRUPTED)
                   throw e;
                 Logging.authorityService.warn("Authority error: "+e.getMessage(),e);
                 response = AuthorityConnectorFactory.getDefaultAuthorizationResponse(threadContext,theRequest.getClassName(),theRequest.getUserID());
@@ -106,9 +106,9 @@ public class AuthCheckThread extends Thr
             AuthorityConnectorFactory.release(connector);
           }
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
-          if (e.getErrorCode() == LCFException.INTERRUPTED)
+          if (e.getErrorCode() == ACFException.INTERRUPTED)
             throw e;
           Logging.authorityService.warn("Authority connection exception: "+e.getMessage(),e);
           response = AuthorityConnectorFactory.getDefaultAuthorizationResponse(threadContext,theRequest.getClassName(),theRequest.getUserID());
@@ -128,15 +128,15 @@ public class AuthCheckThread extends Thr
 
         // Repeat, and only go to sleep if there are no more requests.
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
-        if (e.getErrorCode() == LCFException.INTERRUPTED)
+        if (e.getErrorCode() == ACFException.INTERRUPTED)
           break;
 
         // Log it, but keep the thread alive
         Logging.authorityService.error("Exception tossed: "+e.getMessage(),e);
 
-        if (e.getErrorCode() == LCFException.SETUP_ERROR)
+        if (e.getErrorCode() == ACFException.SETUP_ERROR)
         {
           // Shut the whole system down!
           System.exit(1);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/authorities/system/IdleCleanupThread.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/authorities/system/IdleCleanupThread.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/authorities/system/IdleCleanupThread.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/authorities/system/IdleCleanupThread.java Mon Aug 23 18:08:32 2010
@@ -38,7 +38,7 @@ public class IdleCleanupThread extends T
   /** Constructor.
   */
   public IdleCleanupThread()
-    throws LCFException
+    throws ACFException
   {
     super();
     setName("Idle cleanup thread");
@@ -60,17 +60,17 @@ public class IdleCleanupThread extends T
         AuthorityConnectorFactory.pollAllConnectors(threadContext);
 
         // Sleep for the retry interval.
-        LCF.sleep(15000L);
+        ACF.sleep(15000L);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
-        if (e.getErrorCode() == LCFException.INTERRUPTED)
+        if (e.getErrorCode() == ACFException.INTERRUPTED)
           break;
 
         // Log it, but keep the thread alive
         Logging.authorityService.error("Exception tossed",e);
 
-        if (e.getErrorCode() == LCFException.SETUP_ERROR)
+        if (e.getErrorCode() == ACFException.SETUP_ERROR)
         {
           // Shut the whole system down!
           System.exit(1);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/AbortJob.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/AbortJob.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/AbortJob.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/AbortJob.java Mon Aug 23 18:08:32 2010
@@ -49,7 +49,7 @@ public class AbortJob
 
                 try
                 {
-                        LCF.initializeEnvironment();
+                        ACF.initializeEnvironment();
                         IThreadContext tc = ThreadContextFactory.make();
                         IJobManager jobManager = JobManagerFactory.make(tc);
                         jobManager.manualAbort(new Long(jobID));

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/AddScheduledTime.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/AddScheduledTime.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/AddScheduledTime.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/AddScheduledTime.java Mon Aug 23 18:08:32 2010
@@ -63,13 +63,13 @@ public class AddScheduledTime
 
                 try
                 {
-                        LCF.initializeEnvironment();
+                        ACF.initializeEnvironment();
                         IThreadContext tc = ThreadContextFactory.make();
                         IJobManager jobManager = JobManagerFactory.make(tc);
 
                         IJobDescription desc = jobManager.load(new Long(jobID));
                         if (desc == null)
-                                throw new LCFException("No such job: '"+jobID+"'");
+                                throw new ACFException("No such job: '"+jobID+"'");
 
                         ScheduleRecord sr = new ScheduleRecord(
                                 parseDayOfWeek(dayOfWeekList),
@@ -134,7 +134,7 @@ public class AddScheduledTime
                         return 5;
                 if (day.equals("saturday"))
                         return 6;
-                throw new LCFException("Bad day of week: '"+day+"'");
+                throw new ACFException("Bad day of week: '"+day+"'");
         }
 
         protected static EnumeratedValues parseMonthOfYear(String list)
@@ -190,7 +190,7 @@ public class AddScheduledTime
                 if (day.equals("december"))
                         return 11;
 
-                throw new LCFException("Bad month: '"+day+"'");
+                throw new ACFException("Bad month: '"+day+"'");
         }
 
         protected static EnumeratedValues parseDayOfMonth(String list)

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/BaseCrawlerInitializationCommand.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/BaseCrawlerInitializationCommand.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/BaseCrawlerInitializationCommand.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/BaseCrawlerInitializationCommand.java Mon Aug 23 18:08:32 2010
@@ -2,22 +2,22 @@ package org.apache.acf.crawler;
 
 import org.apache.acf.core.InitializationCommand;
 import org.apache.acf.core.interfaces.IThreadContext;
-import org.apache.acf.core.interfaces.LCFException;
+import org.apache.acf.core.interfaces.ACFException;
 import org.apache.acf.core.interfaces.ThreadContextFactory;
-import org.apache.acf.crawler.system.LCF;
+import org.apache.acf.crawler.system.ACF;
 
 /**
  * @author Jettro Coenradie
  */
 public abstract class BaseCrawlerInitializationCommand implements InitializationCommand
 {
-  public void execute() throws LCFException
+  public void execute() throws ACFException
   {
-    LCF.initializeEnvironment();
+    ACF.initializeEnvironment();
     IThreadContext tc = ThreadContextFactory.make();
     doExecute(tc);
   }
 
-  protected abstract void doExecute(IThreadContext tc) throws LCFException;
+  protected abstract void doExecute(IThreadContext tc) throws ACFException;
 
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ChangeJobDocSpec.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ChangeJobDocSpec.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ChangeJobDocSpec.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ChangeJobDocSpec.java Mon Aug 23 18:08:32 2010
@@ -48,7 +48,7 @@ public class ChangeJobDocSpec
 
                 try
                 {
-                        LCF.initializeEnvironment();
+                        ACF.initializeEnvironment();
                         IThreadContext tc = ThreadContextFactory.make();
                         IJobManager jobManager = JobManagerFactory.make(tc);
                         IJobDescription desc = jobManager.load(new Long(jobID));

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/CheckConfigured.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/CheckConfigured.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/CheckConfigured.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/CheckConfigured.java Mon Aug 23 18:08:32 2010
@@ -46,7 +46,7 @@ public class CheckConfigured
 
                 try
                 {
-                        LCF.initializeEnvironment();
+                        ACF.initializeEnvironment();
                         IThreadContext tc = ThreadContextFactory.make();
                         IRepositoryConnectionManager connManager = RepositoryConnectionManagerFactory.make(tc);
                         if (connManager.getAllConnections().length > 0)

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DefineJob.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DefineJob.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DefineJob.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DefineJob.java Mon Aug 23 18:08:32 2010
@@ -68,7 +68,7 @@ public class DefineJob
 
                 try
                 {
-                        LCF.initializeEnvironment();
+                        ACF.initializeEnvironment();
                         IThreadContext tc = ThreadContextFactory.make();
                         IJobManager jobManager = JobManagerFactory.make(tc);
                         IJobDescription desc = jobManager.createJob();
@@ -82,7 +82,7 @@ public class DefineJob
                         else if (typeString.equals("specified"))
                                 desc.setType(IJobDescription.TYPE_SPECIFIED);
                         else
-                                throw new LCFException("Unknown type: '"+typeString+"'");
+                                throw new ACFException("Unknown type: '"+typeString+"'");
                         if (startString.equals("windowbegin"))
                                 desc.setStartMethod(IJobDescription.START_WINDOWBEGIN);
                         else if (startString.equals("windowinside"))
@@ -90,7 +90,7 @@ public class DefineJob
                         else if (startString.equals("disable"))
                                 desc.setStartMethod(IJobDescription.START_DISABLE);
                         else
-                                throw new LCFException("Unknown start method: '"+startString+"'");
+                                throw new ACFException("Unknown start method: '"+startString+"'");
 
                         if (hopcountString.equals("accurate"))
                                 desc.setHopcountMode(IJobDescription.HOPCOUNT_ACCURATE);
@@ -99,7 +99,7 @@ public class DefineJob
                         else if (hopcountString.equals("neverdelete"))
                                 desc.setHopcountMode(IJobDescription.HOPCOUNT_NEVERDELETE);
                         else
-                                throw new LCFException("Unknown hopcount mode: '"+hopcountString+"'");
+                                throw new ACFException("Unknown hopcount mode: '"+hopcountString+"'");
                         
                         if (recrawlInterval.length() > 0)
                                 desc.setInterval(new Long(recrawlInterval));

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DefineRepositoryConnection.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DefineRepositoryConnection.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DefineRepositoryConnection.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DefineRepositoryConnection.java Mon Aug 23 18:08:32 2010
@@ -52,7 +52,7 @@ public class DefineRepositoryConnection
 
                 try
                 {
-                        LCF.initializeEnvironment();
+                        ACF.initializeEnvironment();
                         IThreadContext tc = ThreadContextFactory.make();
                         IRepositoryConnectionManager mgr = RepositoryConnectionManagerFactory.make(tc);
                         IRepositoryConnection conn = mgr.create();
@@ -70,7 +70,7 @@ public class DefineRepositoryConnection
                                 // Parse
                                 int pos = arg.indexOf("=");
                                 if (pos == -1)
-                                        throw new LCFException("Argument missing =");
+                                        throw new ACFException("Argument missing =");
                                 String name = arg.substring(0,pos);
                                 String value = arg.substring(pos+1);
                                 if (name.endsWith("assword"))

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DeleteJob.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DeleteJob.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DeleteJob.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DeleteJob.java Mon Aug 23 18:08:32 2010
@@ -47,7 +47,7 @@ public class DeleteJob
 
                 try
                 {
-                        LCF.initializeEnvironment();
+                        ACF.initializeEnvironment();
                         IThreadContext tc = ThreadContextFactory.make();
                         IJobManager jobManager = JobManagerFactory.make(tc);
                         jobManager.deleteJob(new Long(jobID));

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DeleteRepositoryConnection.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DeleteRepositoryConnection.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DeleteRepositoryConnection.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/DeleteRepositoryConnection.java Mon Aug 23 18:08:32 2010
@@ -46,7 +46,7 @@ public class DeleteRepositoryConnection
                 String connectionName = args[0];
                 try
                 {
-                        LCF.initializeEnvironment();
+                        ACF.initializeEnvironment();
                         IThreadContext tc = ThreadContextFactory.make();
                         IRepositoryConnectionManager mgr = RepositoryConnectionManagerFactory.make(tc);
                         mgr.delete(connectionName);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ExportConfiguration.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ExportConfiguration.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ExportConfiguration.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ExportConfiguration.java Mon Aug 23 18:08:32 2010
@@ -35,9 +35,9 @@ public class ExportConfiguration extends
     this.exportFilename = exportFilename;
   }
 
-  protected void doExecute(IThreadContext tc) throws LCFException
+  protected void doExecute(IThreadContext tc) throws ACFException
   {
-    LCF.exportConfiguration(tc,exportFilename);
+    ACF.exportConfiguration(tc,exportFilename);
     Logging.root.info("Configuration exported");
   }
 

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/FindJob.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/FindJob.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/FindJob.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/FindJob.java Mon Aug 23 18:08:32 2010
@@ -48,7 +48,7 @@ public class FindJob
 
     try
     {
-      LCF.initializeEnvironment();
+      ACF.initializeEnvironment();
       IThreadContext tc = ThreadContextFactory.make();
       IJobManager jobManager = JobManagerFactory.make(tc);
       IJobDescription[] jobs = jobManager.getAllJobs();

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/GetJobSchedule.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/GetJobSchedule.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/GetJobSchedule.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/GetJobSchedule.java Mon Aug 23 18:08:32 2010
@@ -49,13 +49,13 @@ public class GetJobSchedule
 
     try
     {
-      LCF.initializeEnvironment();
+      ACF.initializeEnvironment();
       IThreadContext tc = ThreadContextFactory.make();
       IJobManager jobManager = JobManagerFactory.make(tc);
 
       IJobDescription job = jobManager.load(new Long(jobID));
       if (job == null)
-        throw new LCFException("No such job: "+jobID);
+        throw new ACFException("No such job: "+jobID);
 
       int i = 0;
       while (i < job.getScheduleRecordCount())

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ImportConfiguration.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ImportConfiguration.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ImportConfiguration.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ImportConfiguration.java Mon Aug 23 18:08:32 2010
@@ -35,9 +35,9 @@ public class ImportConfiguration extends
     this.importFilename = importFilename;
   }
 
-  protected void doExecute(IThreadContext tc) throws LCFException
+  protected void doExecute(IThreadContext tc) throws ACFException
   {
-    LCF.importConfiguration(tc,importFilename);
+    ACF.importConfiguration(tc,importFilename);
     Logging.root.info("Configuration imported");
   }
 

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ListJobStatuses.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ListJobStatuses.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ListJobStatuses.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ListJobStatuses.java Mon Aug 23 18:08:32 2010
@@ -47,7 +47,7 @@ public class ListJobStatuses
 
     try
     {
-      LCF.initializeEnvironment();
+      ACF.initializeEnvironment();
       IThreadContext tc = ThreadContextFactory.make();
       IJobManager jobManager = JobManagerFactory.make(tc);
       JobStatus[] jobStatuses = jobManager.getAllStatus();

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ListJobs.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ListJobs.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ListJobs.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/ListJobs.java Mon Aug 23 18:08:32 2010
@@ -47,7 +47,7 @@ public class ListJobs
 
     try
     {
-      LCF.initializeEnvironment();
+      ACF.initializeEnvironment();
       IThreadContext tc = ThreadContextFactory.make();
       IJobManager jobManager = JobManagerFactory.make(tc);
       IJobDescription[] jobs = jobManager.getAllJobs();

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/PauseJob.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/PauseJob.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/PauseJob.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/PauseJob.java Mon Aug 23 18:08:32 2010
@@ -49,7 +49,7 @@ public class PauseJob
 
                 try
                 {
-                        LCF.initializeEnvironment();
+                        ACF.initializeEnvironment();
                         IThreadContext tc = ThreadContextFactory.make();
                         IJobManager jobManager = JobManagerFactory.make(tc);
                         jobManager.pauseJob(new Long(jobID));

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/Register.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/Register.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/Register.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/Register.java Mon Aug 23 18:08:32 2010
@@ -38,7 +38,7 @@ public class Register extends Transactio
     this.description = description;
   }
 
-  protected void doExecute(IThreadContext tc) throws LCFException
+  protected void doExecute(IThreadContext tc) throws ACFException
   {
     IConnectorManager mgr = ConnectorManagerFactory.make(tc);
     IJobManager jobManager = JobManagerFactory.make(tc);
@@ -71,7 +71,7 @@ public class Register extends Transactio
       register.execute();
       System.err.println("Successfully registered connector '"+className+"'");
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       e.printStackTrace();
       System.exit(1);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RestartJob.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RestartJob.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RestartJob.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RestartJob.java Mon Aug 23 18:08:32 2010
@@ -49,7 +49,7 @@ public class RestartJob
 
                 try
                 {
-                        LCF.initializeEnvironment();
+                        ACF.initializeEnvironment();
                         IThreadContext tc = ThreadContextFactory.make();
                         IJobManager jobManager = JobManagerFactory.make(tc);
                         jobManager.restartJob(new Long(jobID));

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunDocumentStatus.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunDocumentStatus.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunDocumentStatus.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunDocumentStatus.java Mon Aug 23 18:08:32 2010
@@ -75,7 +75,7 @@ public class RunDocumentStatus
 
     try
     {
-      LCF.initializeEnvironment();
+      ACF.initializeEnvironment();
       IThreadContext tc = ThreadContextFactory.make();
       IJobManager jobManager = JobManagerFactory.make(tc);
 
@@ -172,7 +172,7 @@ public class RunDocumentStatus
       String state = states[i].trim();
       Integer value = (Integer)stateMap.get(state.toLowerCase());
       if (value == null)
-        throw new LCFException("State value of '"+state+"' is illegal");
+        throw new ACFException("State value of '"+state+"' is illegal");
       rval[i++] = value.intValue();
     }
     return rval;
@@ -204,7 +204,7 @@ public class RunDocumentStatus
       String status = statuses[i].trim();
       Integer value = (Integer)statusMap.get(status.toLowerCase());
       if (value == null)
-        throw new LCFException("Status value of '"+status+"' is illegal");
+        throw new ACFException("Status value of '"+status+"' is illegal");
       rval[i++] = value.intValue();
     }
     return rval;

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunMaxActivityHistory.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunMaxActivityHistory.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunMaxActivityHistory.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunMaxActivityHistory.java Mon Aug 23 18:08:32 2010
@@ -72,7 +72,7 @@ public class RunMaxActivityHistory
 
     try
     {
-      LCF.initializeEnvironment();
+      ACF.initializeEnvironment();
       IThreadContext tc = ThreadContextFactory.make();
       IRepositoryConnectionManager connManager = RepositoryConnectionManagerFactory.make(tc);
 

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunMaxBandwidthHistory.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunMaxBandwidthHistory.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunMaxBandwidthHistory.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunMaxBandwidthHistory.java Mon Aug 23 18:08:32 2010
@@ -72,7 +72,7 @@ public class RunMaxBandwidthHistory
 
     try
     {
-      LCF.initializeEnvironment();
+      ACF.initializeEnvironment();
       IThreadContext tc = ThreadContextFactory.make();
       IRepositoryConnectionManager connManager = RepositoryConnectionManagerFactory.make(tc);
 

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunQueueStatus.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunQueueStatus.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunQueueStatus.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunQueueStatus.java Mon Aug 23 18:08:32 2010
@@ -77,7 +77,7 @@ public class RunQueueStatus
 
     try
     {
-      LCF.initializeEnvironment();
+      ACF.initializeEnvironment();
       IThreadContext tc = ThreadContextFactory.make();
       IJobManager jobManager = JobManagerFactory.make(tc);
 
@@ -174,7 +174,7 @@ public class RunQueueStatus
       String state = states[i].trim();
       Integer value = (Integer)stateMap.get(state.toLowerCase());
       if (value == null)
-        throw new LCFException("State value of '"+state+"' is illegal");
+        throw new ACFException("State value of '"+state+"' is illegal");
       rval[i++] = value.intValue();
     }
     return rval;
@@ -206,7 +206,7 @@ public class RunQueueStatus
       String status = statuses[i].trim();
       Integer value = (Integer)statusMap.get(status.toLowerCase());
       if (value == null)
-        throw new LCFException("Status value of '"+status+"' is illegal");
+        throw new ACFException("Status value of '"+status+"' is illegal");
       rval[i++] = value.intValue();
     }
     return rval;

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunResultHistory.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunResultHistory.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunResultHistory.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunResultHistory.java Mon Aug 23 18:08:32 2010
@@ -73,7 +73,7 @@ public class RunResultHistory
 
     try
     {
-      LCF.initializeEnvironment();
+      ACF.initializeEnvironment();
       IThreadContext tc = ThreadContextFactory.make();
       IRepositoryConnectionManager connManager = RepositoryConnectionManagerFactory.make(tc);
 

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunSimpleHistory.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunSimpleHistory.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunSimpleHistory.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/RunSimpleHistory.java Mon Aug 23 18:08:32 2010
@@ -70,7 +70,7 @@ public class RunSimpleHistory
 
     try
     {
-      LCF.initializeEnvironment();
+      ACF.initializeEnvironment();
       IThreadContext tc = ThreadContextFactory.make();
       IRepositoryConnectionManager connManager = RepositoryConnectionManagerFactory.make(tc);
 

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/StartJob.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/StartJob.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/StartJob.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/StartJob.java Mon Aug 23 18:08:32 2010
@@ -49,7 +49,7 @@ public class StartJob
 
                 try
                 {
-                        LCF.initializeEnvironment();
+                        ACF.initializeEnvironment();
                         IThreadContext tc = ThreadContextFactory.make();
                         IJobManager jobManager = JobManagerFactory.make(tc);
                         jobManager.manualStart(new Long(jobID));

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/SynchronizeConnectors.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/SynchronizeConnectors.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/SynchronizeConnectors.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/SynchronizeConnectors.java Mon Aug 23 18:08:32 2010
@@ -20,7 +20,7 @@ package org.apache.acf.crawler;
 
 import org.apache.acf.core.interfaces.*;
 import org.apache.acf.crawler.interfaces.*;
-import org.apache.acf.crawler.system.LCF;
+import org.apache.acf.crawler.system.ACF;
 import org.apache.acf.crawler.system.Logging;
 
 
@@ -35,12 +35,12 @@ public class SynchronizeConnectors exten
   {
   }
 
-  protected void doExecute(IThreadContext tc) throws LCFException
+  protected void doExecute(IThreadContext tc) throws ACFException
   {
     IDBInterface database = DBInterfaceFactory.make(tc,
-      LCF.getMasterDatabaseName(),
-      LCF.getMasterDatabaseUsername(),
-      LCF.getMasterDatabasePassword());
+      ACF.getMasterDatabaseName(),
+      ACF.getMasterDatabaseUsername(),
+      ACF.getMasterDatabasePassword());
     IConnectorManager mgr = ConnectorManagerFactory.make(tc);
     IJobManager jobManager = JobManagerFactory.make(tc);
     IRepositoryConnectionManager connManager = RepositoryConnectionManagerFactory.make(tc);
@@ -54,7 +54,7 @@ public class SynchronizeConnectors exten
       {
         RepositoryConnectorFactory.getConnectorNoCheck(className);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
         // Deregistration should be done in a transaction
         database.beginTransaction();
@@ -67,7 +67,7 @@ public class SynchronizeConnectors exten
           // Now that all jobs have been placed into an appropriate state, actually do the deregistration itself.
           mgr.removeConnector(className);
         }
-        catch (LCFException e2)
+        catch (ACFException e2)
         {
           database.signalRollback();
           throw e2;
@@ -101,7 +101,7 @@ public class SynchronizeConnectors exten
       synchronizeConnectors.execute();
       System.err.println("Successfully synchronized all connectors");
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       e.printStackTrace();
       System.exit(1);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/TransactionalCrawlerInitializationCommand.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/TransactionalCrawlerInitializationCommand.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/TransactionalCrawlerInitializationCommand.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/TransactionalCrawlerInitializationCommand.java Mon Aug 23 18:08:32 2010
@@ -2,28 +2,28 @@ package org.apache.acf.crawler;
 
 import org.apache.acf.core.InitializationCommand;
 import org.apache.acf.core.interfaces.*;
-import org.apache.acf.crawler.system.LCF;
+import org.apache.acf.crawler.system.ACF;
 
 /**
  * @author Jettro Coenradie
  */
 public abstract class TransactionalCrawlerInitializationCommand implements InitializationCommand
 {
-  public void execute() throws LCFException
+  public void execute() throws ACFException
   {
-    LCF.initializeEnvironment();
+    ACF.initializeEnvironment();
     IThreadContext tc = ThreadContextFactory.make();
     IDBInterface database = DBInterfaceFactory.make(tc,
-      org.apache.acf.agents.system.LCF.getMasterDatabaseName(),
-      org.apache.acf.agents.system.LCF.getMasterDatabaseUsername(),
-      org.apache.acf.agents.system.LCF.getMasterDatabasePassword());
+      org.apache.acf.agents.system.ACF.getMasterDatabaseName(),
+      org.apache.acf.agents.system.ACF.getMasterDatabaseUsername(),
+      org.apache.acf.agents.system.ACF.getMasterDatabasePassword());
 
     try
     {
       database.beginTransaction();
       doExecute(tc);
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       database.signalRollback();
       throw e;
@@ -40,6 +40,6 @@ public abstract class TransactionalCrawl
 
   }
 
-  protected abstract void doExecute(IThreadContext tc) throws LCFException;
+  protected abstract void doExecute(IThreadContext tc) throws ACFException;
 
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/UnRegister.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/UnRegister.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/UnRegister.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/UnRegister.java Mon Aug 23 18:08:32 2010
@@ -36,7 +36,7 @@ public class UnRegister extends Transact
     this.className = className;
   }
 
-  protected void doExecute(IThreadContext tc) throws LCFException
+  protected void doExecute(IThreadContext tc) throws ACFException
   {
     IConnectorManager mgr = ConnectorManagerFactory.make(tc);
     IJobManager jobManager = JobManagerFactory.make(tc);
@@ -65,7 +65,7 @@ public class UnRegister extends Transact
       unRegister.execute();
       System.err.println("Successfully unregistered connector '"+className+"'");
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       e.printStackTrace();
       System.exit(1);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/UnRegisterAll.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/UnRegisterAll.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/UnRegisterAll.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/UnRegisterAll.java Mon Aug 23 18:08:32 2010
@@ -33,12 +33,12 @@ public class UnRegisterAll extends BaseC
   {
   }
 
-  protected void doExecute(IThreadContext tc) throws LCFException
+  protected void doExecute(IThreadContext tc) throws ACFException
   {
     IDBInterface database = DBInterfaceFactory.make(tc,
-      LCF.getMasterDatabaseName(),
-      LCF.getMasterDatabaseUsername(),
-      LCF.getMasterDatabasePassword());
+      ACF.getMasterDatabaseName(),
+      ACF.getMasterDatabaseUsername(),
+      ACF.getMasterDatabasePassword());
     IConnectorManager mgr = ConnectorManagerFactory.make(tc);
     IJobManager jobManager = JobManagerFactory.make(tc);
     IRepositoryConnectionManager connManager = RepositoryConnectionManagerFactory.make(tc);
@@ -59,7 +59,7 @@ public class UnRegisterAll extends BaseC
         // Now that all jobs have been placed into an appropriate state, actually do the deregistration itself.
         mgr.unregisterConnector(className);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
         database.signalRollback();
         throw e;
@@ -92,7 +92,7 @@ public class UnRegisterAll extends BaseC
       unRegisterAll.execute();
       System.err.println("Successfully unregistered all connectors");
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       e.printStackTrace();
       System.exit(1);

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/WaitForJobDeleted.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/WaitForJobDeleted.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/WaitForJobDeleted.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/WaitForJobDeleted.java Mon Aug 23 18:08:32 2010
@@ -49,7 +49,7 @@ public class WaitForJobDeleted
 
                 try
                 {
-                        LCF.initializeEnvironment();
+                        ACF.initializeEnvironment();
                         IThreadContext tc = ThreadContextFactory.make();
                         IJobManager jobManager = JobManagerFactory.make(tc);
                         while (true)
@@ -57,7 +57,7 @@ public class WaitForJobDeleted
                                 JobStatus status = jobManager.getStatus(new Long(jobID));
                                 if (status == null)
                                         break;
-                                LCF.sleep(10000);
+                                ACF.sleep(10000);
                         }
 
                 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/WaitForJobInactive.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/WaitForJobInactive.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/WaitForJobInactive.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/WaitForJobInactive.java Mon Aug 23 18:08:32 2010
@@ -49,7 +49,7 @@ public class WaitForJobInactive
 
                 try
                 {
-                        LCF.initializeEnvironment();
+                        ACF.initializeEnvironment();
                         IThreadContext tc = ThreadContextFactory.make();
                         IJobManager jobManager = JobManagerFactory.make(tc);
 
@@ -57,7 +57,7 @@ public class WaitForJobInactive
                         {
                                 JobStatus status = jobManager.getStatus(new Long(jobID));
                                 if (status == null)
-                                        throw new LCFException("No such job: '"+jobID+"'");
+                                        throw new ACFException("No such job: '"+jobID+"'");
                                 int statusValue = status.getStatus();
                                 switch (statusValue)
                                 {
@@ -71,7 +71,7 @@ public class WaitForJobInactive
                                         System.out.println("Error: "+status.getErrorText());
                                         break;
                                 default:
-                                        LCF.sleep(10000);
+                                        ACF.sleep(10000);
                                         continue;
                                 }
                                 break;

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/WaitJobPaused.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/WaitJobPaused.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/WaitJobPaused.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/WaitJobPaused.java Mon Aug 23 18:08:32 2010
@@ -49,14 +49,14 @@ public class WaitJobPaused
 
                 try
                 {
-                        LCF.initializeEnvironment();
+                        ACF.initializeEnvironment();
                         IThreadContext tc = ThreadContextFactory.make();
                         IJobManager jobManager = JobManagerFactory.make(tc);
                         while (true)
                         {
                                 if (jobManager.checkJobBusy(new Long(jobID)))
                                 {
-                                        LCF.sleep(5000);
+                                        ACF.sleep(5000);
                                         continue;
                                 }
                                 break;

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/connectors/BaseRepositoryConnector.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/connectors/BaseRepositoryConnector.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/connectors/BaseRepositoryConnector.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/connectors/BaseRepositoryConnector.java Mon Aug 23 18:08:32 2010
@@ -25,7 +25,7 @@ import org.apache.acf.crawler.interfaces
 import java.io.*;
 import java.util.*;
 
-/** This base class describes an instance of a connection between a repository and LCF's
+/** This base class 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
@@ -113,10 +113,10 @@ public abstract class BaseRepositoryConn
   *@param input is the request object.
   */
   public void executeCommand(Configuration output, String command, Configuration input)
-    throws LCFException
+    throws ACFException
   {
     // By definition, the base connector has no commands.
-    throw new LCFException("Unrecognized repository connector command '"+command+"'");
+    throw new ACFException("Unrecognized repository connector command '"+command+"'");
   }
 
   /** Queue "seed" documents.  Seed documents are the starting places for crawling activity.  Documents
@@ -147,7 +147,7 @@ public abstract class BaseRepositoryConn
   */
   public void addSeedDocuments(ISeedingActivity activities, DocumentSpecification spec,
     long startTime, long endTime, int jobMode)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     addSeedDocuments(activities,spec,startTime,endTime);
   }
@@ -179,7 +179,7 @@ public abstract class BaseRepositoryConn
   */
   public void addSeedDocuments(ISeedingActivity activities, DocumentSpecification spec,
     long startTime, long endTime)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     // Call the old-style methods that get document identifiers, and then queue
     // them using the new activities-based methods
@@ -228,7 +228,7 @@ public abstract class BaseRepositoryConn
   */
   public IDocumentIdentifierStream getDocumentIdentifiers(ISeedingActivity activities, DocumentSpecification spec,
     long startTime, long endTime)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     return getDocumentIdentifiers(spec,startTime,endTime);
   }
@@ -241,7 +241,7 @@ public abstract class BaseRepositoryConn
   */
   public IDocumentIdentifierStream getDocumentIdentifiers(DocumentSpecification spec,
     long startTime, long endTime)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     // Something provided here so we can override either one.
     return null;
@@ -264,7 +264,7 @@ public abstract class BaseRepositoryConn
   */
   public IDocumentIdentifierStream getRemainingDocumentIdentifiers(ISeedingActivity activities, DocumentSpecification spec,
     long startTime, long endTime)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     // Usually we don't need to worry about this.
     return null;
@@ -289,7 +289,7 @@ public abstract class BaseRepositoryConn
   */
   public String[] getDocumentVersions(String[] documentIdentifiers, String[] oldVersions, IVersionActivity activities,
     DocumentSpecification spec, int jobMode, boolean usesDefaultAuthority)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     return getDocumentVersions(documentIdentifiers,oldVersions,activities,spec,jobMode);
   }
@@ -312,7 +312,7 @@ public abstract class BaseRepositoryConn
   */
   public String[] getDocumentVersions(String[] documentIdentifiers, String[] oldVersions, IVersionActivity activities,
     DocumentSpecification spec, int jobMode)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     return getDocumentVersions(documentIdentifiers,oldVersions,activities,spec);
   }
@@ -333,7 +333,7 @@ public abstract class BaseRepositoryConn
   * will always be processed.
   */
   public String[] getDocumentVersions(String[] documentIdentifiers, String[] oldVersions, IVersionActivity activities, DocumentSpecification spec)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     return getDocumentVersions(documentIdentifiers,activities,spec);
   }
@@ -352,7 +352,7 @@ public abstract class BaseRepositoryConn
   * will always be processed.
   */
   public String[] getDocumentVersions(String[] documentIdentifiers, IVersionActivity activities, DocumentSpecification spec)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     return getDocumentVersions(documentIdentifiers,spec);
   }
@@ -370,7 +370,7 @@ public abstract class BaseRepositoryConn
   * will always be processed.
   */
   public String[] getDocumentVersions(String[] documentIdentifiers, DocumentSpecification spec)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     // Return unknown versions
     String[] rval = new String[documentIdentifiers.length];
@@ -390,7 +390,7 @@ public abstract class BaseRepositoryConn
   *@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
   {
     // Base implementation does nothing
   }
@@ -420,7 +420,7 @@ public abstract class BaseRepositoryConn
   */
   public void processDocuments(String[] documentIdentifiers, String[] versions, IProcessActivity activities,
     DocumentSpecification spec, boolean[] scanOnly, int jobMode)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     processDocuments(documentIdentifiers,versions,activities,spec,scanOnly);
   }
@@ -440,7 +440,7 @@ public abstract class BaseRepositoryConn
   */
   public void processDocuments(String[] documentIdentifiers, String[] versions, IProcessActivity activities,
     DocumentSpecification spec, boolean[] scanOnly)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     // Does nothing; override to make something happen
   }
@@ -461,7 +461,7 @@ public abstract class BaseRepositoryConn
   *@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
   {
   }
   
@@ -474,7 +474,7 @@ public abstract class BaseRepositoryConn
   *@param tabName is the current tab name.
   */
   public void outputSpecificationBody(IHTTPOutput out, DocumentSpecification ds, String tabName)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
   }
   
@@ -487,7 +487,7 @@ public abstract class BaseRepositoryConn
   *@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
   {
     return null;
   }
@@ -499,7 +499,7 @@ public abstract class BaseRepositoryConn
   *@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/connmgr/ConnectorManager.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/connmgr/ConnectorManager.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/connmgr/ConnectorManager.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/connmgr/ConnectorManager.java Mon Aug 23 18:08:32 2010
@@ -41,7 +41,7 @@ public class ConnectorManager extends or
   *@param database is the database handle.
   */
   public ConnectorManager(IThreadContext threadContext, IDBInterface database)
-    throws LCFException
+    throws ACFException
   {
     super(database,"connectors");
     this.threadContext = threadContext;
@@ -51,7 +51,7 @@ public class ConnectorManager extends or
   /** Install or upgrade.
   */
   public void install()
-    throws LCFException
+    throws ACFException
   {
     // Always do an outer loop, to support upgrade complexities
     while (true)
@@ -96,7 +96,7 @@ public class ConnectorManager extends or
   /** Uninstall.  This also unregisters all connectors.
   */
   public void deinstall()
-    throws LCFException
+    throws ACFException
   {
     StringSet invKeys = new StringSet(getCacheKey());
 
@@ -115,7 +115,7 @@ public class ConnectorManager extends or
       }
       performDrop(invKeys);
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -137,7 +137,7 @@ public class ConnectorManager extends or
   *@param className is the class name.
   */
   public void registerConnector(String description, String className)
-    throws LCFException
+    throws ACFException
   {
     StringSet invKeys = new StringSet(getCacheKey());
     beginTransaction();
@@ -164,7 +164,7 @@ public class ConnectorManager extends or
       // Either way, we must do the install/upgrade itself.
       RepositoryConnectorFactory.install(threadContext,className);
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -185,7 +185,7 @@ public class ConnectorManager extends or
   *@param className is the class of the connector to unregister.
   */
   public void unregisterConnector(String className)
-    throws LCFException
+    throws ACFException
   {
     StringSet invKeys = new StringSet(getCacheKey());
     beginTransaction();
@@ -196,7 +196,7 @@ public class ConnectorManager extends or
 
       removeConnector(className);
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       signalRollback();
       throw e;
@@ -218,7 +218,7 @@ public class ConnectorManager extends or
   *@param className is the connector class to remove.
   */
   public void removeConnector(String className)
-    throws LCFException
+    throws ACFException
   {
     StringSet invKeys = new StringSet(getCacheKey());
     ArrayList list = new ArrayList();
@@ -231,7 +231,7 @@ public class ConnectorManager extends or
   * These will be ordered by description.
   */
   public IResultSet getConnectors()
-    throws LCFException
+    throws ACFException
   {
     StringSet invKeys = new StringSet(getCacheKey());
 
@@ -244,7 +244,7 @@ public class ConnectorManager extends or
   *@return the description, or null if the class is not registered.
   */
   public String getDescription(String className)
-    throws LCFException
+    throws ACFException
   {
     StringSet invKeys = new StringSet(getCacheKey());
 
@@ -263,7 +263,7 @@ public class ConnectorManager extends or
   *@return true if installed, false otherwise.
   */
   public boolean isInstalled(String className)
-    throws LCFException
+    throws ACFException
   {
     // Use the global table key; that's good enough because we don't expect stuff to change out from under very often.
     StringSet invKeys = new StringSet(getCacheKey());

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

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/DocumentSpecification.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/DocumentSpecification.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/DocumentSpecification.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/DocumentSpecification.java Mon Aug 23 18:08:32 2010
@@ -38,7 +38,7 @@ public class DocumentSpecification exten
   *@param xml is the input XML.
   */
   public DocumentSpecification(String xml)
-    throws LCFException
+    throws ACFException
   {
     super(xml);
   }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IAbortActivity.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IAbortActivity.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IAbortActivity.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IAbortActivity.java Mon Aug 23 18:08:32 2010
@@ -34,6 +34,6 @@ public interface IAbortActivity
   * caller, will signal that the current seeding activity remains incomplete and must be retried when the job is resumed.
   */
   public void checkJobStillActive()
-    throws LCFException, ServiceInterruption;
+    throws ACFException, ServiceInterruption;
 
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IConnectorManager.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IConnectorManager.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IConnectorManager.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IConnectorManager.java Mon Aug 23 18:08:32 2010
@@ -30,12 +30,12 @@ public interface IConnectorManager
   /** Install.
   */
   public void install()
-    throws LCFException;
+    throws ACFException;
 
   /** Uninstall.  This also unregisters all connectors.
   */
   public void deinstall()
-    throws LCFException;
+    throws ACFException;
 
   /** Register a new connector.
   * The connector's install method will also be called.
@@ -43,14 +43,14 @@ public interface IConnectorManager
   *@param className is the class name.
   */
   public void registerConnector(String description, String className)
-    throws LCFException;
+    throws ACFException;
 
   /** Unregister a connector.
   * The connector's deinstall method will also be called.
   *@param className is the connector class to unregister.
   */
   public void unregisterConnector(String className)
-    throws LCFException;
+    throws ACFException;
 
   /** Remove a connector.
   * Use this method when the connector doesn't seem to be in the
@@ -58,27 +58,27 @@ public interface IConnectorManager
   *@param className is the connector class to remove.
   */
   public void removeConnector(String className)
-    throws LCFException;
+    throws ACFException;
 
   /** Get ordered list of connectors.
   *@return a resultset with the columns "description" and "classname".
   * These will be ordered by description.
   */
   public IResultSet getConnectors()
-    throws LCFException;
+    throws ACFException;
 
   /** Get a description given a class name.
   *@param className is the class name.
   *@return the description, or null if the class is not registered.
   */
   public String getDescription(String className)
-    throws LCFException;
+    throws ACFException;
 
   /** Check if a particular connector is installed or not.
   *@param className is the class name of the connector.
   *@return true if installed, false otherwise.
   */
   public boolean isInstalled(String className)
-    throws LCFException;
+    throws ACFException;
 
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IDocumentIdentifierStream.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IDocumentIdentifierStream.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IDocumentIdentifierStream.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IDocumentIdentifierStream.java Mon Aug 23 18:08:32 2010
@@ -37,11 +37,11 @@ public interface IDocumentIdentifierStre
   *@return the next document identifier, or null if there are no more.
   */
   public String getNextIdentifier()
-    throws LCFException, ServiceInterruption;
+    throws ACFException, ServiceInterruption;
 
   /** Close the stream.
   */
   public void close()
-    throws LCFException;
+    throws ACFException;
 
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IEventActivity.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IEventActivity.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IEventActivity.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IEventActivity.java Mon Aug 23 18:08:32 2010
@@ -74,7 +74,7 @@ public interface IEventActivity extends 
   *@return false if the event is already in the "pending" state.
   */
   public boolean beginEventSequence(String eventName)
-    throws LCFException;
+    throws ACFException;
 
   /** Complete an event sequence.
   * This method should be called to signal that an event is no longer in the "pending" state.  This can mean that the prerequisite processing is
@@ -84,7 +84,7 @@ public interface IEventActivity extends 
   *@param eventName is the event name.
   */
   public void completeEventSequence(String eventName)
-    throws LCFException;
+    throws ACFException;
 
   /** Abort processing a document (for sequencing reasons).
   * This method should be called in order to cause the specified document to be requeued for later processing.  While this is similar in some respects
@@ -93,7 +93,7 @@ public interface IEventActivity extends 
   *@param localIdentifier is the document identifier to requeue
   */
   public void retryDocumentProcessing(String localIdentifier)
-    throws LCFException;
+    throws ACFException;
 
 
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IFingerprintActivity.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IFingerprintActivity.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IFingerprintActivity.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IFingerprintActivity.java Mon Aug 23 18:08:32 2010
@@ -35,13 +35,13 @@ public interface IFingerprintActivity
   *@return true if the mime type is indexable by this connector.
   */
   public boolean checkMimeTypeIndexable(String mimeType)
-    throws LCFException, ServiceInterruption;
+    throws ACFException, ServiceInterruption;
 
   /** Check whether a document is indexable by the currently specified output connector.
   *@param localFile is the local copy of the file to check.
   *@return true if the document is indexable.
   */
   public boolean checkDocumentIndexable(File localFile)
-    throws LCFException, ServiceInterruption;
+    throws ACFException, ServiceInterruption;
 
 }

Modified: incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IHistoryActivity.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IHistoryActivity.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IHistoryActivity.java (original)
+++ incubator/lcf/trunk/modules/framework/pull-agent/org/apache/acf/crawler/interfaces/IHistoryActivity.java Mon Aug 23 18:08:32 2010
@@ -46,6 +46,6 @@ public interface IHistoryActivity
   */
   public void recordActivity(Long startTime, String activityType, Long dataSize,
     String entityIdentifier, String resultCode, String resultDescription, String[] childIdentifiers)
-    throws LCFException;
+    throws ACFException;
 
 }