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/10/04 16:32:28 UTC

svn commit: r1004255 [6/24] - in /incubator/lcf/trunk: modules/connectors/activedirectory/connector/src/main/java/org/apache/manifoldcf/authorities/authorities/activedirectory/ modules/connectors/documentum/connector/src/main/java/org/apache/manifoldcf...

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

Modified: incubator/lcf/trunk/modules/connectors/nulloutput/connector/src/main/java/org/apache/manifoldcf/agents/output/nullconnector/NullConnector.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/nulloutput/connector/src/main/java/org/apache/manifoldcf/agents/output/nullconnector/NullConnector.java?rev=1004255&r1=1004254&r2=1004255&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/nulloutput/connector/src/main/java/org/apache/manifoldcf/agents/output/nullconnector/NullConnector.java (original)
+++ incubator/lcf/trunk/modules/connectors/nulloutput/connector/src/main/java/org/apache/manifoldcf/agents/output/nullconnector/NullConnector.java Mon Oct  4 14:32:19 2010
@@ -73,14 +73,14 @@ public class NullConnector extends org.a
   /** Close the connection.  Call this before discarding the connection.
   */
   public void disconnect()
-    throws ACFException
+    throws ManifoldCFException
   {
     super.disconnect();
   }
 
   /** Set up a session */
   protected void getSession()
-    throws ACFException, ServiceInterruption
+    throws ManifoldCFException, ServiceInterruption
   {
   }
 
@@ -88,7 +88,7 @@ public class NullConnector extends org.a
   *@return the connection's status as a displayable string.
   */
   public String check()
-    throws ACFException
+    throws ManifoldCFException
   {
     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 ACFException
+    throws ManifoldCFException
   {
     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 ACFException, ServiceInterruption
+    throws ManifoldCFException, 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 ACFException, ServiceInterruption
+    throws ManifoldCFException, ServiceInterruption
   {
     // Establish a session
     getSession();

Modified: incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/DataCache.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/DataCache.java?rev=1004255&r1=1004254&r2=1004255&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/DataCache.java (original)
+++ incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/DataCache.java Mon Oct  4 14:32:19 2010
@@ -22,7 +22,7 @@ import org.apache.manifoldcf.core.interf
 import org.apache.manifoldcf.agents.interfaces.*;
 import org.apache.manifoldcf.crawler.interfaces.*;
 import org.apache.manifoldcf.crawler.system.Logging;
-import org.apache.manifoldcf.crawler.system.ACF;
+import org.apache.manifoldcf.crawler.system.ManifoldCF;
 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 ACFException, ServiceInterruption
+    throws ManifoldCFException, 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();
-        ACF.addFile(tempFile);
+        ManifoldCF.addFile(tempFile);
 
         // Transfer data to temporary file
         long checkSum = 0L;
@@ -94,7 +94,7 @@ public class DataCache
             }
             catch (InterruptedIOException e)
             {
-              throw new ACFException("Interrupted: "+e.getMessage(),ACFException.INTERRUPTED);
+              throw new ManifoldCFException("Interrupted: "+e.getMessage(),ManifoldCFException.INTERRUPTED);
             }
             catch (IOException e)
             {
@@ -133,35 +133,35 @@ public class DataCache
       }
       catch (IOException e)
       {
-        ACF.deleteFile(tempFile);
+        ManifoldCF.deleteFile(tempFile);
         throw e;
       }
       catch (ServiceInterruption e)
       {
-        ACF.deleteFile(tempFile);
+        ManifoldCF.deleteFile(tempFile);
         throw e;
       }
       catch (Error e)
       {
-        ACF.deleteFile(tempFile);
+        ManifoldCF.deleteFile(tempFile);
         throw e;
       }
     }
     catch (java.net.SocketTimeoutException e)
     {
-      throw new ACFException("Socket timeout exception creating temporary file: "+e.getMessage(),e);
+      throw new ManifoldCFException("Socket timeout exception creating temporary file: "+e.getMessage(),e);
     }
     catch (org.apache.commons.httpclient.ConnectTimeoutException e)
     {
-      throw new ACFException("Socket connect timeout exception creating temporary file: "+e.getMessage(),e);
+      throw new ManifoldCFException("Socket connect timeout exception creating temporary file: "+e.getMessage(),e);
     }
     catch (InterruptedIOException e)
     {
-      throw new ACFException("Interrupted: "+e.getMessage(),ACFException.INTERRUPTED);
+      throw new ManifoldCFException("Interrupted: "+e.getMessage(),ManifoldCFException.INTERRUPTED);
     }
     catch (IOException e)
     {
-      throw new ACFException("IO exception creating temporary file: "+e.getMessage(),e);
+      throw new ManifoldCFException("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 ACFException
+    throws ManifoldCFException
   {
     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 ACFException
+    throws ManifoldCFException
   {
     File f = (File)cacheData.get(documentIdentifier);
     if (f == null)
@@ -194,7 +194,7 @@ public class DataCache
     }
     catch (IOException e)
     {
-      throw new ACFException("IO exception getting data length: "+e.getMessage(),e);
+      throw new ManifoldCFException("IO exception getting data length: "+e.getMessage(),e);
     }
   }
 
@@ -207,7 +207,7 @@ public class DataCache
     cacheData.remove(documentIdentifier);
     if (f != null)
     {
-      ACF.deleteFile(f);
+      ManifoldCF.deleteFile(f);
     }
   }
 

Modified: incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/GetSeedList.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/GetSeedList.java?rev=1004255&r1=1004254&r2=1004255&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/GetSeedList.java (original)
+++ incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/GetSeedList.java Mon Oct  4 14:32:19 2010
@@ -47,7 +47,7 @@ public class GetSeedList
 
     try
     {
-      ACF.initializeEnvironment();
+      ManifoldCF.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/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/IThrottledConnection.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/IThrottledConnection.java?rev=1004255&r1=1004254&r2=1004255&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/IThrottledConnection.java (original)
+++ incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/IThrottledConnection.java Mon Oct  4 14:32:19 2010
@@ -51,7 +51,7 @@ public interface IThrottledConnection
   *        is used solely for logging purposes.
   */
   public void beginFetch(String fetchType)
-    throws ACFException;
+    throws ManifoldCFException;
 
   /** 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 ACFException, ServiceInterruption;
+    throws ManifoldCFException, 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 ACFException, ServiceInterruption;
+    throws ManifoldCFException, ServiceInterruption;
 
   /** Get the response input stream.  It is the responsibility of the caller
   * to close this stream when done.
   */
   public InputStream getResponseBodyStream()
-    throws ACFException, ServiceInterruption;
+    throws ManifoldCFException, 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 ACFException, ServiceInterruption;
+    throws ManifoldCFException, 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 ACFException;
+    throws ManifoldCFException;
 
   /** Close the connection.  Call this to end this server connection.
   */
   public void close()
-    throws ACFException;
+    throws ManifoldCFException;
 }

Modified: incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/RSSConnector.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/RSSConnector.java?rev=1004255&r1=1004254&r2=1004255&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/RSSConnector.java (original)
+++ incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/RSSConnector.java Mon Oct  4 14:32:19 2010
@@ -22,7 +22,7 @@ import org.apache.manifoldcf.core.interf
 import org.apache.manifoldcf.agents.interfaces.*;
 import org.apache.manifoldcf.crawler.interfaces.*;
 import org.apache.manifoldcf.crawler.system.Logging;
-import org.apache.manifoldcf.crawler.system.ACF;
+import org.apache.manifoldcf.crawler.system.ManifoldCF;
 
 import org.xml.sax.Attributes;
 
@@ -163,7 +163,7 @@ public class RSSConnector extends org.ap
 
   /** Establish a session */
   protected void getSession()
-    throws ACFException
+    throws ManifoldCFException
   {
     if (!isInitialized)
     {
@@ -171,8 +171,8 @@ public class RSSConnector extends org.ap
 
       String emailAddress = params.getParameter(emailParameter);
       if (emailAddress == null)
-        throw new ACFException("Missing email address");
-      userAgent = "ApacheACFRSSFeedReader; "+((emailAddress==null)?"":emailAddress)+")";
+        throw new ManifoldCFException("Missing email address");
+      userAgent = "ApacheManifoldCFRSSFeedReader; "+((emailAddress==null)?"":emailAddress)+")";
       from = emailAddress;
 
       String robotsUsageString = params.getParameter(robotsUsageParameter);
@@ -199,7 +199,7 @@ public class RSSConnector extends org.ap
         }
         catch (NumberFormatException e)
         {
-          throw new ACFException(e.getMessage(),e);
+          throw new ManifoldCFException(e.getMessage(),e);
         }
       }
 
@@ -219,7 +219,7 @@ public class RSSConnector extends org.ap
         }
         catch (NumberFormatException e)
         {
-          throw new ACFException("Bad number: "+e.getMessage(),e);
+          throw new ManifoldCFException("Bad number: "+e.getMessage(),e);
         }
       }
 
