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 2014/10/03 09:36:02 UTC

svn commit: r1629128 - /manifoldcf/branches/CONNECTORS-1037/connectors/alfresco-webscript/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/alfrescowebscript/AlfrescoConnector.java

Author: kwright
Date: Fri Oct  3 07:36:01 2014
New Revision: 1629128

URL: http://svn.apache.org/r1629128
Log:
Bring logging and formatting into conformance

Modified:
    manifoldcf/branches/CONNECTORS-1037/connectors/alfresco-webscript/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/alfrescowebscript/AlfrescoConnector.java

Modified: manifoldcf/branches/CONNECTORS-1037/connectors/alfresco-webscript/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/alfrescowebscript/AlfrescoConnector.java
URL: http://svn.apache.org/viewvc/manifoldcf/branches/CONNECTORS-1037/connectors/alfresco-webscript/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/alfrescowebscript/AlfrescoConnector.java?rev=1629128&r1=1629127&r2=1629128&view=diff
==============================================================================
--- manifoldcf/branches/CONNECTORS-1037/connectors/alfresco-webscript/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/alfrescowebscript/AlfrescoConnector.java (original)
+++ manifoldcf/branches/CONNECTORS-1037/connectors/alfresco-webscript/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/alfrescowebscript/AlfrescoConnector.java Fri Oct  3 07:36:01 2014
@@ -40,12 +40,10 @@ import org.apache.manifoldcf.crawler.con
 import org.apache.manifoldcf.crawler.interfaces.IExistingVersions;
 import org.apache.manifoldcf.crawler.interfaces.IProcessActivity;
 import org.apache.manifoldcf.crawler.interfaces.ISeedingActivity;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
+import org.apache.manifoldcf.crawler.system.Logging;
+import java.text.MessageFormat;
 
 public class AlfrescoConnector extends BaseRepositoryConnector {
-  private static final Logger logger = LoggerFactory.getLogger(AlfrescoConnector.class);
   private static final String ACTIVITY_FETCH = "fetch document";
   private static final String[] activitiesList = new String[]{ACTIVITY_FETCH};
   private AlfrescoClient alfrescoClient;
@@ -124,15 +122,15 @@ public class AlfrescoConnector extends B
       long lastAclChangesetId = 0;
       
       if(lastSeedVersion != null && !lastSeedVersion.isEmpty()){
-    	  StringTokenizer tokenizer = new StringTokenizer(lastSeedVersion,"|");
+        StringTokenizer tokenizer = new StringTokenizer(lastSeedVersion,"|");
 
-    	  if (tokenizer.countTokens() == 2) {
-    		  lastTransactionId = new Long(tokenizer.nextToken());
-    		  lastAclChangesetId = new Long(tokenizer.nextToken());
-    	  }
+        if (tokenizer.countTokens() == 2) {
+          lastTransactionId = new Long(tokenizer.nextToken());
+          lastAclChangesetId = new Long(tokenizer.nextToken());
+        }
       }
       
-      logger.info("Starting from transaction id: {} and acl changeset id: {}", lastTransactionId, lastAclChangesetId);
+      Logging.connectors.debug(MessageFormat.format("Starting from transaction id: {0} and acl changeset id: {1}", new Object[]{lastTransactionId, lastAclChangesetId}));
       
       long transactionIdsProcessed;
       long aclChangesetsProcessed;
@@ -149,7 +147,7 @@ public class AlfrescoConnector extends B
           activities.addSeedDocument(uuid);
           count++;
         }
-        logger.info("Fetched and added {} seed documents", count);
+        Logging.connectors.debug(MessageFormat.format("Fetched and added {0} seed documents", new Object[]{new Integer(count)}));
 
         transactionIdsProcessed = response.getLastTransactionId() - lastTransactionId;
         aclChangesetsProcessed = response.getLastAclChangesetId() - lastAclChangesetId;
