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 [5/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/connecto...

Modified: incubator/lcf/trunk/modules/connectors/memex/connector/org/apache/acf/crawler/connectors/memex/MemexConnector.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/memex/connector/org/apache/acf/crawler/connectors/memex/MemexConnector.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/memex/connector/org/apache/acf/crawler/connectors/memex/MemexConnector.java (original)
+++ incubator/lcf/trunk/modules/connectors/memex/connector/org/apache/acf/crawler/connectors/memex/MemexConnector.java Mon Aug 23 18:08:32 2010
@@ -23,7 +23,7 @@ import org.apache.acf.core.interfaces.*;
 import org.apache.acf.agents.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;
 import java.util.*;
 import java.io.*;
 import org.w3c.dom.*;
@@ -99,9 +99,9 @@ public class MemexConnector extends org.
   protected String webServerPort = null;
 
   //mieConnection is the connection to the main Configuration Server.
-  //There will be further LCFMemexConnection objects for each
+  //There will be further ACFMemexConnection objects for each
   //physical server accessed through the physicalServers collection.
-  private LCFMemexConnection mieConnection = null;
+  private ACFMemexConnection mieConnection = null;
   private MemexConnectionPool miePool = new MemexConnectionPool();
 
   //Collection describing the logical servers making up this system
@@ -109,7 +109,7 @@ public class MemexConnector extends org.
   private Hashtable<String, LogicalServer> logicalServersByPrefix = null;
 
   //Collection describing the physical servers making up this system
-  private Hashtable<String, LCFMemexConnection> physicalServers = null;
+  private Hashtable<String, ACFMemexConnection> physicalServers = null;
 
   //Two collections describing the entities in the set-up - one keyed by the entities' name, the other
   //by their label - generally speaking, we should use labels for anything being presented to the users
@@ -199,7 +199,7 @@ public class MemexConnector extends org.
       }
       return new String[]{""};
     }
-    catch(LCFException e){
+    catch(ACFException e){
       Logging.connectors.warn("Memex connection error: "+e.getMessage(),e);
       return new String[]{""};
     }
@@ -249,7 +249,7 @@ public class MemexConnector extends org.
   *@return the connection's status as a displayable string.
   */
   public String check()
-    throws LCFException
+    throws ACFException
   {
     try{
       this.setupConnection();
@@ -264,7 +264,7 @@ public class MemexConnector extends org.
   * in active use.
   */
   public void poll()
-    throws LCFException
+    throws ACFException
   {
     // Is the connection still valid?
     if (this.physicalServers != null && !this.physicalServers.isEmpty())
@@ -283,7 +283,7 @@ public class MemexConnector extends org.
   /** Disconnect from Memex.
   */
   public void disconnect()
-    throws LCFException
+    throws ACFException
   {
     this.cleanUpConnections();
     userName = null;
@@ -306,13 +306,13 @@ public class MemexConnector extends org.
   *@param input is the request object.
   */
   public void executeCommand(Configuration output, String command, Configuration input)
-    throws LCFException
+    throws ACFException
   {
     if (command.equals("database/list"))
     {
-      String virtualServer = LCF.getRootArgument(input,"virtual_server");
+      String virtualServer = ACF.getRootArgument(input,"virtual_server");
       if (virtualServer == null)
-        throw new LCFException("Missing required argument 'virtual_server'");
+        throw new ACFException("Missing required argument 'virtual_server'");
       
       try
       {
@@ -334,11 +334,11 @@ public class MemexConnector extends org.
       }
       catch (ServiceInterruption e)
       {
-        LCF.createServiceInterruptionNode(output,e);
+        ACF.createServiceInterruptionNode(output,e);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
-        LCF.createErrorNode(output,e);
+        ACF.createErrorNode(output,e);
       }
     }
     else if (command.equals("virtualserver/list"))
@@ -357,11 +357,11 @@ public class MemexConnector extends org.
       }
       catch (ServiceInterruption e)
       {
-        LCF.createServiceInterruptionNode(output,e);
+        ACF.createServiceInterruptionNode(output,e);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
-        LCF.createErrorNode(output,e);
+        ACF.createErrorNode(output,e);
       }
     }
     else if (command.equals("entitytype/list"))
@@ -386,18 +386,18 @@ public class MemexConnector extends org.
       }
       catch (ServiceInterruption e)
       {
-        LCF.createServiceInterruptionNode(output,e);
+        ACF.createServiceInterruptionNode(output,e);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
-        LCF.createErrorNode(output,e);
+        ACF.createErrorNode(output,e);
       }
     }
     else if (command.equals("field/list"))
     {
-      String entityPrefix = LCF.getRootArgument(input,"entity_type_name");
+      String entityPrefix = ACF.getRootArgument(input,"entity_type_name");
       if (entityPrefix == null)
-        throw new LCFException("Missing required argument 'entity_type_name'");
+        throw new ACFException("Missing required argument 'entity_type_name'");
       try
       {
         String[] fieldNames = listFieldNames(entityPrefix);
@@ -412,18 +412,18 @@ public class MemexConnector extends org.
       }
       catch (ServiceInterruption e)
       {
-        LCF.createServiceInterruptionNode(output,e);
+        ACF.createServiceInterruptionNode(output,e);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
-        LCF.createErrorNode(output,e);
+        ACF.createErrorNode(output,e);
       }
     }
     else if (command.equals("field/listmatchable"))
     {
-      String entityPrefix = LCF.getRootArgument(input,"entity_type_name");
+      String entityPrefix = ACF.getRootArgument(input,"entity_type_name");
       if (entityPrefix == null)
-        throw new LCFException("Missing required argument 'entity_type_name'");
+        throw new ACFException("Missing required argument 'entity_type_name'");
       try
       {
         String[] fieldNames = listMatchableFieldNames(entityPrefix);
@@ -438,11 +438,11 @@ public class MemexConnector extends org.
       }
       catch (ServiceInterruption e)
       {
-        LCF.createServiceInterruptionNode(output,e);
+        ACF.createServiceInterruptionNode(output,e);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
-        LCF.createErrorNode(output,e);
+        ACF.createErrorNode(output,e);
       }
     }
     else
@@ -490,7 +490,7 @@ public class MemexConnector extends org.
   */
   public void addSeedDocuments(ISeedingActivity activities, DocumentSpecification spec,
     long startTime, long endTime)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     //start by making sure we have a connection
     this.setupConnection();
@@ -676,11 +676,11 @@ public class MemexConnector extends org.
         {
           try
           {
-            LCF.sleep(100L);
+            ACF.sleep(100L);
           }
           catch (InterruptedException e)
           {
-            throw new LCFException(e.getMessage(),e,LCFException.INTERRUPTED);
+            throw new ACFException(e.getMessage(),e,ACFException.INTERRUPTED);
           }
         }
       }
@@ -697,7 +697,7 @@ public class MemexConnector extends org.
   }
 
   protected static boolean checkCriteria(Map<String,DecodedField> fields, List<CrawlMatchDescription> specificMatchCriteria)
-    throws LCFException
+    throws ACFException
   {
     // An empty array means EVERYTHING.
     if (specificMatchCriteria.size() == 0)
@@ -745,7 +745,7 @@ public class MemexConnector extends org.
             return true;
         }
         else
-          throw new LCFException("Bad operator value: "+operator);
+          throw new ACFException("Bad operator value: "+operator);
       }
     }
     return false;
@@ -753,7 +753,7 @@ public class MemexConnector extends org.
 
   protected void doDecode(ArrayList fieldListX, List<Map<String,DecodedField>> fieldsPerRecord, List<CrawlMatchDescription> specificMatchCriteria,
     LogicalServer ls, ISeedingActivity activities)
-    throws MemexException, LCFException
+    throws MemexException, ACFException
   {
     // First, do the decode
     ls.getMIE().mie.mxie_decode_fields(fieldListX);
@@ -850,7 +850,7 @@ public class MemexConnector extends org.
   */
   public String[] getDocumentVersions(String[] documentIdentifiers, String[] oldVersions, IVersionActivity activity,
     DocumentSpecification spec, int jobMode, boolean usesDefaultAuthority)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     String[] newVersions = new String[documentIdentifiers.length];
     // Build a hash of the indices for each document identifier
@@ -1278,7 +1278,7 @@ public class MemexConnector extends org.
   */
   public void processDocuments(String[] documentIdentifiers, String[] documentVersions,
     IProcessActivity activities, DocumentSpecification spec, boolean[] scanOnly)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
 
     // First, create the CrawlDescription object
@@ -1310,7 +1310,7 @@ public class MemexConnector extends org.
           Hashtable currentRec = lookupCachedRecord(recordURN);
           if (currentRec == null)
             // This should never happen!!
-            throw new LCFException("Process request for a record whose version was never requested!!");
+            throw new ACFException("Process request for a record whose version was never requested!!");
 
           // Now, unpack the version string to obtain what fields we should ingest etc.
           ArrayList<String> primaryList = new ArrayList<String>();
@@ -1468,7 +1468,7 @@ public class MemexConnector extends org.
         }
       }
     }catch(java.io.UnsupportedEncodingException e){
-      throw new LCFException("Unsupported encoding: "+e.getMessage(),e);
+      throw new ACFException("Unsupported encoding: "+e.getMessage(),e);
     }
 
   }