@@ -232,7 +232,7 @@ public class RSSConnector extends org.ap
         }
         catch (NumberFormatException e)
         {
-          throw new ACFException("Bad number: "+e.getMessage(),e);
+          throw new ManifoldCFException("Bad number: "+e.getMessage(),e);
         }
       }
 
@@ -248,7 +248,7 @@ public class RSSConnector extends org.ap
         }
         catch (NumberFormatException e)
         {
-          throw new ACFException("Bad number: "+e.getMessage(),e);
+          throw new ManifoldCFException("Bad number: "+e.getMessage(),e);
         }
 
       }
@@ -315,7 +315,7 @@ public class RSSConnector extends org.ap
   * in active use.
   */
   public void poll()
-    throws ACFException
+    throws ManifoldCFException
   {
     fetcher.poll();
     robots.poll();
@@ -324,7 +324,7 @@ public class RSSConnector extends org.ap
   /** Check status of connection.
   */
   public String check()
-    throws ACFException
+    throws ManifoldCFException
   {
     getSession();
     return super.check();
@@ -333,7 +333,7 @@ public class RSSConnector extends org.ap
   /** Close the connection.  Call this before discarding the repository connector.
   */
   public void disconnect()
-    throws ACFException
+    throws ManifoldCFException
   {
     isInitialized = false;
 
@@ -407,7 +407,7 @@ public class RSSConnector extends org.ap
   */
   public void addSeedDocuments(ISeedingActivity activities, DocumentSpecification spec,
     long startTime, long endTime)
-    throws ACFException, ServiceInterruption
+    throws ManifoldCFException, ServiceInterruption
   {
     getSession();
 
@@ -433,7 +433,7 @@ public class RSSConnector extends org.ap
   *@return the canonical URL (the document identifier), or null if the url was illegal.
   */
   protected static String makeDocumentIdentifier(CanonicalizationPolicies policies, String parentIdentifier, String rawURL)
-    throws ACFException
+    throws ManifoldCFException
   {
     try
     {
@@ -532,7 +532,7 @@ public class RSSConnector extends org.ap
   /** Code to canonicalize a URL.  If URL cannot be canonicalized (and is illegal) return null.
   */
   protected static String doCanonicalization(CanonicalizationPolicy p, java.net.URI url)
-    throws ACFException, java.net.URISyntaxException
+    throws ManifoldCFException, java.net.URISyntaxException
   {
     // Note well: The java.net.URI class mistreats the query part of the URI, near as I can tell, in the following ways:
     // (1) It decodes the whole thing without regards to the argument interpretation, so the escaped ampersands etc in the arguments are converted
@@ -745,7 +745,7 @@ public class RSSConnector extends org.ap
   */
   public String[] getDocumentVersions(String[] documentIdentifiers, String[] oldVersions, IVersionActivity activities,
     DocumentSpecification spec, int jobType, boolean usesDefaultAuthority)
-    throws ACFException, ServiceInterruption
+    throws ManifoldCFException, ServiceInterruption
   {
     getSession();
 
@@ -892,19 +892,19 @@ public class RSSConnector extends org.ap
             }
             catch (UnsupportedEncodingException e)
             {
-              throw new ACFException("Unsupported encoding: "+e.getMessage(),e);
+              throw new ManifoldCFException("Unsupported encoding: "+e.getMessage(),e);
             }
             catch (java.net.SocketTimeoutException e)
             {
-              throw new ACFException("IO exception reading data from string: "+e.getMessage(),e);
+              throw new ManifoldCFException("IO exception reading data from string: "+e.getMessage(),e);
             }
             catch (InterruptedIOException e)
             {
-              throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+              throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
             }
             catch (IOException e)
             {
-              throw new ACFException("IO exception reading data from string: "+e.getMessage(),e);
+              throw new ManifoldCFException("IO exception reading data from string: "+e.getMessage(),e);
             }
           }
           else
@@ -1151,7 +1151,7 @@ public class RSSConnector extends org.ap
                     }
                     catch (InterruptedIOException e)
                     {
-                      throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+                      throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
                     }
                     catch (IOException e)
                     {
@@ -1220,7 +1220,7 @@ public class RSSConnector extends org.ap
   */
   public void processDocuments(String[] documentIdentifiers, String[] versions, IProcessActivity activities,
     DocumentSpecification spec, boolean[] scanOnly, int jobType)
-    throws ACFException, ServiceInterruption
+    throws ManifoldCFException, ServiceInterruption
   {
     getSession();
 
@@ -1462,15 +1462,15 @@ public class RSSConnector extends org.ap
               }
               catch (java.net.SocketTimeoutException e)
               {
-                throw new ACFException("IO error closing stream: "+e.getMessage(),e);
+                throw new ManifoldCFException("IO error closing stream: "+e.getMessage(),e);
               }
               catch (InterruptedIOException e)
               {
-                throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+                throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
               }
               catch (IOException e)
               {
-                throw new ACFException("IO error closing stream: "+e.getMessage(),e);
+                throw new ManifoldCFException("IO error closing stream: "+e.getMessage(),e);
               }
             }
           }
@@ -1494,7 +1494,7 @@ public class RSSConnector extends org.ap
   *@param versions is the corresponding set of version identifiers (individual identifiers may be null).
   */
   public void releaseDocumentVersions(String[] documentIdentifiers, String[] versions)
-    throws ACFException
+    throws ManifoldCFException
   {
     int i = 0;
     while (i < documentIdentifiers.length)
@@ -1526,7 +1526,7 @@ public class RSSConnector extends org.ap
   *@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 ACFException, IOException
+    throws ManifoldCFException, IOException
   {
     tabsArray.add("Email");
     tabsArray.add("Robots");
@@ -1591,7 +1591,7 @@ public class RSSConnector extends org.ap
   *@param tabName is the current tab name.
   */
   public void outputConfigurationBody(IThreadContext threadContext, IHTTPOutput out, ConfigParams parameters, String tabName)
-    throws ACFException, IOException
+    throws ManifoldCFException, IOException
   {
     String email = parameters.getParameter(org.apache.manifoldcf.crawler.connectors.rss.RSSConnector.emailParameter);
     if (email == null)
@@ -1758,7 +1758,7 @@ public class RSSConnector extends org.ap
   *@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 ACFException
+    throws ManifoldCFException
   {
     String email = variableContext.getParameter("email");
     if (email != null)
@@ -1805,7 +1805,7 @@ public class RSSConnector extends org.ap
   *@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 ACFException, IOException
+    throws ManifoldCFException, IOException
   {
     out.print(
 "<table class=\"displaytable\">\n"+
@@ -1853,7 +1853,7 @@ public class RSSConnector extends org.ap
   *@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 ACFException, IOException
+    throws ManifoldCFException, IOException
   {
     tabsArray.add("URLs");
     tabsArray.add("Canonicalization");
@@ -1972,7 +1972,7 @@ public class RSSConnector extends org.ap
   *@param tabName is the current tab name.
   */
   public void outputSpecificationBody(IHTTPOutput out, DocumentSpecification ds, String tabName)
-    throws ACFException, IOException
+    throws ManifoldCFException, IOException
   {
     int i;
     int k;
@@ -2568,7 +2568,7 @@ public class RSSConnector extends org.ap
   *@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 ACFException
+    throws ManifoldCFException
   {
     // Get the map
     String value = variableContext.getParameter("rssmapcount");
@@ -2653,7 +2653,7 @@ public class RSSConnector extends org.ap
       }
       catch (java.io.IOException e)
       {
-        throw new ACFException("IO error",e);
+        throw new ManifoldCFException("IO error",e);
       }
     }
 
@@ -2991,7 +2991,7 @@ public class RSSConnector extends org.ap
   *@param ds is the current document specification for this job.
   */
   public void viewSpecification(IHTTPOutput out, DocumentSpecification ds)
-    throws ACFException, IOException
+    throws ManifoldCFException, IOException
   {
     out.print(
 "<table class=\"displaytable\">\n"
@@ -3309,7 +3309,7 @@ public class RSSConnector extends org.ap
 
   /** Handle an RSS feed document, using SAX to limit the memory impact */
   protected void handleRSSFeedSAX(String documentIdentifier, IProcessActivity activities, Filter filter)
-    throws ACFException, ServiceInterruption
+    throws ManifoldCFException, ServiceInterruption
   {
     // The SAX model uses parsing events to control parsing, which allows me to manage memory usage much better.
     // This is essential for when a feed contains dechromed content as well as links.
@@ -3336,7 +3336,7 @@ public class RSSConnector extends org.ap
           {
             x.parse(is);
           }
-          catch (ACFException e)
+          catch (ManifoldCFException e)
           {
             // Ignore XML parsing errors.
             if (e.getMessage().indexOf("pars") >= 0)
@@ -3366,19 +3366,19 @@ public class RSSConnector extends org.ap
     }
     catch (java.net.SocketTimeoutException e)
     {
-      throw new ACFException("Socket timeout error: "+e.getMessage(),e);
+      throw new ManifoldCFException("Socket timeout error: "+e.getMessage(),e);
     }
     catch (org.apache.commons.httpclient.ConnectTimeoutException e)
     {
-      throw new ACFException("Socket connect timeout error: "+e.getMessage(),e);
+      throw new ManifoldCFException("Socket connect timeout error: "+e.getMessage(),e);
     }
     catch (InterruptedIOException e)
     {
-      throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+      throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
     }
     catch (IOException e)
     {
-      throw new ACFException("IO error: "+e.getMessage(),e);
+      throw new ManifoldCFException("IO error: "+e.getMessage(),e);
     }
 
   }
@@ -3417,7 +3417,7 @@ public class RSSConnector extends org.ap
 
     /** Check if the rescan flag was set or not, and if not, make sure it gets set properly */
     public void setDefaultRescanTimeIfNeeded()
-      throws ACFException
+      throws ManifoldCFException
     {
       if (rescanTimeSet == false)
       {
@@ -3439,7 +3439,7 @@ public class RSSConnector extends org.ap
 
     /** Handle the tag beginning to set the correct second-level parsing context */
     protected XMLContext beginTag(String namespaceURI, String localName, String qName, Attributes atts)
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       if (qName.equals("rss"))
       {
@@ -3468,7 +3468,7 @@ public class RSSConnector extends org.ap
 
     /** Handle the tag ending */
     protected void endTag()
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       XMLContext context = theStream.getContext();
       String tagName = context.getQname();
@@ -3510,7 +3510,7 @@ public class RSSConnector extends org.ap
     }
 
     protected XMLContext beginTag(String namespaceURI, String localName, String qName, Attributes atts)
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       // Handle each channel
       if (qName.equals("channel"))
@@ -3524,7 +3524,7 @@ public class RSSConnector extends org.ap
     }
 
     protected void endTag()
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       // If it's our channel tag, process global channel information
       XMLContext context = theStream.getContext();
@@ -3539,7 +3539,7 @@ public class RSSConnector extends org.ap
 
     /** Process this data */
     protected boolean process()
-      throws ACFException
+      throws ManifoldCFException
     {
       return rescanTimeSet;
     }
@@ -3567,7 +3567,7 @@ public class RSSConnector extends org.ap
     }
 
     protected XMLContext beginTag(String namespaceURI, String localName, String qName, Attributes atts)
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       // The tags we care about are "ttl" and "item", nothing else.
       if (qName.equals("ttl"))
@@ -3585,7 +3585,7 @@ public class RSSConnector extends org.ap
     }
 
     protected void endTag()
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       XMLContext theContext = theStream.getContext();
       String theTag = theContext.getQname();
@@ -3615,7 +3615,7 @@ public class RSSConnector extends org.ap
 
     /** Process this data, return true if rescan time was set */
     protected boolean process()
-      throws ACFException
+      throws ManifoldCFException
     {
       // Deal with the ttlvalue, if it was found
       // Use the ttl value as a signal for when we ought to look at this feed again.  If not present, use the default.
@@ -3673,7 +3673,7 @@ public class RSSConnector extends org.ap
     }
 
     protected XMLContext beginTag(String namespaceURI, String localName, String qName, Attributes atts)
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       // The tags we care about are "ttl" and "item", nothing else.
       if (qName.equals("link"))
@@ -3717,15 +3717,15 @@ public class RSSConnector extends org.ap
             }
             catch (java.net.SocketTimeoutException e)
             {
-              throw new ACFException("IO exception creating temp file: "+e.getMessage(),e);
+              throw new ManifoldCFException("IO exception creating temp file: "+e.getMessage(),e);
             }
             catch (InterruptedIOException e)
             {
-              throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+              throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
             }
             catch (IOException e)
             {
-              throw new ACFException("IO exception creating temp file: "+e.getMessage(),e);
+              throw new ManifoldCFException("IO exception creating temp file: "+e.getMessage(),e);
             }
           }
           break;
@@ -3739,15 +3739,15 @@ public class RSSConnector extends org.ap
             }
             catch (java.net.SocketTimeoutException e)
             {
-              throw new ACFException("IO exception creating temp file: "+e.getMessage(),e);
+              throw new ManifoldCFException("IO exception creating temp file: "+e.getMessage(),e);
             }
             catch (InterruptedIOException e)
             {
-              throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+              throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
             }
             catch (IOException e)
             {
-              throw new ACFException("IO exception creating temp file: "+e.getMessage(),e);
+              throw new ManifoldCFException("IO exception creating temp file: "+e.getMessage(),e);
             }
           }
           break;
@@ -3761,7 +3761,7 @@ public class RSSConnector extends org.ap
 
     /** Convert the individual sub-fields of the item context into their final forms */
     protected void endTag()
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       XMLContext theContext = theStream.getContext();
       String theTag = theContext.getQname();
@@ -3818,7 +3818,7 @@ public class RSSConnector extends org.ap
     }
 
     protected void tagCleanup()
-      throws ACFException
+      throws ManifoldCFException
     {
       // Delete the contents file if it is there.
       if (contentsFile != null)
@@ -3830,7 +3830,7 @@ public class RSSConnector extends org.ap
 
     /** Process the data accumulated for this item */
     public void process(String documentIdentifier, IProcessActivity activities, Filter filter)
-      throws ACFException
+      throws ManifoldCFException
     {
       if (linkField == null || linkField.length() == 0)
         linkField = guidField;
@@ -3958,7 +3958,7 @@ public class RSSConnector extends org.ap
     }
 
     protected XMLContext beginTag(String namespaceURI, String localName, String qName, Attributes atts)
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       // The tags we care about are "ttl" and "item", nothing else.
       if (qName.equals("ttl"))
@@ -3976,7 +3976,7 @@ public class RSSConnector extends org.ap
     }
 
     protected void endTag()
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       XMLContext theContext = theStream.getContext();
       String theTag = theContext.getQname();
@@ -4006,7 +4006,7 @@ public class RSSConnector extends org.ap
 
     /** Process this data */
     protected boolean process()
-      throws ACFException
+      throws ManifoldCFException
     {
       // Deal with the ttlvalue, if it was found
       // Use the ttl value as a signal for when we ought to look at this feed again.  If not present, use the default.
@@ -4062,7 +4062,7 @@ public class RSSConnector extends org.ap
     }
 
     protected XMLContext beginTag(String namespaceURI, String localName, String qName, Attributes atts)
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       // The tags we care about are "ttl" and "item", nothing else.
       if (qName.equals("link"))
@@ -4096,15 +4096,15 @@ public class RSSConnector extends org.ap
             }
             catch (java.net.SocketTimeoutException e)
             {
-              throw new ACFException("IO exception creating temp file: "+e.getMessage(),e);
+              throw new ManifoldCFException("IO exception creating temp file: "+e.getMessage(),e);
             }
             catch (InterruptedIOException e)
             {
-              throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+              throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
             }
             catch (IOException e)
             {
-              throw new ACFException("IO exception creating temp file: "+e.getMessage(),e);
+              throw new ManifoldCFException("IO exception creating temp file: "+e.getMessage(),e);
             }
           }
           break;
@@ -4118,15 +4118,15 @@ public class RSSConnector extends org.ap
             }
             catch (java.net.SocketTimeoutException e)
             {
-              throw new ACFException("IO exception creating temp file: "+e.getMessage(),e);
+              throw new ManifoldCFException("IO exception creating temp file: "+e.getMessage(),e);
             }
             catch (InterruptedIOException e)
             {
-              throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+              throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
             }
             catch (IOException e)
             {
-              throw new ACFException("IO exception creating temp file: "+e.getMessage(),e);
+              throw new ManifoldCFException("IO exception creating temp file: "+e.getMessage(),e);
             }
           }
           break;
@@ -4140,7 +4140,7 @@ public class RSSConnector extends org.ap
 
     /** Convert the individual sub-fields of the item context into their final forms */
     protected void endTag()
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       XMLContext theContext = theStream.getContext();
       String theTag = theContext.getQname();
@@ -4189,7 +4189,7 @@ public class RSSConnector extends org.ap
     }
 
     protected void tagCleanup()
-      throws ACFException
+      throws ManifoldCFException
     {
       // Delete the contents file if it is there.
       if (contentsFile != null)
@@ -4201,7 +4201,7 @@ public class RSSConnector extends org.ap
 
     /** Process the data accumulated for this item */
     public void process(String documentIdentifier, IProcessActivity activities, Filter filter)
-      throws ACFException
+      throws ManifoldCFException
     {
       if (linkField != null && linkField.length() > 0)
       {
@@ -4305,7 +4305,7 @@ public class RSSConnector extends org.ap
     }
 
     protected XMLContext beginTag(String namespaceURI, String localName, String qName, Attributes atts)
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       // The tags we care about are "ttl" and "item", nothing else.
       if (qName.equals("ttl"))
@@ -4323,7 +4323,7 @@ public class RSSConnector extends org.ap
     }
 
     protected void endTag()
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       XMLContext theContext = theStream.getContext();
       String theTag = theContext.getQname();
@@ -4353,7 +4353,7 @@ public class RSSConnector extends org.ap
 
     /** Process this data */
     protected boolean process()
-      throws ACFException
+      throws ManifoldCFException
     {
       // Deal with the ttlvalue, if it was found
       // Use the ttl value as a signal for when we ought to look at this feed again.  If not present, use the default.
@@ -4410,7 +4410,7 @@ public class RSSConnector extends org.ap
     }
 
     protected XMLContext beginTag(String namespaceURI, String localName, String qName, Attributes atts)
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       // The tags we care about are "ttl" and "item", nothing else.
       if (qName.equals("link"))
@@ -4452,15 +4452,15 @@ public class RSSConnector extends org.ap
             }
             catch (java.net.SocketTimeoutException e)
             {
-              throw new ACFException("IO exception creating temp file: "+e.getMessage(),e);
+              throw new ManifoldCFException("IO exception creating temp file: "+e.getMessage(),e);
             }
             catch (InterruptedIOException e)
             {
-              throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+              throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
             }
             catch (IOException e)
             {
-              throw new ACFException("IO exception creating temp file: "+e.getMessage(),e);
+              throw new ManifoldCFException("IO exception creating temp file: "+e.getMessage(),e);
             }
           }
           break;
@@ -4474,15 +4474,15 @@ public class RSSConnector extends org.ap
             }
             catch (java.net.SocketTimeoutException e)
             {
-              throw new ACFException("IO exception creating temp file: "+e.getMessage(),e);
+              throw new ManifoldCFException("IO exception creating temp file: "+e.getMessage(),e);
             }
             catch (InterruptedIOException e)
             {
-              throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+              throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
             }
             catch (IOException e)
             {
-              throw new ACFException("IO exception creating temp file: "+e.getMessage(),e);
+              throw new ManifoldCFException("IO exception creating temp file: "+e.getMessage(),e);
             }
           }
           break;