@@ -157,18 +155,18 @@ public class AlfrescoConnector extends B
         lastTransactionId = response.getLastTransactionId();
         lastAclChangesetId = response.getLastAclChangesetId();
 
-        logger.info("transaction_id={}, acl_changeset_id={}", lastTransactionId, lastAclChangesetId);
+        Logging.connectors.debug(MessageFormat.format("transaction_id={0}, acl_changeset_id={1}", new Object[]{lastTransactionId, lastAclChangesetId}));
       } while (transactionIdsProcessed > 0 || aclChangesetsProcessed > 0);
 
-      logger.info("Recording {} as last transaction id and {} as last changeset id", lastTransactionId, lastAclChangesetId);
+      Logging.connectors.debug(MessageFormat.format("Recording {0} as last transaction id and {1} as last changeset id", new Object[]{lastTransactionId, lastAclChangesetId}));
       return lastTransactionId + "|" + lastAclChangesetId;
     } catch (AlfrescoDownException e) {
       throw new ManifoldCFException(e);
     }
   }
 
-@Override
-public void processDocuments(String[] documentIdentifiers, IExistingVersions statuses, Specification spec,
+  @Override
+  public void processDocuments(String[] documentIdentifiers, IExistingVersions statuses, Specification spec,
                              IProcessActivity activities, int jobMode, boolean usesDefaultAuthority)
         throws ManifoldCFException, ServiceInterruption {
 
@@ -178,9 +176,9 @@ public void processDocuments(String[] do
       // Calling again Alfresco API because Document's actions are lost from seeding method
       AlfrescoResponse response = alfrescoClient.fetchNode(doc);
       if(response.getDocumentList().isEmpty()){ // Not found seeded document. Could reflect an error in Alfresco
-    	  logger.error("Invalid Seeded Document from Alfresco with ID {}", doc);
-    	  activities.noDocument(doc, nextVersion);
-    	  continue;
+        Logging.connectors.warn(MessageFormat.format("Invalid Seeded Document from Alfresco with ID {0}", new Object[]{doc}));
+        activities.noDocument(doc, nextVersion);
+        continue;
       }
       Map<String, Object> map = response.getDocumentList().get(0); // Should be only one
       RepositoryDocument rd = new RepositoryDocument();
@@ -197,24 +195,24 @@ public void processDocuments(String[] do
       } else {
         if (this.enableDocumentProcessing) {
           try{
-          	processMetaData(rd,uuid);
+            processMetaData(rd,uuid);
           }catch(AlfrescoDownException e){
-        	  logger.error("Invalid Document from Alfresco with ID {}", uuid, e);
-        	  activities.noDocument(doc, nextVersion);
-        	  continue; // No Metadata, No Content....skip document
+            Logging.connectors.warn(MessageFormat.format("Invalid Document from Alfresco with ID {0}", new Object[]{uuid}), e);
+            activities.noDocument(doc, nextVersion);
+            continue; // No Metadata, No Content....skip document
           }
         }
         try {
-        	if(rd.getBinaryStream() == null){
-        		byte[] empty = new byte[0];
-        		rd.setBinary(new ByteArrayInputStream(empty), 0L);
-        	}
-        	logger.info("Ingesting with id: {}, URI {} and rd {}", uuid, nodeRef, rd.getFileName());
-			activities.ingestDocumentWithException(uuid, "", uuid, rd);
-		} catch (IOException e) {
-			throw new ManifoldCFException(
+          if(rd.getBinaryStream() == null){
+            byte[] empty = new byte[0];
+            rd.setBinary(new ByteArrayInputStream(empty), 0L);
+          }
+          Logging.connectors.debug(MessageFormat.format("Ingesting with id: {0}, URI {1} and rd {2}", new Object[]{uuid, nodeRef, rd.getFileName()}));
+          activities.ingestDocumentWithException(uuid, "", uuid, rd);
+        } catch (IOException e) {
+          throw new ManifoldCFException(
 					"Error Ingesting Document with ID " + String.valueOf(uuid), e);
-		}
+        }
       }
     }
   }
@@ -230,16 +228,16 @@ public void processDocuments(String[] do
     // Document Binary Content
     String contentUrlPath = (String) properties.get(CONTENT_URL_PROPERTY);
     if(contentUrlPath != null && !contentUrlPath.isEmpty()){
-    	InputStream binaryContent = alfrescoClient.fetchContent(contentUrlPath);
-    	if(binaryContent != null) // Content-based Alfresco Document
-    		rd.setBinary(binaryContent, 0L);
+      InputStream binaryContent = alfrescoClient.fetchContent(contentUrlPath);
+      if(binaryContent != null) // Content-based Alfresco Document
+        rd.setBinary(binaryContent, 0L);
     }
     
     // Indexing Permissions
     @SuppressWarnings("unchecked")
-	List<String> permissions = (List<String>) properties.remove(AUTHORITIES_PROPERTY);
+    List<String> permissions = (List<String>) properties.remove(AUTHORITIES_PROPERTY);
     if(permissions != null){
-    	rd.setSecurityACL(RepositoryDocument.SECURITY_TYPE_DOCUMENT,
+      rd.setSecurityACL(RepositoryDocument.SECURITY_TYPE_DOCUMENT,
     		permissions.toArray(new String[permissions.size()]));
     }
   }
@@ -277,29 +275,29 @@ public void processDocuments(String[] do
   }
   
   
-   @Override
-   public void outputSpecificationHeader(IHTTPOutput out, Locale locale, Specification os,
-     int connectionSequenceNumber, List<String> tabsArray)
-     throws ManifoldCFException, IOException{
-	   ConfigurationHandler.outputSpecificationHeader(out, locale, os, connectionSequenceNumber, tabsArray);
-   }
+  @Override
+  public void outputSpecificationHeader(IHTTPOutput out, Locale locale, Specification os,
+    int connectionSequenceNumber, List<String> tabsArray)
+    throws ManifoldCFException, IOException{
+    ConfigurationHandler.outputSpecificationHeader(out, locale, os, connectionSequenceNumber, tabsArray);
+  }
    
-   @Override
-   public void outputSpecificationBody(IHTTPOutput out, Locale locale, Specification os,
-		    int connectionSequenceNumber, int actualSequenceNumber, String tabName) throws ManifoldCFException, IOException{
-	   ConfigurationHandler.outputSpecificationBody(out, locale, os, connectionSequenceNumber, actualSequenceNumber, tabName);
-   }
+  @Override
+  public void outputSpecificationBody(IHTTPOutput out, Locale locale, Specification os,
+    int connectionSequenceNumber, int actualSequenceNumber, String tabName) throws ManifoldCFException, IOException{
+    ConfigurationHandler.outputSpecificationBody(out, locale, os, connectionSequenceNumber, actualSequenceNumber, tabName);
+  }
    
-   @Override
-   public String processSpecificationPost(IPostParameters variableContext, Locale locale, Specification os,
+  @Override
+  public String processSpecificationPost(IPostParameters variableContext, Locale locale, Specification os,
 			  int connectionSequenceNumber) throws ManifoldCFException{
-	   return ConfigurationHandler.processSpecificationPost(variableContext, locale, os, connectionSequenceNumber);
-   }
+    return ConfigurationHandler.processSpecificationPost(variableContext, locale, os, connectionSequenceNumber);
+  }
    
-   @Override
-   public void viewSpecification(IHTTPOutput out, Locale locale, Specification os,
+  @Override
+  public void viewSpecification(IHTTPOutput out, Locale locale, Specification os,
 			  int connectionSequenceNumber) throws ManifoldCFException, IOException{
-	   ConfigurationHandler.viewSpecification(out, locale, os, connectionSequenceNumber);
-   }
+  ConfigurationHandler.viewSpecification(out, locale, os, connectionSequenceNumber);
+  }
   
 }