@@ -1521,7 +1521,7 @@ public class MemexConnector extends org.
   *@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
   {
     // Clean up our part of the cache.
     for (int i = 0; i < documentIdentifiers.length; i++)
@@ -1554,7 +1554,7 @@ public class MemexConnector extends org.
   *@param tabsArray is an array of tab names.  Add to this array any tab names that are specific to the connector.
   */
   public void outputConfigurationHeader(IThreadContext threadContext, IHTTPOutput out, ConfigParams parameters, ArrayList tabsArray)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     tabsArray.add("Memex Server");
     tabsArray.add("Web Server");
@@ -1780,7 +1780,7 @@ public class MemexConnector extends org.
   *@param tabName is the current tab name.
   */
   public void outputConfigurationBody(IThreadContext threadContext, IHTTPOutput out, ConfigParams parameters, String tabName)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     String memexServerName = parameters.getParameter(org.apache.acf.crawler.connectors.memex.MemexConnector.CONFIG_PARAM_MEMEXSERVERNAME);
     if (memexServerName == null)
@@ -1925,7 +1925,7 @@ public class MemexConnector extends org.
   *@return null if all is well, or a string error message if there is an error that should prevent saving of the connection (and cause a redirection to an error page).
   */
   public String processConfigurationPost(IThreadContext threadContext, IPostParameters variableContext, ConfigParams parameters)
-    throws LCFException
+    throws ACFException
   {
     String memexServerName = variableContext.getParameter("memexservername");
     if (memexServerName != null)
@@ -1973,7 +1973,7 @@ public class MemexConnector extends org.
   *@param parameters are the configuration parameters, as they currently exist, for this connection being configured.
   */
   public void viewConfiguration(IThreadContext threadContext, IHTTPOutput out, ConfigParams parameters)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     out.print(
 "<table class=\"displaytable\">\n"+
@@ -2021,7 +2021,7 @@ public class MemexConnector extends org.
   *@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
   {
     tabsArray.add("Record Criteria");
     tabsArray.add("Entities");
@@ -2307,7 +2307,7 @@ public class MemexConnector extends org.
   *@param tabName is the current tab name.
   */
   public void outputSpecificationBody(IHTTPOutput out, DocumentSpecification ds, String tabName)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     int i;
     int k;
@@ -2473,7 +2473,7 @@ public class MemexConnector extends org.
           ii++;
         }
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
         out.print(
 "  <tr>\n"+
@@ -2734,7 +2734,7 @@ public class MemexConnector extends org.
 "              </select>\n"
           );
         }
-        catch (LCFException e)
+        catch (ACFException e)
         {
           out.print(
 "              "+org.apache.acf.ui.util.Encoder.bodyEscape(e.getMessage())+"\n"
@@ -2789,7 +2789,7 @@ public class MemexConnector extends org.
 "              </select>\n"
             );
           }
-          catch (LCFException e)
+          catch (ACFException e)
           {
             out.print(
 "              "+org.apache.acf.ui.util.Encoder.bodyEscape(e.getMessage())+"\n"
@@ -2858,7 +2858,7 @@ public class MemexConnector extends org.
 "              <input type=\"text\" name=\"rulefieldvalueselect\" size=\"32\" value=\"\"/>\n"
             );
           }
-          catch (LCFException e)
+          catch (ACFException e)
           {
             out.print(
 "              "+org.apache.acf.ui.util.Encoder.bodyEscape(e.getMessage())+"\n"
@@ -3049,7 +3049,7 @@ public class MemexConnector extends org.
   *@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
   {
     String x = variableContext.getParameter("entitytypecount");
     if (x != null && x.length() > 0)
@@ -3300,7 +3300,7 @@ public class MemexConnector extends org.
   *@param ds is the current document specification for this job.
   */
   public void viewSpecification(IHTTPOutput out, DocumentSpecification ds)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     out.print(
 "<table class=\"displaytable\">\n"+
@@ -3540,7 +3540,7 @@ public class MemexConnector extends org.
 
   /** Return a list of databases (instances of an entity type) on a given virtual server*/
   public NameDescription[] listDatabasesForVirtualServer(String virtualServerName)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     //Start by making sure we're connected
     this.setupConnection();
@@ -3549,11 +3549,11 @@ public class MemexConnector extends org.
     if(!(logicalServers.containsKey(virtualServerName))){
       //If we can't find the virtual server, its unlikely we can
       //recover
-      throw new LCFException("Memex error: Virtual server "+virtualServerName+" not found");
+      throw new ACFException("Memex error: Virtual server "+virtualServerName+" not found");
     }
     LogicalServer ls = logicalServers.get(virtualServerName);
     if (ls == null)
-      throw new LCFException("Memex error: Virtual server "+virtualServerName+" not found");
+      throw new ACFException("Memex error: Virtual server "+virtualServerName+" not found");
 
     ArrayList<String> dblist = new ArrayList<String>();
     for(int i = 0; i < ls.getDatabaseCount(); i++){
@@ -3582,7 +3582,7 @@ public class MemexConnector extends org.
 
   /** Return a list of virtual servers for the connection, in sorted alphabetic order */
   public String[] listVirtualServers()
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     //Start by making sure we're connected
     this.setupConnection();
@@ -3615,7 +3615,7 @@ public class MemexConnector extends org.
 
   /** Return a list of the entity types there are for the connection, in sorted alphabetic order */
   public NameDescription[] listEntityTypes()
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     //Start by making sure we're connected
     this.setupConnection();
@@ -3652,7 +3652,7 @@ public class MemexConnector extends org.
 
   /** Return a list of the field names for the entity prefix in the implied connection, in sorted alphabetic order */
   public String[] listFieldNames(String entityPrefix)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     //Start by making sure we're connected
     this.setupConnection();
@@ -3662,12 +3662,12 @@ public class MemexConnector extends org.
       if (entity != null)
         return entity.getFields();
     }
-    throw new LCFException("Entity type '"+entityPrefix+"' does not exist");
+    throw new ACFException("Entity type '"+entityPrefix+"' does not exist");
   }
 
   /** Return a list of the field names that mie can directly fetch from a record (for document specification) */
   public String[] listMatchableFieldNames(String entityPrefix)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     String[] candidates = listFieldNames(entityPrefix);
     if (candidates == null)
@@ -3813,7 +3813,7 @@ public class MemexConnector extends org.
   //
   ///////////////////////////////////////////////////////////////////////
   private void setupConnection()
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
 
     boolean connected = false;
@@ -3822,7 +3822,7 @@ public class MemexConnector extends org.
       connected = true;
       for(Enumeration serverkeys = physicalServers.keys(); serverkeys.hasMoreElements();){
         String serverkey = (String)serverkeys.nextElement();
-        LCFMemexConnection pserver = physicalServers.get(serverkey);
+        ACFMemexConnection pserver = physicalServers.get(serverkey);
         if(!(pserver.isConnected())){
           connected = false;
         }
@@ -3842,10 +3842,10 @@ public class MemexConnector extends org.
         miePool.setCharset(characterEncoding);
 
         //Initialise data structures
-        mieConnection = new LCFMemexConnection();
+        mieConnection = new ACFMemexConnection();
         logicalServers = new Hashtable<String, LogicalServer>();
         logicalServersByPrefix = new Hashtable<String, LogicalServer>();
-        physicalServers = new Hashtable<String, LCFMemexConnection>();
+        physicalServers = new Hashtable<String, ACFMemexConnection>();
         entitiesByName = new Hashtable<String, MemexEntity>();
         entitiesByLabel = new Hashtable<String, MemexEntity>();
         entitiesByPrefix = new Hashtable<String, MemexEntity>();
@@ -3873,7 +3873,7 @@ public class MemexConnector extends org.
 
       }
       catch(PoolAuthenticationException e){
-        throw new LCFException("Authentication failure connecting to Memex Server " + miePool.getHostname() + ":" + Integer.toString(miePool.getPort())+": "+e.getMessage(),e);
+        throw new ACFException("Authentication failure connecting to Memex Server " + miePool.getHostname() + ":" + Integer.toString(miePool.getPort())+": "+e.getMessage(),e);
       }
       catch(PoolException e){
         Logging.connectors.warn("Memex: Pool error connecting to Memex Server " + miePool.getHostname() + ":" + Integer.toString(miePool.getPort()) + " - " + e.getMessage() + " - retrying",e);
@@ -3913,7 +3913,7 @@ public class MemexConnector extends org.
       while (i < serverKeyArray.length)
       {
         String serverkey = serverKeyArray[i++];
-        LCFMemexConnection currentMIE = physicalServers.get(serverkey);
+        ACFMemexConnection currentMIE = physicalServers.get(serverkey);
         try{
           // Remove history directories belonging to this session
           physicalServers.remove(serverkey);
@@ -3943,7 +3943,7 @@ public class MemexConnector extends org.
   /**Creates an alphabetically ordered list of entity objects.
   */
   private void getEntities()
-    throws MemexException, LCFException, ServiceInterruption
+    throws MemexException, ACFException, ServiceInterruption
   {
     String mxEntityPath = null;
     String[] entityReturn = new String[1];
@@ -4013,11 +4013,11 @@ public class MemexConnector extends org.
                   // Parse it!
                   entityForm = db.parse(formStream);
                 }catch(ParserConfigurationException e){
-                  throw new LCFException("Can't find a valid parser: "+e.getMessage(),e);
+                  throw new ACFException("Can't find a valid parser: "+e.getMessage(),e);
                 }catch(SAXException e){
-                  throw new LCFException("XML had parse errors: "+e.getMessage(),e);
+                  throw new ACFException("XML had parse errors: "+e.getMessage(),e);
                 }catch(InterruptedIOException e){
-                  throw new LCFException(e.getMessage(),e,LCFException.INTERRUPTED);
+                  throw new ACFException(e.getMessage(),e,ACFException.INTERRUPTED);
                 }catch(IOException e){
                   // I/O problem; treat as  a service interruption
                   long currentTime = System.currentTimeMillis();
@@ -4032,11 +4032,11 @@ public class MemexConnector extends org.
                   }
                   catch (InterruptedIOException e)
                   {
-                    throw new LCFException(e.getMessage(),e,LCFException.INTERRUPTED);
+                    throw new ACFException(e.getMessage(),e,ACFException.INTERRUPTED);
                   }
                   catch (IOException e)
                   {
-                    throw new LCFException("Error reading memex form data: "+e.getMessage(),e);
+                    throw new ACFException("Error reading memex form data: "+e.getMessage(),e);
                   }
                 }
               }catch(MemexException e){
@@ -4116,7 +4116,7 @@ public class MemexConnector extends org.
             serverFields.add(serversource);
             //mieConnection.mie.mxie_goto_record(hist, x);
             mieConnection.mie.mxie_decode_fields(serverFields);
-            LCFMemexConnection mie;
+            ACFMemexConnection mie;
             if(serversource.getText().equals("configuration-server")){
               mie = mieConnection;
             }else{
@@ -4137,14 +4137,14 @@ public class MemexConnector extends org.
     }
   }
 
-  private LCFMemexConnection getPhysicalServer(String server, int port){
+  private ACFMemexConnection getPhysicalServer(String server, int port){
 
     String key = server + ":" + Integer.toString(port);
 
     if(physicalServers.containsKey(key)){
-      return (LCFMemexConnection)physicalServers.get(key);
+      return (ACFMemexConnection)physicalServers.get(key);
     }else{
-      LCFMemexConnection newServer = new LCFMemexConnection();
+      ACFMemexConnection newServer = new ACFMemexConnection();
       try{
         MemexConnection newMIE = miePool.getConnection(server, port);
         newServer.mie = newMIE;
@@ -4267,7 +4267,7 @@ public class MemexConnector extends org.
   * @return - the hash table representation of the record. Null if its not found
   */
   private Hashtable getmxRecordObj(LogicalServer ls, int histno, int recnum)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     Hashtable mxRecord = null;
     try{
@@ -4436,7 +4436,7 @@ public class MemexConnector extends org.
       }
       catch (InterruptedIOException eek)
       {
-        throw new LCFException(eek.getMessage(),eek,LCFException.INTERRUPTED);
+        throw new ACFException(eek.getMessage(),eek,ACFException.INTERRUPTED);
       }
       catch (IOException eek) {
         // Treat this as a service interruption
@@ -4460,15 +4460,15 @@ public class MemexConnector extends org.
     }
     catch (UnsupportedEncodingException e){
       Logging.connectors.error("Memex: "+e.getMessage(),e);
-      throw new LCFException(e.getMessage(),e);
+      throw new ACFException(e.getMessage(),e);
     }
     catch (InterruptedIOException e)
     {
-      throw new LCFException(e.getMessage(),e,LCFException.INTERRUPTED);
+      throw new ACFException(e.getMessage(),e,ACFException.INTERRUPTED);
     }
     catch (IOException e)
     {
-      throw new LCFException(e.getMessage(),e);
+      throw new ACFException(e.getMessage(),e);
     }
   }
 

Modified: incubator/lcf/trunk/modules/connectors/meridio/connector/org/apache/acf/crawler/connectors/meridio/MeridioAuthority.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/meridio/connector/org/apache/acf/crawler/connectors/meridio/MeridioAuthority.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/meridio/connector/org/apache/acf/crawler/connectors/meridio/MeridioAuthority.java (original)
+++ incubator/lcf/trunk/modules/connectors/meridio/connector/org/apache/acf/crawler/connectors/meridio/MeridioAuthority.java Mon Aug 23 18:08:32 2010
@@ -25,7 +25,7 @@ import org.apache.acf.crawler.connectors
 import org.apache.acf.crawler.connectors.meridio.RMDataSet.RMDataSet;
 import org.tempuri.GroupResult;
 import org.apache.acf.authorities.system.Logging;
-import org.apache.acf.authorities.system.LCF;
+import org.apache.acf.authorities.system.ACF;
 import org.apache.acf.authorities.interfaces.AuthorizationResponse;
 
 import org.apache.commons.httpclient.protocol.Protocol;
@@ -122,7 +122,7 @@ public class MeridioAuthority extends or
 
   /** Set up connection before attempting to use it */
   protected void attemptToConnect()
-    throws LCFException
+    throws ACFException
   {
     if (meridio_ == null)
     {
@@ -135,7 +135,7 @@ public class MeridioAuthority extends or
 
       String DMWSProtocol = params.getParameter("DMWSServerProtocol");
       if (DMWSProtocol == null)
-        throw new LCFException("Missing required configuration parameter: DMWSServerProtocol");
+        throw new ACFException("Missing required configuration parameter: DMWSServerProtocol");
       String DMWSPort = params.getParameter("DMWSServerPort");
       if (DMWSPort == null || DMWSPort.length() == 0)
         DMWSPort = "";
@@ -149,7 +149,7 @@ public class MeridioAuthority extends or
 
       String RMWSProtocol = params.getParameter("RMWSServerProtocol");
       if (RMWSProtocol == null)
-        throw new LCFException("Missing required configuration parameter: RMWSServerProtocol");
+        throw new ACFException("Missing required configuration parameter: RMWSServerProtocol");
       String RMWSPort = params.getParameter("RMWSServerPort");
       if (RMWSPort == null || RMWSPort.length() == 0)
         RMWSPort = "";
@@ -163,14 +163,14 @@ public class MeridioAuthority extends or
 
       String MetaCartaWSProtocol = params.getParameter("MetaCartaWSServerProtocol");
       if (MetaCartaWSProtocol == null)
-        throw new LCFException("Missing required configuration parameter: MetaCartaWSServerProtocol");
+        throw new ACFException("Missing required configuration parameter: MetaCartaWSServerProtocol");
       String MetaCartaWSPort = params.getParameter("MetaCartaWSServerPort");
       if (MetaCartaWSPort == null || MetaCartaWSPort.length() == 0)
         MetaCartaWSPort = "";
       else
         MetaCartaWSPort = ":" + MetaCartaWSPort;
 
-      String LCFWSUrlString = MetaCartaWSProtocol + "://" +
+      String ACFWSUrlString = MetaCartaWSProtocol + "://" +
         params.getParameter("MetaCartaWSServerName") +
         MetaCartaWSPort +
         params.getParameter("MetaCartaWSLocation");
@@ -192,7 +192,7 @@ public class MeridioAuthority extends or
       {
         DmwsURL = new URL(DMWSUrlString);
         RmwsURL = new URL(RMWSUrlString);
-        MetaCartawsURL = new URL(LCFWSUrlString);
+        MetaCartawsURL = new URL(ACFWSUrlString);
 
         if (Logging.authorityConnectors.isDebugEnabled())
         {
@@ -204,7 +204,7 @@ public class MeridioAuthority extends or
       }
       catch (MalformedURLException malformedURLException)
       {
-        throw new LCFException("Meridio: Could not construct the URL for either " +
+        throw new ACFException("Meridio: Could not construct the URL for either " +
           "the Meridio DM, Meridio RM, or MetaCarta Meridio Web Service: "+malformedURLException, malformedURLException);
       }
 
@@ -214,9 +214,9 @@ public class MeridioAuthority extends or
         * Now try and login to Meridio; the wrapper's constructor can be
         * used as it calls the Meridio login method
         *================================================================*/
-        File meridioWSDDLocation = LCF.getFileProperty(wsddPathProperty);
+        File meridioWSDDLocation = ACF.getFileProperty(wsddPathProperty);
         if (meridioWSDDLocation == null)
-          throw new LCFException("Meridio wsdd location path (property "+wsddPathProperty+") must be specified!");
+          throw new ACFException("Meridio wsdd location path (property "+wsddPathProperty+") must be specified!");
 
         meridio_ = new MeridioWrapper(Logging.authorityConnectors, DmwsURL, RmwsURL, MetaCartawsURL,
           DMWSProxyHost, DMWSProxyPort, RMWSProxyHost, RMWSProxyPort, MetaCartaWSProxyHost, MetaCartaWSProxyPort,
@@ -227,7 +227,7 @@ public class MeridioAuthority extends or
       }
       catch (UnknownHostException unknownHostException)
       {
-        throw new LCFException("Meridio: A Unknown Host Exception occurred while " +
+        throw new ACFException("Meridio: A Unknown Host Exception occurred while " +
           "connecting - is a network software and hardware configuration: "+unknownHostException.getMessage(), unknownHostException);
       }
       catch (org.apache.axis.AxisFault e)
@@ -240,23 +240,23 @@ public class MeridioAuthority extends or
           {
             elem.normalize();
             String httpErrorCode = elem.getFirstChild().getNodeValue().trim();
-            throw new LCFException("Unexpected http error code "+httpErrorCode+" accessing Meridio: "+e.getMessage(),e);
+            throw new ACFException("Unexpected http error code "+httpErrorCode+" accessing Meridio: "+e.getMessage(),e);
           }
-          throw new LCFException("Unknown http error occurred while connecting: "+e.getMessage(),e);
+          throw new ACFException("Unknown http error occurred while connecting: "+e.getMessage(),e);
         }
         if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server.userException")))
         {
           String exceptionName = e.getFaultString();
           if (exceptionName.equals("java.lang.InterruptedException"))
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
         }
         if (Logging.authorityConnectors.isDebugEnabled())
           Logging.authorityConnectors.debug("Meridio: Got an unknown remote exception connecting - axis fault = "+e.getFaultCode().getLocalPart()+", detail = "+e.getFaultString()+" - retrying",e);
-        throw new LCFException("Remote procedure exception: "+e.getMessage(),e);
+        throw new ACFException("Remote procedure exception: "+e.getMessage(),e);
       }
       catch (RemoteException remoteException)
       {
-        throw new LCFException("Meridio: An unknown remote exception occurred while " +
+        throw new ACFException("Meridio: An unknown remote exception occurred while " +
           "connecting: "+remoteException.getMessage(), remoteException);
       }
 
@@ -270,7 +270,7 @@ public class MeridioAuthority extends or
   /** Check connection for sanity.
   */
   public String check()
-    throws LCFException
+    throws ACFException
   {
     Logging.authorityConnectors.debug("Meridio: Entering 'check' method");
     attemptToConnect();
@@ -331,7 +331,7 @@ public class MeridioAuthority extends or
       {
         String exceptionName = e.getFaultString();
         if (exceptionName.equals("java.lang.InterruptedException"))
-          throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+          throw new ACFException("Interrupted",ACFException.INTERRUPTED);
       }
       if (Logging.authorityConnectors.isDebugEnabled())
         Logging.authorityConnectors.debug("Meridio: Got an unknown remote exception checking - axis fault = "+e.getFaultCode().getLocalPart()+", detail = "+e.getFaultString()+" - retrying",e);
@@ -365,7 +365,7 @@ public class MeridioAuthority extends or
   /** Close the connection.  Call this before discarding the repository connector.
   */
   public void disconnect()
-    throws LCFException
+    throws ACFException
   {
     Logging.authorityConnectors.debug("Meridio: Entering 'disconnect' method");
     try
@@ -395,7 +395,7 @@ public class MeridioAuthority extends or
       {
         String exceptionName = e.getFaultString();
         if (exceptionName.equals("java.lang.InterruptedException"))
-          throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+          throw new ACFException("Interrupted",ACFException.INTERRUPTED);
       }
       if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server")))
       {
@@ -442,7 +442,7 @@ public class MeridioAuthority extends or
   * (Should throws an exception only when a condition cannot be properly described within the authorization response object.)
   */
   public AuthorizationResponse getAuthorizationResponse(String userName)
-    throws LCFException
+    throws ACFException
   {
     if (Logging.authorityConnectors.isDebugEnabled())
       Logging.authorityConnectors.debug("Meridio: Authentication user name = '" + userName + "'");
@@ -561,15 +561,15 @@ public class MeridioAuthority extends or
           {
             elem.normalize();
             String httpErrorCode = elem.getFirstChild().getNodeValue().trim();
-            throw new LCFException("Unexpected http error code "+httpErrorCode+" accessing Meridio: "+e.getMessage(),e);
+            throw new ACFException("Unexpected http error code "+httpErrorCode+" accessing Meridio: "+e.getMessage(),e);
           }
-          throw new LCFException("Unknown http error occurred while getting doc versions: "+e.getMessage(),e);
+          throw new ACFException("Unknown http error occurred while getting doc versions: "+e.getMessage(),e);
         }
         if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server.userException")))
         {
           String exceptionName = e.getFaultString();
           if (exceptionName.equals("java.lang.InterruptedException"))
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
         }
         if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server")))
         {
@@ -583,18 +583,18 @@ public class MeridioAuthority extends or
 
         if (Logging.authorityConnectors.isDebugEnabled())
           Logging.authorityConnectors.debug("Meridio: Got an unknown remote exception getting user tokens - axis fault = "+e.getFaultCode().getLocalPart()+", detail = "+e.getFaultString()+" - retrying",e);
-        throw new LCFException("Axis fault: "+e.getMessage(),  e);
+        throw new ACFException("Axis fault: "+e.getMessage(),  e);
       }
       catch (RemoteException remoteException)
       {
-        throw new LCFException("Meridio: A remote exception occurred while getting user tokens: " +
+        throw new ACFException("Meridio: A remote exception occurred while getting user tokens: " +
           remoteException.getMessage(), remoteException);
       }
       catch (MeridioDataSetException meridioDataSetException)
       {
         Logging.authorityConnectors.error("Meridio: A provlem occurred manipulating the Web Service XML: " +
           meridioDataSetException.getMessage(), meridioDataSetException);
-        throw new LCFException("Meridio: A problem occurred manipulating the Web " +
+        throw new ACFException("Meridio: A problem occurred manipulating the Web " +
           "Service XML: "+meridioDataSetException.getMessage(), meridioDataSetException);
       }
     }
@@ -623,7 +623,7 @@ public class MeridioAuthority extends or
   *@param tabsArray is an array of tab names.  Add to this array any tab names that are specific to the connector.
   */
   public void outputConfigurationHeader(IThreadContext threadContext, IHTTPOutput out, ConfigParams parameters, ArrayList tabsArray)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     tabsArray.add("Document Server");
     tabsArray.add("Records Server");
@@ -773,7 +773,7 @@ public class MeridioAuthority extends or
   *@param tabName is the current tab name.
   */
   public void outputConfigurationBody(IThreadContext threadContext, IHTTPOutput out, ConfigParams parameters, String tabName)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     String dmwsServerProtocol = parameters.getParameter("DMWSServerProtocol");
     if (dmwsServerProtocol == null)
@@ -1065,7 +1065,7 @@ public class MeridioAuthority extends or
   *@return null if all is well, or a string error message if there is an error that should prevent saving of the connection (and cause a redirection to an error page).
   */
   public String processConfigurationPost(IThreadContext threadContext, IPostParameters variableContext, ConfigParams parameters)
-    throws LCFException
+    throws ACFException
   {
     String dmwsServerProtocol = variableContext.getParameter("dmwsServerProtocol");
     if (dmwsServerProtocol != null)
@@ -1194,7 +1194,7 @@ public class MeridioAuthority extends or
           }
           catch (IOException e)
           {
-            throw new LCFException(e.getMessage(),e);
+            throw new ACFException(e.getMessage(),e);
           }
         }
 
@@ -1217,7 +1217,7 @@ public class MeridioAuthority extends or
   *@param parameters are the configuration parameters, as they currently exist, for this connection being configured.
   */
   public void viewConfiguration(IThreadContext threadContext, IHTTPOutput out, ConfigParams parameters)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     out.print(
 "<table class=\"displaytable\">\n"+

Modified: incubator/lcf/trunk/modules/connectors/meridio/connector/org/apache/acf/crawler/connectors/meridio/MeridioConnector.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/meridio/connector/org/apache/acf/crawler/connectors/meridio/MeridioConnector.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/meridio/connector/org/apache/acf/crawler/connectors/meridio/MeridioConnector.java (original)
+++ incubator/lcf/trunk/modules/connectors/meridio/connector/org/apache/acf/crawler/connectors/meridio/MeridioConnector.java Mon Aug 23 18:08:32 2010
@@ -29,7 +29,7 @@ import org.apache.acf.crawler.connectors
 import org.apache.acf.crawler.connectors.meridio.meridiowrapper.MeridioWrapper;
 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;
 
 import org.apache.commons.httpclient.protocol.Protocol;
 import org.apache.commons.httpclient.protocol.ProtocolFactory;
@@ -117,7 +117,7 @@ public class MeridioConnector extends or
 
   /** Set up the session with Meridio */
   protected void getSession()
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     if (meridio_ == null)
     {
@@ -183,8 +183,8 @@ public class MeridioConnector extends or
       }
       catch (MalformedURLException malformedURLException)
       {
-        throw new LCFException("Meridio: Could not construct the URL for either " +
-          "the DM or RM Meridio Web Service", malformedURLException, LCFException.REPOSITORY_CONNECTION_ERROR);
+        throw new ACFException("Meridio: Could not construct the URL for either " +
+          "the DM or RM Meridio Web Service", malformedURLException, ACFException.REPOSITORY_CONNECTION_ERROR);
       }
 
       // Do the second part (where we actually try to connect to the system)
@@ -194,9 +194,9 @@ public class MeridioConnector extends or
         * Now try and login to Meridio; the wrapper's constructor can be
         * used as it calls the Meridio login method
         *================================================================*/
-        File meridioWSDDLocation = LCF.getFileProperty(wsddPathProperty);
+        File meridioWSDDLocation = ACF.getFileProperty(wsddPathProperty);
         if (meridioWSDDLocation == null)
-          throw new LCFException("Meridio wsdd location path (property "+wsddPathProperty+") must be specified!");
+          throw new ACFException("Meridio wsdd location path (property "+wsddPathProperty+") must be specified!");
 
         meridio_ = new MeridioWrapper(Logging.connectors, DmwsURL, RmwsURL, null,
           params.getParameter("DMWSProxyHost"),
@@ -213,7 +213,7 @@ public class MeridioConnector extends or
       }
       catch (UnknownHostException unknownHostException)
       {
-        throw new LCFException("Meridio: A Unknown Host Exception occurred while " +
+        throw new ACFException("Meridio: A Unknown Host Exception occurred while " +
           "connecting - is a network software and hardware configuration: "+unknownHostException.getMessage(), unknownHostException);
       }
       catch (org.apache.axis.AxisFault e)
@@ -226,15 +226,15 @@ public class MeridioConnector extends or
           {
             elem.normalize();
             String httpErrorCode = elem.getFirstChild().getNodeValue().trim();
-            throw new LCFException("Unexpected http error code "+httpErrorCode+" accessing Meridio: "+e.getMessage(),e);
+            throw new ACFException("Unexpected http error code "+httpErrorCode+" accessing Meridio: "+e.getMessage(),e);
           }
-          throw new LCFException("Unknown http error occurred while connecting: "+e.getMessage(),e);
+          throw new ACFException("Unknown http error occurred while connecting: "+e.getMessage(),e);
         }
         if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server.userException")))
         {
           String exceptionName = e.getFaultString();
           if (exceptionName.equals("java.lang.InterruptedException"))
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
         }
         if (Logging.connectors.isDebugEnabled())
           Logging.connectors.debug("Meridio: Got an unknown remote exception connecting - axis fault = "+e.getFaultCode().getLocalPart()+", detail = "+e.getFaultString()+" - retrying",e);
@@ -243,7 +243,7 @@ public class MeridioConnector extends or
       }
       catch (RemoteException remoteException)
       {
-        throw new LCFException("Meridio: An unknown remote exception occurred while " +
+        throw new ACFException("Meridio: An unknown remote exception occurred while " +
           "connecting: "+remoteException.getMessage(), remoteException);
       }
 
@@ -270,7 +270,7 @@ public class MeridioConnector extends or
   *@return the connection's status as a displayable string.
   */
   public String check()
-    throws LCFException
+    throws ACFException
   {
     Logging.connectors.debug("Meridio: Entering 'check' method");
 
@@ -284,7 +284,7 @@ public class MeridioConnector extends or
     {
       return "Meridio temporarily unavailable: "+e.getMessage();
     }
-    catch (LCFException e)
+    catch (ACFException e)
     {
       return e.getMessage();
     }
@@ -340,7 +340,7 @@ public class MeridioConnector extends or
       {
         String exceptionName = e.getFaultString();
         if (exceptionName.equals("java.lang.InterruptedException"))
-          throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+          throw new ACFException("Interrupted",ACFException.INTERRUPTED);
       }
       if (Logging.connectors.isDebugEnabled())
         Logging.connectors.debug("Meridio: Got an unknown remote exception checking - axis fault = "+e.getFaultCode().getLocalPart()+", detail = "+e.getFaultString()+" - retrying",e);
@@ -391,7 +391,7 @@ public class MeridioConnector extends or
   /** Close the connection.  Call this before discarding the repository connector.
   */
   public void disconnect()
-    throws LCFException
+    throws ACFException
   {
     Logging.connectors.debug("Meridio: Entering 'disconnect' method");
 
@@ -422,7 +422,7 @@ public class MeridioConnector extends or
       {
         String exceptionName = e.getFaultString();
         if (exceptionName.equals("java.lang.InterruptedException"))
-          throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+          throw new ACFException("Interrupted",ACFException.INTERRUPTED);
       }
       if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server")))
       {
@@ -474,7 +474,7 @@ public class MeridioConnector extends or
   *@param input is the request object.
   */
   public void executeCommand(Configuration output, String command, Configuration input)
-    throws LCFException
+    throws ACFException
   {
     if (command.equals("category/list"))
     {
@@ -492,11 +492,11 @@ public class MeridioConnector extends or
       }
       catch (ServiceInterruption e)
       {
-        LCF.createServiceInterruptionNode(output,e);
+        ACF.createServiceInterruptionNode(output,e);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
-        LCF.createErrorNode(output,e);
+        ACF.createErrorNode(output,e);
       }
     }
     else if (command.equals("documentproperties/list"))
@@ -515,18 +515,18 @@ public class MeridioConnector extends or
       }
       catch (ServiceInterruption e)
       {
-        LCF.createServiceInterruptionNode(output,e);
+        ACF.createServiceInterruptionNode(output,e);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
-        LCF.createErrorNode(output,e);
+        ACF.createErrorNode(output,e);
       }
     }
     else if (command.equals("classorfolder/list"))
     {
-      String classOrFolderIdString = LCF.getRootArgument(input,"class_or_folder_id");
+      String classOrFolderIdString = ACF.getRootArgument(input,"class_or_folder_id");
       if (classOrFolderIdString == null)
-        throw new LCFException("Missing required argument 'class_or_folder_id'");
+        throw new ACFException("Missing required argument 'class_or_folder_id'");
       int classOrFolderId;
       try
       {
@@ -534,7 +534,7 @@ public class MeridioConnector extends or
       }
       catch (NumberFormatException e)
       {
-        throw new LCFException("Argument 'class_or_folder_id' must be an integer: "+e.getMessage(),e);
+        throw new ACFException("Argument 'class_or_folder_id' must be an integer: "+e.getMessage(),e);
       }
       try
       {
@@ -566,11 +566,11 @@ public class MeridioConnector extends or
       }
       catch (ServiceInterruption e)
       {
-        LCF.createServiceInterruptionNode(output,e);
+        ACF.createServiceInterruptionNode(output,e);
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
-        LCF.createErrorNode(output,e);
+        ACF.createErrorNode(output,e);
       }
     }
     else
@@ -590,7 +590,7 @@ public class MeridioConnector extends or
   *@return the stream of local document identifiers that should be added to the queue.
   */
   public IDocumentIdentifierStream getDocumentIdentifiers(DocumentSpecification spec, long startTime, long endTime)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     Logging.connectors.debug("Meridio: Entering 'getDocumentIdentifiers' method");
 
@@ -632,7 +632,7 @@ public class MeridioConnector extends or
   */
   public String[] getDocumentVersions(String[] documentIdentifiers, String[] oldVersions, IVersionActivity activities,
     DocumentSpecification spec, int jobMode, boolean usesDefaultAuthority)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     Logging.connectors.debug("Meridio: Entering 'getDocumentVersions' method");
 
@@ -849,15 +849,15 @@ public class MeridioConnector extends or
           {
             elem.normalize();
             String httpErrorCode = elem.getFirstChild().getNodeValue().trim();
-            throw new LCFException("Unexpected http error code "+httpErrorCode+" accessing Meridio: "+e.getMessage(),e);
+            throw new ACFException("Unexpected http error code "+httpErrorCode+" accessing Meridio: "+e.getMessage(),e);
           }
-          throw new LCFException("Unknown http error occurred while getting doc versions: "+e.getMessage(),e);
+          throw new ACFException("Unknown http error occurred while getting doc versions: "+e.getMessage(),e);
         }
         if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server.userException")))
         {
           String exceptionName = e.getFaultString();
           if (exceptionName.equals("java.lang.InterruptedException"))
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
         }
         if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server")))
         {
@@ -876,12 +876,12 @@ public class MeridioConnector extends or
       }
       catch (RemoteException remoteException)
       {
-        throw new LCFException("Meridio: A remote exception occurred while getting doc versions: " +
+        throw new ACFException("Meridio: A remote exception occurred while getting doc versions: " +
           remoteException.getMessage(), remoteException);
       }
       catch (MeridioDataSetException meridioDataSetException)
       {
-        throw new LCFException("Meridio: A problem occurred manipulating the Web " +
+        throw new ACFException("Meridio: A problem occurred manipulating the Web " +
           "Service XML: "+meridioDataSetException.getMessage(), meridioDataSetException);
       }
     }
@@ -901,7 +901,7 @@ public class MeridioConnector extends or
   * should only find other references, and should not actually call the ingestion methods.
   */
   public void processDocuments(String[] documentIdentifiers, String[] versions, IProcessActivity activities, DocumentSpecification spec, boolean[] scanOnly)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     Logging.connectors.debug("Meridio: Entering 'processDocuments' method");
 
@@ -1396,15 +1396,15 @@ public class MeridioConnector extends or
           }
           catch (java.net.SocketTimeoutException ioex)
           {
-            throw new LCFException("Socket timeout exception: "+ioex.getMessage(), ioex);
+            throw new ACFException("Socket timeout exception: "+ioex.getMessage(), ioex);
           }
           catch (org.apache.commons.httpclient.ConnectTimeoutException ioex)
           {
-            throw new LCFException("Connect timeout exception: "+ioex.getMessage(), ioex);
+            throw new ACFException("Connect timeout exception: "+ioex.getMessage(), ioex);
           }
           catch (InterruptedIOException e)
           {
-            throw new LCFException("Interrupted: "+e.getMessage(),e,LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
           }
           catch (org.apache.axis.AxisFault e)
           {
@@ -1416,12 +1416,12 @@ public class MeridioConnector extends or
           }
           catch (SOAPException soapEx)
           {
-            throw new LCFException("SOAP Exception encountered while retrieving document content: "+soapEx.getMessage(),
+            throw new ACFException("SOAP Exception encountered while retrieving document content: "+soapEx.getMessage(),
               soapEx);
           }
           catch (IOException ioex)
           {
-            throw new LCFException("Input stream failure: "+ioex.getMessage(), ioex);
+            throw new ACFException("Input stream failure: "+ioex.getMessage(), ioex);
           }
           i++;
         }
@@ -1439,15 +1439,15 @@ public class MeridioConnector extends or
           {
             elem.normalize();
             String httpErrorCode = elem.getFirstChild().getNodeValue().trim();
-            throw new LCFException("Unexpected http error code "+httpErrorCode+" accessing Meridio: "+e.getMessage(),e);
+            throw new ACFException("Unexpected http error code "+httpErrorCode+" accessing Meridio: "+e.getMessage(),e);
           }
-          throw new LCFException("Unknown http error occurred while processing docs: "+e.getMessage(),e);
+          throw new ACFException("Unknown http error occurred while processing docs: "+e.getMessage(),e);
         }
         if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server.userException")))
         {
           String exceptionName = e.getFaultString();
           if (exceptionName.equals("java.lang.InterruptedException"))
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
         }
         if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server")))
         {
@@ -1466,12 +1466,12 @@ public class MeridioConnector extends or
       }
       catch (RemoteException remoteException)
       {
-        throw new LCFException("Meridio: A remote exception occurred while " +
+        throw new ACFException("Meridio: A remote exception occurred while " +
           "processing a Meridio document: "+remoteException.getMessage(), remoteException);
       }
       catch (MeridioDataSetException meridioDataSetException)
       {
-        throw new LCFException("Meridio: A DataSet exception occurred while  " +
+        throw new ACFException("Meridio: A DataSet exception occurred while  " +
           "processing a Meridio document", meridioDataSetException);
       }
     }
@@ -1494,7 +1494,7 @@ public class MeridioConnector extends or
   *@param tabsArray is an array of tab names.  Add to this array any tab names that are specific to the connector.
   */
   public void outputConfigurationHeader(IThreadContext threadContext, IHTTPOutput out, ConfigParams parameters, ArrayList tabsArray)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     tabsArray.add("Document Server");
     tabsArray.add("Records Server");
@@ -1637,7 +1637,7 @@ public class MeridioConnector extends or
   *@param tabName is the current tab name.
   */
   public void outputConfigurationBody(IThreadContext threadContext, IHTTPOutput out, ConfigParams parameters, String tabName)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     String dmwsServerProtocol = parameters.getParameter("DMWSServerProtocol");
     if (dmwsServerProtocol == null)
@@ -1944,7 +1944,7 @@ public class MeridioConnector extends or
   *@return null if all is well, or a string error message if there is an error that should prevent saving of the connection (and cause a redirection to an error page).
   */
   public String processConfigurationPost(IThreadContext threadContext, IPostParameters variableContext, ConfigParams parameters)
-    throws LCFException
+    throws ACFException
   {
     String dmwsServerProtocol = variableContext.getParameter("dmwsServerProtocol");
     if (dmwsServerProtocol != null)
@@ -2091,7 +2091,7 @@ public class MeridioConnector extends or
   *@param parameters are the configuration parameters, as they currently exist, for this connection being configured.
   */
   public void viewConfiguration(IThreadContext threadContext, IHTTPOutput out, ConfigParams parameters)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     out.print(
 "<table class=\"displaytable\">\n"+
@@ -2191,7 +2191,7 @@ public class MeridioConnector extends or
   *@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
   {
     tabsArray.add("Search Paths");
     tabsArray.add("Content Types");
@@ -2286,7 +2286,7 @@ public class MeridioConnector extends or
   *@param tabName is the current tab name.
   */
   public void outputSpecificationBody(IHTTPOutput out, DocumentSpecification ds, String tabName)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     int i;
     int k;
@@ -2420,7 +2420,7 @@ public class MeridioConnector extends or
 "    <td class=\"message\" colspan=\"2\">Service interruption: "+org.apache.acf.ui.util.Encoder.bodyEscape(e.getMessage())+"</td>\n"
         );
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
         e.printStackTrace();
         out.print(
@@ -2574,7 +2574,7 @@ public class MeridioConnector extends or
 "    <td class=\"message\" colspan=\"2\">Service interruption: "+org.apache.acf.ui.util.Encoder.bodyEscape(e.getMessage())+"</td>\n"
         );
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
         e.printStackTrace();
         out.print(
@@ -2856,7 +2856,7 @@ public class MeridioConnector extends or
 "    <td class=\"message\" colspan=\"4\">Service interruption: "+org.apache.acf.ui.util.Encoder.bodyEscape(e.getMessage())+"</td>\n"
         );
       }
-      catch (LCFException e)
+      catch (ACFException e)
       {
         e.printStackTrace();
         out.print(
@@ -2956,7 +2956,7 @@ public class MeridioConnector extends or
   *@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
   {
     int i;
 
@@ -3307,7 +3307,7 @@ public class MeridioConnector extends or
   *@param ds is the current document specification for this job.
   */
   public void viewSpecification(IHTTPOutput out, DocumentSpecification ds)
-    throws LCFException, IOException
+    throws ACFException, IOException
   {
     out.print(
 "<table class=\"displaytable\">\n"+
@@ -4463,7 +4463,7 @@ public class MeridioConnector extends or
       long startTime,
       long endTime
     )
-      throws LCFException,ServiceInterruption
+      throws ACFException,ServiceInterruption
     {
       Logging.connectors.debug("Meridio: Entering 'IdentifierStream' constructor");
       while (true)
@@ -4493,15 +4493,15 @@ public class MeridioConnector extends or
             {
               elem.normalize();
               String httpErrorCode = elem.getFirstChild().getNodeValue().trim();
-              throw new LCFException("Unexpected http error code "+httpErrorCode+" accessing Meridio: "+e.getMessage(),e);
+              throw new ACFException("Unexpected http error code "+httpErrorCode+" accessing Meridio: "+e.getMessage(),e);
             }
-            throw new LCFException("Unknown http error occurred while performing search: "+e.getMessage(),e);
+            throw new ACFException("Unknown http error occurred while performing search: "+e.getMessage(),e);
           }
           if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server.userException")))
           {
             String exceptionName = e.getFaultString();
             if (exceptionName.equals("java.lang.InterruptedException"))
-              throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+              throw new ACFException("Interrupted",ACFException.INTERRUPTED);
           }
           if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server")))
           {
@@ -4519,12 +4519,12 @@ public class MeridioConnector extends or
         }
         catch (RemoteException remoteException)
         {
-          throw new LCFException("Meridio: A Remote Exception occurred while " +
+          throw new ACFException("Meridio: A Remote Exception occurred while " +
             "performing a search: "+remoteException.getMessage(), remoteException);
         }
         catch (MeridioDataSetException meridioDataSetException)
         {
-          throw new LCFException("Meridio: A problem occurred manipulating the Web " +
+          throw new ACFException("Meridio: A problem occurred manipulating the Web " +
             "Service XML: "+meridioDataSetException.getMessage(), meridioDataSetException);
         }
       }
@@ -4536,7 +4536,7 @@ public class MeridioConnector extends or
     *@return the next document identifier, or null if there are no more.
     */
     public String getNextIdentifier()
-      throws LCFException, ServiceInterruption
+      throws ACFException, ServiceInterruption
     {
       Logging.connectors.debug("Meridio: Entering 'getNextIdentifier' method");
 
@@ -4572,15 +4572,15 @@ public class MeridioConnector extends or
                 {
                   elem.normalize();
                   String httpErrorCode = elem.getFirstChild().getNodeValue().trim();
-                  throw new LCFException("Unexpected http error code "+httpErrorCode+" performing search: "+e.getMessage());
+                  throw new ACFException("Unexpected http error code "+httpErrorCode+" performing search: "+e.getMessage());
                 }
-                throw new LCFException("Unknown http error occurred while performing search: "+e.getMessage(),e);
+                throw new ACFException("Unknown http error occurred while performing search: "+e.getMessage(),e);
               }
               if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server.userException")))
               {
                 String exceptionName = e.getFaultString();
                 if (exceptionName.equals("java.lang.InterruptedException"))
-                  throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+                  throw new ACFException("Interrupted",ACFException.INTERRUPTED);
               }
               if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server")))
               {
@@ -4592,7 +4592,7 @@ public class MeridioConnector extends or
                 }
               }
 
-              throw new LCFException("Meridio: Got an unknown remote exception performing search - axis fault = "+e.getFaultCode().getLocalPart()+", detail = "+e.getFaultString(),e);
+              throw new ACFException("Meridio: Got an unknown remote exception performing search - axis fault = "+e.getFaultCode().getLocalPart()+", detail = "+e.getFaultString(),e);
             }
             catch (RemoteException remoteException)
             {
@@ -4603,7 +4603,7 @@ public class MeridioConnector extends or
             }
             catch (MeridioDataSetException meridioDataSetException)
             {
-              throw new LCFException("Meridio: A problem occurred manipulating the Web " +
+              throw new ACFException("Meridio: A problem occurred manipulating the Web " +
                 "Service XML: "+meridioDataSetException.getMessage(), meridioDataSetException);
             }
           }
@@ -4630,7 +4630,7 @@ public class MeridioConnector extends or
     /** Close the stream.
     */
     public void close()
-      throws LCFException
+      throws ACFException
     {
       Logging.connectors.debug("Meridio: Entering 'IdentifierStream.close' method");
 
@@ -4656,7 +4656,7 @@ public class MeridioConnector extends or
   *@return Sorted array of strings containing the category names
   */
   public String [] getMeridioCategories ()
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     Logging.connectors.debug("Entering 'getMeridioCategories' method");
 
@@ -4706,15 +4706,15 @@ public class MeridioConnector extends or
           {
             elem.normalize();
             String httpErrorCode = elem.getFirstChild().getNodeValue().trim();
-            throw new LCFException("Unexpected http error code "+httpErrorCode+" getting categories: "+e.getMessage());
+            throw new ACFException("Unexpected http error code "+httpErrorCode+" getting categories: "+e.getMessage());
           }
-          throw new LCFException("Unknown http error occurred while getting categories: "+e.getMessage(),e);
+          throw new ACFException("Unknown http error occurred while getting categories: "+e.getMessage(),e);
         }
         if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server.userException")))
         {
           String exceptionName = e.getFaultString();
           if (exceptionName.equals("java.lang.InterruptedException"))
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
         }
         if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server")))
         {
@@ -4726,16 +4726,16 @@ public class MeridioConnector extends or
           }
         }
 
-        throw new LCFException("Meridio: Got an unknown remote exception getting categories - axis fault = "+e.getFaultCode().getLocalPart()+", detail = "+e.getFaultString(),e);
+        throw new ACFException("Meridio: Got an unknown remote exception getting categories - axis fault = "+e.getFaultCode().getLocalPart()+", detail = "+e.getFaultString(),e);
       }
       catch (RemoteException remoteException)
       {
-        throw new LCFException("Meridio: A Remote Exception occurred while " +
+        throw new ACFException("Meridio: A Remote Exception occurred while " +
           "retrieving the Meridio categories: "+remoteException.getMessage(), remoteException);
       }
       catch (MeridioDataSetException meridioDataSetException)
       {
-        throw new LCFException("Meridio: DataSet Exception occurred retrieving the Meridio categories: "+meridioDataSetException.getMessage(),
+        throw new ACFException("Meridio: DataSet Exception occurred retrieving the Meridio categories: "+meridioDataSetException.getMessage(),
           meridioDataSetException);
       }
     }
@@ -4744,7 +4744,7 @@ public class MeridioConnector extends or
 
 
   public String [] getMeridioDocumentProperties ()
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     Logging.connectors.debug("Entering 'getMeridioDocumentProperties' method");
 
@@ -4815,15 +4815,15 @@ public class MeridioConnector extends or
           {
             elem.normalize();
             String httpErrorCode = elem.getFirstChild().getNodeValue().trim();
-            throw new LCFException("Unexpected http error code "+httpErrorCode+" getting document properties: "+e.getMessage());
+            throw new ACFException("Unexpected http error code "+httpErrorCode+" getting document properties: "+e.getMessage());
           }
-          throw new LCFException("Unknown http error occurred while getting document properties: "+e.getMessage(),e);
+          throw new ACFException("Unknown http error occurred while getting document properties: "+e.getMessage(),e);
         }
         if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server.userException")))
         {
           String exceptionName = e.getFaultString();
           if (exceptionName.equals("java.lang.InterruptedException"))
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
         }
         if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server")))
         {
@@ -4835,16 +4835,16 @@ public class MeridioConnector extends or
           }
         }
 
-        throw new LCFException("Meridio: Got an unknown remote exception getting document properties - axis fault = "+e.getFaultCode().getLocalPart()+", detail = "+e.getFaultString(),e);
+        throw new ACFException("Meridio: Got an unknown remote exception getting document properties - axis fault = "+e.getFaultCode().getLocalPart()+", detail = "+e.getFaultString(),e);
       }
       catch (RemoteException remoteException)
       {
-        throw new LCFException("Meridio: A Remote Exception occurred while " +
+        throw new ACFException("Meridio: A Remote Exception occurred while " +
           "retrieving the Meridio document properties: "+remoteException.getMessage(), remoteException);
       }
       catch (MeridioDataSetException meridioDataSetException)
       {
-        throw new LCFException("Meridio: DataSet Exception occurred retrieving the Meridio document properties: "+meridioDataSetException.getMessage(),
+        throw new ACFException("Meridio: DataSet Exception occurred retrieving the Meridio document properties: "+meridioDataSetException.getMessage(),
           meridioDataSetException);
       }
     }
@@ -4856,7 +4856,7 @@ public class MeridioConnector extends or
   (
     int classOrFolderId
   )
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     Logging.connectors.debug("Entering 'getClassOrFolderContents' method");
 
@@ -4923,15 +4923,15 @@ public class MeridioConnector extends or
           {
             elem.normalize();
             String httpErrorCode = elem.getFirstChild().getNodeValue().trim();
-            throw new LCFException("Unexpected http error code "+httpErrorCode+" getting class or folder contents: "+e.getMessage());
+            throw new ACFException("Unexpected http error code "+httpErrorCode+" getting class or folder contents: "+e.getMessage());
           }
-          throw new LCFException("Unknown http error occurred while getting class or folder contents: "+e.getMessage(),e);
+          throw new ACFException("Unknown http error occurred while getting class or folder contents: "+e.getMessage(),e);
         }
         if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server.userException")))
         {
           String exceptionName = e.getFaultString();
           if (exceptionName.equals("java.lang.InterruptedException"))
-            throw new LCFException("Interrupted",LCFException.INTERRUPTED);
+            throw new ACFException("Interrupted",ACFException.INTERRUPTED);
         }
         if (e.getFaultCode().equals(new javax.xml.namespace.QName("http://schemas.xmlsoap.org/soap/envelope/","Server")))
         {
@@ -4943,16 +4943,16 @@ public class MeridioConnector extends or
           }
         }
 
-        throw new LCFException("Meridio: Got an unknown remote exception getting class or folder contents - axis fault = "+e.getFaultCode().getLocalPart()+", detail = "+e.getFaultString(),e);
+        throw new ACFException("Meridio: Got an unknown remote exception getting class or folder contents - axis fault = "+e.getFaultCode().getLocalPart()+", detail = "+e.getFaultString(),e);
       }
       catch (RemoteException remoteException)
       {
-        throw new LCFException("Meridio: A Remote Exception occurred while " +
+        throw new ACFException("Meridio: A Remote Exception occurred while " +
           "retrieving class or folder contents: "+remoteException.getMessage(), remoteException);
       }
       catch (MeridioDataSetException meridioDataSetException)
       {
-        throw new LCFException("Meridio: A problem occurred manipulating the Web " +
+        throw new ACFException("Meridio: A problem occurred manipulating the Web " +
           "Service XML: "+meridioDataSetException.getMessage(), meridioDataSetException);
       }
     }

Modified: incubator/lcf/trunk/modules/connectors/meridio/connector/org/apache/acf/crawler/connectors/meridio/meridiowrapper/MeridioWrapper.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/meridio/connector/org/apache/acf/crawler/connectors/meridio/meridiowrapper/MeridioWrapper.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/meridio/connector/org/apache/acf/crawler/connectors/meridio/meridiowrapper/MeridioWrapper.java (original)
+++ incubator/lcf/trunk/modules/connectors/meridio/connector/org/apache/acf/crawler/connectors/meridio/meridiowrapper/MeridioWrapper.java Mon Aug 23 18:08:32 2010
@@ -63,7 +63,7 @@ import org.apache.acf.crawler.connectors
 public class MeridioWrapper
 {
 
-  public static final String CONFIGURATION_PROPERTY = "LCF_Configuration";
+  public static final String CONFIGURATION_PROPERTY = "ACF_Configuration";
 
   // This is the local cache
   protected long meridioCategoriesTime                    = -1L;
@@ -145,7 +145,7 @@ public class MeridioWrapper
     Logger log,
     URL    meridioDmwsUrl,
     URL    meridioRmwsUrl,
-    URL    meridioLCFWSUrl,
+    URL    meridioACFWSUrl,
     String dmwsProxyHost,
     String dmwsProxyPort,
     String rmwsProxyHost,
@@ -234,11 +234,11 @@ public class MeridioWrapper
     /*=================================================================
     * Get a handle to the MeridioMetaCarta Web Service
     *================================================================*/
-    if (meridioLCFWSUrl != null)
+    if (meridioACFWSUrl != null)
     {
       MetaCartaLocator meridioMCWS = new MetaCartaLocator(engineConfiguration);
       Service McWsService = null;
-      MetaCartaSoapStub meridioMetaCartaWebService = new MetaCartaSoapStub(meridioLCFWSUrl, McWsService);
+      MetaCartaSoapStub meridioMetaCartaWebService = new MetaCartaSoapStub(meridioACFWSUrl, McWsService);
 
       meridioMetaCartaWebService.setPortName(meridioMCWS.getMetaCartaSoapWSDDServiceName());
       meridioMetaCartaWebService.setUsername(userName);

Modified: incubator/lcf/trunk/modules/connectors/nulloutput/connector/org/apache/acf/agents/output/nullconnector/NullConnector.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/nulloutput/connector/org/apache/acf/agents/output/nullconnector/NullConnector.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/nulloutput/connector/org/apache/acf/agents/output/nullconnector/NullConnector.java (original)
+++ incubator/lcf/trunk/modules/connectors/nulloutput/connector/org/apache/acf/agents/output/nullconnector/NullConnector.java Mon Aug 23 18:08:32 2010
@@ -73,14 +73,14 @@ public class NullConnector extends org.a
   /** Close the connection.  Call this before discarding the connection.
   */
   public void disconnect()
-    throws LCFException
+    throws ACFException
   {
     super.disconnect();
   }
 
   /** Set up a session */
   protected void getSession()
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
   }
 
@@ -88,7 +88,7 @@ public class NullConnector extends org.a
   *@return the connection's status as a displayable string.
   */
   public String check()
-    throws LCFException
+    throws ACFException
   {
     try
     {
@@ -113,7 +113,7 @@ public class NullConnector extends org.a
   * the document will not need to be sent again to the output data store.
   */
   public String getOutputDescription(OutputSpecification spec)
-    throws LCFException
+    throws ACFException
   {
     return "";
   }
@@ -133,7 +133,7 @@ public class NullConnector extends org.a
   *@return the document status (accepted or permanently rejected).
   */
   public int addOrReplaceDocument(String documentURI, String outputDescription, RepositoryDocument document, String authorityNameString, IOutputAddActivity activities)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     // Establish a session
     getSession();
@@ -149,7 +149,7 @@ public class NullConnector extends org.a
   *@param activities is the handle to an object that the implementer of an output connector may use to perform operations, such as logging processing activity.
   */
   public void removeDocument(String documentURI, String outputDescription, IOutputRemoveActivity activities)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     // Establish a session
     getSession();

Modified: incubator/lcf/trunk/modules/connectors/rss/connector/org/apache/acf/crawler/connectors/rss/DataCache.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/rss/connector/org/apache/acf/crawler/connectors/rss/DataCache.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/rss/connector/org/apache/acf/crawler/connectors/rss/DataCache.java (original)
+++ incubator/lcf/trunk/modules/connectors/rss/connector/org/apache/acf/crawler/connectors/rss/DataCache.java Mon Aug 23 18:08:32 2010
@@ -22,7 +22,7 @@ import org.apache.acf.core.interfaces.*;
 import org.apache.acf.agents.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;
 import java.util.*;
 import java.io.*;
 
@@ -50,7 +50,7 @@ public class DataCache
   *@return the checksum value.
   */
   public long addData(IVersionActivity activities, String documentIdentifier, InputStream dataStream)
-    throws LCFException, ServiceInterruption
+    throws ACFException, ServiceInterruption
   {
     // Create a temporary file; that's what we will cache
     try
@@ -63,7 +63,7 @@ public class DataCache
         // after it's removed.  So disable this and live with the occasional
         // dangling file left as a result of shutdown or error. :-(
         // tempFile.deleteOnExit();
-        LCF.addFile(tempFile);
+        ACF.addFile(tempFile);
 
         // Transfer data to temporary file
         long checkSum = 0L;
@@ -94,7 +94,7 @@ public class DataCache
             }
             catch (InterruptedIOException e)
             {
-              throw new LCFException("Interrupted: "+e.getMessage(),LCFException.INTERRUPTED);
+              throw new ACFException("Interrupted: "+e.getMessage(),ACFException.INTERRUPTED);
             }
             catch (IOException e)
             {
@@ -133,35 +133,35 @@ public class DataCache
       }
       catch (IOException e)
       {
-        LCF.deleteFile(tempFile);
+        ACF.deleteFile(tempFile);
         throw e;
       }
       catch (ServiceInterruption e)
       {
-        LCF.deleteFile(tempFile);
+        ACF.deleteFile(tempFile);
         throw e;
       }
       catch (Error e)
       {
-        LCF.deleteFile(tempFile);
+        ACF.deleteFile(tempFile);
         throw e;
       }
     }
     catch (java.net.SocketTimeoutException e)
     {
-      throw new LCFException("Socket timeout exception creating temporary file: "+e.getMessage(),e);
+      throw new ACFException("Socket timeout exception creating temporary file: "+e.getMessage(),e);
     }
     catch (org.apache.commons.httpclient.ConnectTimeoutException e)
     {
-      throw new LCFException("Socket connect timeout exception creating temporary file: "+e.getMessage(),e);
+      throw new ACFException("Socket connect timeout exception creating temporary file: "+e.getMessage(),e);
     }
     catch (InterruptedIOException e)
     {
-      throw new LCFException("Interrupted: "+e.getMessage(),LCFException.INTERRUPTED);
+      throw new ACFException("Interrupted: "+e.getMessage(),ACFException.INTERRUPTED);
     }
     catch (IOException e)
     {
-      throw new LCFException("IO exception creating temporary file: "+e.getMessage(),e);
+      throw new ACFException("IO exception creating temporary file: "+e.getMessage(),e);
     }
   }
 
@@ -170,7 +170,7 @@ public class DataCache
   *@return the length.
   */
   public synchronized long getDataLength(String documentIdentifier)
-    throws LCFException
+    throws ACFException
   {
     File f = (File)cacheData.get(documentIdentifier);
     if (f == null)
@@ -183,7 +183,7 @@ public class DataCache
   *@return a binary data stream.
   */
   public synchronized InputStream getData(String documentIdentifier)
-    throws LCFException
+    throws ACFException
   {
     File f = (File)cacheData.get(documentIdentifier);
     if (f == null)
@@ -194,7 +194,7 @@ public class DataCache
     }
     catch (IOException e)
     {
-      throw new LCFException("IO exception getting data length: "+e.getMessage(),e);
+      throw new ACFException("IO exception getting data length: "+e.getMessage(),e);
     }
   }
 
@@ -207,7 +207,7 @@ public class DataCache
     cacheData.remove(documentIdentifier);
     if (f != null)
     {
-      LCF.deleteFile(f);
+      ACF.deleteFile(f);
     }
   }
 

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

Modified: incubator/lcf/trunk/modules/connectors/rss/connector/org/apache/acf/crawler/connectors/rss/IThrottledConnection.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/rss/connector/org/apache/acf/crawler/connectors/rss/IThrottledConnection.java?rev=988237&r1=988236&r2=988237&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/rss/connector/org/apache/acf/crawler/connectors/rss/IThrottledConnection.java (original)
+++ incubator/lcf/trunk/modules/connectors/rss/connector/org/apache/acf/crawler/connectors/rss/IThrottledConnection.java Mon Aug 23 18:08:32 2010
@@ -51,7 +51,7 @@ public interface IThrottledConnection
   *        is used solely for logging purposes.
   */
   public void beginFetch(String fetchType)
-    throws LCFException;
+    throws ACFException;
 
   /** Execute the fetch and get the return code.  This method uses the
   * standard logging mechanism to keep track of the fetch attempt.  It also
@@ -69,35 +69,35 @@ public interface IThrottledConnection
   public int executeFetch(String protocol, int port, String urlPath, String userAgent, String from,
     String proxyHost, int proxyPort, String proxyAuthDomain, String proxyAuthUsername, String proxyAuthPassword,
     String lastETag, String lastModified)
-    throws LCFException, ServiceInterruption;
+    throws ACFException, ServiceInterruption;
 
   /** Get the http response code.
   *@return the response code.  This is either an HTTP response code, or one of the codes above.
   */
   public int getResponseCode()
-    throws LCFException, ServiceInterruption;
+    throws ACFException, ServiceInterruption;
 
   /** Get the response input stream.  It is the responsibility of the caller
   * to close this stream when done.
   */
   public InputStream getResponseBodyStream()
-    throws LCFException, ServiceInterruption;
+    throws ACFException, ServiceInterruption;
 
   /** Get a specified response header, if it exists.
   *@param headerName is the name of the header.
   *@return the header value, or null if it doesn't exist.
   */
   public String getResponseHeader(String headerName)
-    throws LCFException, ServiceInterruption;
+    throws ACFException, ServiceInterruption;
 
   /** Done with the fetch.  Call this when the fetch has been completed.  A log entry will be generated
   * describing what was done.
   */
   public void doneFetch(IVersionActivity activities)
-    throws LCFException;
+    throws ACFException;
 
   /** Close the connection.  Call this to end this server connection.
   */
   public void close()
-    throws LCFException;
+    throws ACFException;
 }