@@ -4496,7 +4496,7 @@ public class RSSConnector extends org.ap
 
     /** Convert the individual sub-fields of the item context into their final forms */
     protected void endTag()
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       XMLContext theContext = theStream.getContext();
       String theTag = theContext.getQname();
@@ -4541,7 +4541,7 @@ public class RSSConnector extends org.ap
     }
 
     protected void tagCleanup()
-      throws ACFException
+      throws ManifoldCFException
     {
       // Delete the contents file if it is there.
       if (contentsFile != null)
@@ -4553,7 +4553,7 @@ public class RSSConnector extends org.ap
 
     /** Process the data accumulated for this item */
     public void process(String documentIdentifier, IProcessActivity activities, Filter filter)
-      throws ACFException
+      throws ManifoldCFException
     {
       if (linkField != null && linkField.length() > 0)
       {
@@ -5024,7 +5024,7 @@ public class RSSConnector extends org.ap
   /** Code to check if data is interesting, based on response code and content type.
   */
   protected boolean isContentInteresting(IFingerprintActivity activities, String contentType)
-    throws ServiceInterruption, ACFException
+    throws ServiceInterruption, ManifoldCFException
   {
     // Look at the content type and decide if it's a kind we want.  This is defined
     // as something we think we can either ingest, or extract links from.
@@ -5287,7 +5287,7 @@ public class RSSConnector extends org.ap
     /** Get current token.
     */
     public EvaluatorToken peek()
-      throws ACFException
+      throws ManifoldCFException
     {
       if (token == null)
       {
@@ -5304,7 +5304,7 @@ public class RSSConnector extends org.ap
     }
 
     protected EvaluatorToken nextToken()
-      throws ACFException
+      throws ManifoldCFException
     {
       char x;
       // Fetch the next token
@@ -5396,7 +5396,7 @@ public class RSSConnector extends org.ap
         else if (modifier.startsWith("m"))
           style = EvaluatorToken.GROUPSTYLE_MIXED;
         else
-          throw new ACFException("Unknown style: "+modifier);
+          throw new ManifoldCFException("Unknown style: "+modifier);
       }
       return new EvaluatorToken(groupNumber,style);
     }
@@ -5502,7 +5502,7 @@ public class RSSConnector extends org.ap
     }
 
     public String map(String url)
-      throws ACFException
+      throws ManifoldCFException
     {
       // Create a matcher, and attempt to do a match
       Matcher matcher = matchPattern.matcher(url);
@@ -5550,7 +5550,7 @@ public class RSSConnector extends org.ap
             }
             break;
           default:
-            throw new ACFException("Illegal group style");
+            throw new ManifoldCFException("Illegal group style");
           }
           break;
         case EvaluatorToken.TYPE_TEXT:
@@ -5558,7 +5558,7 @@ public class RSSConnector extends org.ap
           sb.append(t.getTextValue());
           break;
         default:
-          throw new ACFException("Illegal token type");
+          throw new ManifoldCFException("Illegal token type");
         }
       }
       return sb.toString();
@@ -5596,7 +5596,7 @@ public class RSSConnector extends org.ap
     }
 
     public String map(String url)
-      throws ACFException
+      throws ManifoldCFException
     {
       if (mappings.size() == 0)
         return url;
@@ -5633,7 +5633,7 @@ public class RSSConnector extends org.ap
 
     /** Constructor. */
     public Filter(DocumentSpecification spec, boolean warnOnBadSeed)
-      throws ACFException
+      throws ManifoldCFException
     {
       // To save allocation, preallocate the seeds map assuming that it will require 1.5x the number of nodes in the spec
       int initialSize = spec.getChildCount();
@@ -5660,7 +5660,7 @@ public class RSSConnector extends org.ap
             }
             catch (java.util.regex.PatternSyntaxException e)
             {
-              throw new ACFException("Regular expression '"+match+"' is illegal: "+e.getMessage(),e);
+              throw new ManifoldCFException("Regular expression '"+match+"' is illegal: "+e.getMessage(),e);
             }
             if (map == null)
               map = "";
@@ -5738,7 +5738,7 @@ public class RSSConnector extends org.ap
           }
           catch (java.util.regex.PatternSyntaxException e)
           {
-            throw new ACFException("Canonicalization regular expression '"+urlRegexp+"' is illegal: "+e.getMessage(),e);
+            throw new ManifoldCFException("Canonicalization regular expression '"+urlRegexp+"' is illegal: "+e.getMessage(),e);
           }
         }
       }
@@ -5788,7 +5788,7 @@ public class RSSConnector extends org.ap
             }
             catch (NumberFormatException e)
             {
-              throw new ACFException("Bad number: "+e.getMessage(),e);
+              throw new ManifoldCFException("Bad number: "+e.getMessage(),e);
             }
           }
         }
@@ -5803,7 +5803,7 @@ public class RSSConnector extends org.ap
             }
             catch (NumberFormatException e)
             {
-              throw new ACFException("Bad number: "+e.getMessage(),e);
+              throw new ManifoldCFException("Bad number: "+e.getMessage(),e);
             }
           }
         }
@@ -5818,7 +5818,7 @@ public class RSSConnector extends org.ap
             }
             catch (NumberFormatException e)
             {
-              throw new ACFException("Bad number: "+e.getMessage(),e);
+              throw new ManifoldCFException("Bad number: "+e.getMessage(),e);
             }
           }
         }
@@ -5833,7 +5833,7 @@ public class RSSConnector extends org.ap
             }
             catch (NumberFormatException e)
             {
-              throw new ACFException("Bad number: "+e.getMessage(),e);
+              throw new ManifoldCFException("Bad number: "+e.getMessage(),e);
             }
           }
         }
@@ -5952,7 +5952,7 @@ public class RSSConnector extends org.ap
     * @return null if the url doesn't match or should not be ingested, or the new string if it does.
     */
     public String mapDocumentURL(String url)
-      throws ACFException
+      throws ManifoldCFException
     {
       if (seeds.get(url) != null)
         return null;

Modified: incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/Robots.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/Robots.java?rev=1004255&r1=1004254&r2=1004255&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/Robots.java (original)
+++ incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/Robots.java Mon Oct  4 14:32:19 2010
@@ -100,7 +100,7 @@ public class Robots
 
   /** Decide whether a specific robot can crawl a specific URL.
   * A ServiceInterruption exception is thrown if the fetch itself fails in a transient way.
-  * A permanent failure (such as an invalid URL) with throw a ACFException.
+  * A permanent failure (such as an invalid URL) with throw a ManifoldCFException.
   *@param userAgent is the user-agent string used by the robot.
   *@param from is the email address.
   *@param protocol is the name of the protocol (e.g. "http")
@@ -115,7 +115,7 @@ public class Robots
     long minimumMillisecondsPerFetchPerServer,
     String proxyHost, int proxyPort, String proxyAuthDomain, String proxyAuthUsername, String proxyAuthPassword,
     IVersionActivity activities, int connectionLimit)
-    throws ACFException, ServiceInterruption
+    throws ManifoldCFException, ServiceInterruption
   {
     String identifyingString = protocol + "://" + hostName;
     if (port != -1)
@@ -263,7 +263,7 @@ public class Robots
       long minimumMillisecondsPerFetchPerServer,
       String proxyHost, int proxyPort, String proxyAuthDomain, String proxyAuthUsername, String proxyAuthPassword,
       IVersionActivity activities, int connectionLimit)
-      throws ServiceInterruption, ACFException
+      throws ServiceInterruption, ManifoldCFException
     {
       synchronized (this)
       {
@@ -278,7 +278,7 @@ public class Robots
             }
             catch (InterruptedException e)
             {
-              throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+              throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
             }
             // Back around...
           }
@@ -294,7 +294,7 @@ public class Robots
               }
               catch (InterruptedException e)
               {
-                throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+                throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
               }
               // Back around...
             }
@@ -440,7 +440,7 @@ public class Robots
       long minimumMillisecondsPerFetchPerServer,
       String proxyHost, int proxyPort, String proxyAuthDomain, String proxyAuthUsername, String proxyAuthPassword,
       String hostName, IVersionActivity activities, int connectionLimit)
-      throws ServiceInterruption, ACFException
+      throws ServiceInterruption, ManifoldCFException
     {
       invalidTime = currentTime + 24L * 60L * 60L * 1000L;
 
@@ -506,7 +506,7 @@ public class Robots
       }
       catch (InterruptedIOException e)
       {
-        throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+        throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
       }
       catch (IOException e)
       {
@@ -523,7 +523,7 @@ public class Robots
     * Is NOT expected to close the stream.
     */
     protected void parseRobotsTxt(BufferedReader r, String hostName, IVersionActivity activities)
-      throws IOException, ACFException
+      throws IOException, ManifoldCFException
     {
       boolean parseCompleted = false;
       boolean robotsWasHtml = false;

Modified: incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/SetSeedList.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/SetSeedList.java?rev=1004255&r1=1004254&r2=1004255&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/SetSeedList.java (original)
+++ incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/SetSeedList.java Mon Oct  4 14:32:19 2010
@@ -47,7 +47,7 @@ public class SetSeedList
 
     try
     {
-      ACF.initializeEnvironment();
+      ManifoldCF.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/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/ThrottledFetcher.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/ThrottledFetcher.java?rev=1004255&r1=1004254&r2=1004255&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/ThrottledFetcher.java (original)
+++ incubator/lcf/trunk/modules/connectors/rss/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/rss/ThrottledFetcher.java Mon Oct  4 14:32:19 2010
@@ -22,7 +22,7 @@ import org.apache.manifoldcf.core.interf
 import org.apache.manifoldcf.agents.interfaces.*;
 import org.apache.manifoldcf.crawler.interfaces.*;
 import org.apache.manifoldcf.crawler.system.Logging;
-import org.apache.manifoldcf.crawler.system.ACF;
+import org.apache.manifoldcf.crawler.system.ManifoldCF;
 import java.util.*;
 import java.io.*;
 
@@ -84,7 +84,7 @@ public class ThrottledFetcher
 
   /** Note that we're about to need a handle (and make sure we have enough) */
   protected static void registerGlobalHandle(int maxHandles)
-    throws ACFException
+    throws ManifoldCFException
   {
     try
     {
@@ -99,7 +99,7 @@ public class ThrottledFetcher
     }
     catch (InterruptedException e)
     {
-      throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+      throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
     }
   }
 
@@ -138,7 +138,7 @@ public class ThrottledFetcher
   */
   public synchronized IThrottledConnection createConnection(String serverName, double minimumMillisecondsPerBytePerServer,
     int maxOpenConnectionsPerServer, long minimumMillisecondsPerFetchPerServer, int connectionLimit, int connectionTimeoutMilliseconds)
-    throws ACFException, ServiceInterruption
+    throws ManifoldCFException, ServiceInterruption
   {
     Server server;
     server = (Server)serverMap.get(serverName);
@@ -154,7 +154,7 @@ public class ThrottledFetcher
   /** Poll.  This method is designed to allow idle connections to be closed and freed.
   */
   public synchronized void poll()
-    throws ACFException
+    throws ManifoldCFException
   {
     // Nothing needed now; connections are released when we're done with them.
   }
@@ -311,7 +311,7 @@ public class ThrottledFetcher
     }
 
     public DataSession getSession(String url)
-      throws ACFException
+      throws ManifoldCFException
     {
       initializeParameters();
       return new DataSession(this,url);
@@ -319,7 +319,7 @@ public class ThrottledFetcher
 
     /** Atomically write resultlog record, returning data file name to use */
     public synchronized String writeResponseRecord(String url, int responseCode, ArrayList headerNames, ArrayList headerValues)
-      throws ACFException
+      throws ManifoldCFException
     {
       // Open log file
       try
@@ -356,7 +356,7 @@ public class ThrottledFetcher
       }
       catch (IOException e)
       {
-        throw new ACFException("Error recording file info: "+e.getMessage(),e);
+        throw new ManifoldCFException("Error recording file info: "+e.getMessage(),e);
       }
 
     }
@@ -392,7 +392,7 @@ public class ThrottledFetcher
     }
 
     public void endHeader()
-      throws ACFException
+      throws ManifoldCFException
     {
       documentName = dr.writeResponseRecord(url,responseCode,headerNames,headerValues);
     }
@@ -453,7 +453,7 @@ public class ThrottledFetcher
     */
     public ThrottledConnection(Server server, double minimumMillisecondsPerBytePerServer, int maxOpenConnectionsPerServer,
       long minimumMillisecondsPerFetchPerServer, int connectionTimeoutMilliseconds, int connectionLimit)
-      throws ACFException
+      throws ManifoldCFException
     {
       this.minimumMillisecondsPerBytePerServer = minimumMillisecondsPerBytePerServer;
       this.maxOpenConnectionsPerServer = maxOpenConnectionsPerServer;
@@ -474,7 +474,7 @@ public class ThrottledFetcher
     *        is used solely for logging purposes.
     */
     public void beginFetch(String fetchType)
-      throws ACFException
+      throws ManifoldCFException
     {
       this.fetchType = fetchType;
       fetchCounter = 0L;
@@ -484,7 +484,7 @@ public class ThrottledFetcher
       }
       catch (InterruptedException e)
       {
-        throw new ACFException("Interrupted",ACFException.INTERRUPTED);
+        throw new ManifoldCFException("Interrupted",ManifoldCFException.INTERRUPTED);
       }
     }
 
@@ -558,7 +558,7 @@ public class ThrottledFetcher
     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 ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
 
       StringBuffer sb = new StringBuffer(protocol);
@@ -686,7 +686,7 @@ public class ThrottledFetcher
         }
         catch (InterruptedIOException e)
         {
-          throw new ACFException("Interrupted",ACFException.INTERRUPTED);
+          throw new ManifoldCFException("Interrupted",ManifoldCFException.INTERRUPTED);
         }
         catch (org.apache.commons.httpclient.CircularRedirectException e)
         {
@@ -737,11 +737,11 @@ public class ThrottledFetcher
       {
         // Drop the current connection on the floor, so it cannot be reused.
         fetchMethod = null;
-        throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+        throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
       }
       catch (URIException e)
       {
-        throwable = new ACFException("Illegal URI: '"+myUrl+"'",e);
+        throwable = new ManifoldCFException("Illegal URI: '"+myUrl+"'",e);
         statusCode = FETCH_BAD_URI;
         if (recordEverything)
           dataSession.setResponseCode(statusCode);
@@ -749,7 +749,7 @@ public class ThrottledFetcher
       }
       catch (IllegalArgumentException e)
       {
-        throwable = new ACFException("Illegal URI: '"+myUrl+"'",e);
+        throwable = new ManifoldCFException("Illegal URI: '"+myUrl+"'",e);
         statusCode = FETCH_BAD_URI;
         if (recordEverything)
           dataSession.setResponseCode(statusCode);
@@ -757,7 +757,7 @@ public class ThrottledFetcher
       }
       catch (IllegalStateException e)
       {
-        throwable = new ACFException("Illegal state while fetching URI: '"+myUrl+"'",e);
+        throwable = new ManifoldCFException("Illegal state while fetching URI: '"+myUrl+"'",e);
         statusCode = FETCH_SEQUENCE_ERROR;
         if (recordEverything)
           dataSession.setResponseCode(statusCode);
@@ -767,7 +767,7 @@ public class ThrottledFetcher
       {
         throw e;
       }
-      catch (ACFException e)
+      catch (ManifoldCFException e)
       {
         throw e;
       }
@@ -786,7 +786,7 @@ public class ThrottledFetcher
     *@return the response code.  This is either an HTTP response code, or one of the codes above.
     */
     public int getResponseCode()
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       return statusCode;
     }
@@ -795,26 +795,26 @@ public class ThrottledFetcher
     * to close this stream when done.
     */
     public InputStream getResponseBodyStream()
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       if (fetchMethod == null)
-        throw new ACFException("Attempt to get a response when there is no method");
+        throw new ManifoldCFException("Attempt to get a response when there is no method");
       try
       {
         if (recordEverything)
           dataSession.endHeader();
         InputStream bodyStream = fetchMethod.getResponseBodyAsStream();
         if (bodyStream == null)
-          throw new ACFException("Failed to set up body response stream");
+          throw new ManifoldCFException("Failed to set up body response stream");
         return new ThrottledInputstream(this,server,bodyStream,minimumMillisecondsPerBytePerServer,dataSession);
       }
       catch (IOException e)
       {
-        throw new ACFException("IO exception setting up response stream",e);
+        throw new ManifoldCFException("IO exception setting up response stream",e);
       }
       catch (IllegalStateException e)
       {
-        throw new ACFException("State error getting response body",e);
+        throw new ManifoldCFException("State error getting response body",e);
       }
     }
 
@@ -823,7 +823,7 @@ public class ThrottledFetcher
     *@return the header value, or null if it doesn't exist.
     */
     public String getResponseHeader(String headerName)
-      throws ACFException, ServiceInterruption
+      throws ManifoldCFException, ServiceInterruption
     {
       Header h = fetchMethod.getResponseHeader(headerName);
       if (h == null)
@@ -837,7 +837,7 @@ public class ThrottledFetcher
     * describing what was done.
     */
     public void doneFetch(IVersionActivity activities)
-      throws ACFException
+      throws ManifoldCFException
     {
       if (fetchType != null)
       {
@@ -878,7 +878,7 @@ public class ThrottledFetcher
     /** Close the connection.  Call this to end this server connection.
     */
     public void close()
-      throws ACFException
+      throws ManifoldCFException
     {
       // Clean up the connection pool.  This should do the necessary bookkeeping to release the one connection that's sitting there.
       connectionManager.shutdown();
@@ -1137,7 +1137,7 @@ public class ThrottledFetcher
 
     /** Register an outstanding connection (and wait until it can be obtained before proceeding) */
     public synchronized void registerConnection(int maxOutstandingConnections)
-      throws ACFException
+      throws ManifoldCFException
     {
       try
       {
@@ -1149,7 +1149,7 @@ public class ThrottledFetcher
       }
       catch (InterruptedException e)
       {
-        throw new ACFException("Interrupted: "+e.getMessage(),e,ACFException.INTERRUPTED);
+        throw new ManifoldCFException("Interrupted: "+e.getMessage(),e,ManifoldCFException.INTERRUPTED);
       }
     }
 
@@ -1190,7 +1190,7 @@ public class ThrottledFetcher
         if (Logging.connectors.isDebugEnabled())
           Logging.connectors.debug("RSS: Performing a fetch wait for server '"+serverName+"' for "+
           new Long(waitAmount).toString()+" ms.");
-        ACF.sleep(waitAmount);
+        ManifoldCF.sleep(waitAmount);
       }
 
       // System.out.println("For server "+this.toString()+", at "+new Long(System.currentTimeMillis()).toString()+", the next fetch time is now "+new Long(nextFetchTime).toString());
@@ -1284,7 +1284,7 @@ public class ThrottledFetcher
         if (Logging.connectors.isDebugEnabled())
           Logging.connectors.debug("RSS: Performing a read wait on server '"+serverName+"' of "+
           new Long(waitTime).toString()+" ms.");
-        ACF.sleep(waitTime);
+        ManifoldCF.sleep(waitTime);
       }
 
       //if (Logging.connectors.isTraceEnabled())

Modified: incubator/lcf/trunk/modules/connectors/sharepoint/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/sharepoint/MatchMap.java
URL: http://svn.apache.org/viewvc/incubator/lcf/trunk/modules/connectors/sharepoint/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/sharepoint/MatchMap.java?rev=1004255&r1=1004254&r2=1004255&view=diff
==============================================================================
--- incubator/lcf/trunk/modules/connectors/sharepoint/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/sharepoint/MatchMap.java (original)
+++ incubator/lcf/trunk/modules/connectors/sharepoint/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/sharepoint/MatchMap.java Mon Oct  4 14:32:19 2010
@@ -261,7 +261,7 @@ public class MatchMap
   /** Perform a translation.
   */
   public String translate(String input)
-    throws ACFException
+    throws ManifoldCFException
   {
     // Build pattern vector if not already there
     if (matchPatterns == null)
@@ -278,7 +278,7 @@ public class MatchMap
         catch (java.util.regex.PatternSyntaxException e)
         {
           matchPatterns = null;
-          throw new ACFException("For match expression '"+regexp+"', found pattern syntax error: "+e.getMessage(),e);
+          throw new ManifoldCFException("For match expression '"+regexp+"', found pattern syntax error: "+e.getMessage(),e);
         }
         i++;
       }