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 2016/11/23 07:28:32 UTC

svn commit: r1770925 [2/3] - in /manifoldcf/branches/CONNECTORS-1290/connectors/nuxeo/connector/src: main/java/org/apache/manifoldcf/authorities/authorities/nuxeo/ main/java/org/apache/manifoldcf/crawler/connectors/nuxeo/ main/java/org/apache/manifoldc...

Modified: manifoldcf/branches/CONNECTORS-1290/connectors/nuxeo/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/nuxeo/NuxeoRepositoryConnector.java
URL: http://svn.apache.org/viewvc/manifoldcf/branches/CONNECTORS-1290/connectors/nuxeo/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/nuxeo/NuxeoRepositoryConnector.java?rev=1770925&r1=1770924&r2=1770925&view=diff
==============================================================================
--- manifoldcf/branches/CONNECTORS-1290/connectors/nuxeo/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/nuxeo/NuxeoRepositoryConnector.java (original)
+++ manifoldcf/branches/CONNECTORS-1290/connectors/nuxeo/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/nuxeo/NuxeoRepositoryConnector.java Wed Nov 23 07:28:32 2016
@@ -1,3 +1,21 @@
+/* $Id: DefaultAuthenticator.java 1688076 2015-06-28 23:04:30Z kwright $ */
+
+/**
+* Licensed to the Apache Software Foundation (ASF) under one or more
+* contributor license agreements. See the NOTICE file distributed with
+* this work for additional information regarding copyright ownership.
+* The ASF licenses this file to You under the Apache License, Version 2.0
+* (the "License"); you may not use this file except in compliance with
+* the License. You may obtain a copy of the License at
+*
+* http://www.apache.org/licenses/LICENSE-2.0
+*
+* Unless required by applicable law or agreed to in writing, software
+* distributed under the License is distributed on an "AS IS" BASIS,
+* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+* See the License for the specific language governing permissions and
+* limitations under the License.
+*/
 package org.apache.manifoldcf.crawler.connectors.nuxeo;
 
 import java.io.IOException;
@@ -49,789 +67,789 @@ import com.google.common.collect.Maps;
  */
 public class NuxeoRepositoryConnector extends BaseRepositoryConnector {
 
-	protected final static String ACTIVITY_READ = "read document";
+  protected final static String ACTIVITY_READ = "read document";
 
-	// Configuration tabs
-	private static final String NUXEO_SERVER_TAB_PROPERTY = "NuxeoRepositoryConnector.Server";
+  // Configuration tabs
+  private static final String NUXEO_SERVER_TAB_PROPERTY = "NuxeoRepositoryConnector.Server";
 
-	// Specification tabs
-	private static final String CONF_DOMAINS_TAB_PROPERTY = "NuxeoRepositoryConnector.Domains";
-	private static final String CONF_DOCUMENTS_TYPE_TAB_PROPERTY = "NuxeoRepositoryConnector.DocumentsType";
-	private static final String CONF_DOCUMENT_PROPERTY = "NuxeoRepositoryConnector.Documents";
-
-	// Prefix for nuxeo configuration and specification parameters
-	private static final String PARAMETER_PREFIX = "nuxeo_";
-
-	// Templates for Nuxeo configuration
-	/**
-	 * Javascript to check the configuration parameters
-	 */
-	private static final String EDIT_CONFIG_HEADER_FORWARD = "editConfiguration_conf.js";
-
-	/**
-	 * Server edit tab template
-	 */
-	private static final String EDIT_CONFIG_FORWARD_SERVER = "editConfiguration_conf_server.html";
-
-	/**
-	 * Server view tab template
-	 */
-	private static final String VIEW_CONFIG_FORWARD = "viewConfiguration_conf.html";
-
-	// Templates for Nuxeo specification
-	/**
-	 * Forward to the javascript to check the specification parameters for the
-	 * job
-	 */
-	private static final String EDIT_SPEC_HEADER_FORWARD = "editSpecification_conf.js";
-
-	/**
-	 * Forward to the template to edit domains for the job
-	 */
-	private static final String EDIT_SPEC_FORWARD_CONF_DOMAINS = "editSpecification_confDomains.html";
-
-	/**
-	 * Forward to the template to edit documents type for the job
-	 */
-	private static final String EDIT_SPEC_FORWARD_CONF_DOCUMENTS_TYPE = "editSpecification_confDocumentsType.html";
-
-	/**
-	 * Forward to the template to edit document properties for the job
-	 */
-	private static final String EDIT_SPEC_FORWARD_CONF_DOCUMENTS = "editSpecification_confDocuments.html";
-
-	/**
-	 * Forward to the template to view the specification parameters for the job
-	 */
-	private static final String VIEW_SPEC_FORWARD = "viewSpecification_conf.html";
-
-	protected long lastSessionFetch = -1L;
-	protected static final long timeToRelease = 300000L;
-
-	private Logger logger = LoggerFactory.getLogger(NuxeoRepositoryConnector.class);
-
-	/* Nuxeo instance parameters */
-	protected String protocol = null;
-	protected String host = null;
-	protected String port = null;
-	protected String path = null;
-	protected String username = null;
-	protected String password = null;
-
-	protected NuxeoClient nuxeoClient = null;
-
-	// Constructor
-	public NuxeoRepositoryConnector() {
-		super();
-	}
-
-	public void setNuxeoClient(NuxeoClient nuxeoClient) {
-		this.nuxeoClient = nuxeoClient;
-	}
-
-	@Override
-	public String[] getActivitiesList() {
-		return new String[] { ACTIVITY_READ };
-	}
-
-	@Override
-	public String[] getBinNames(String documentIdenfitier) {
-		return new String[] { host };
-	}
-
-	/** CONFIGURATION CONNECTOR **/
-	@Override
-	public void outputConfigurationHeader(IThreadContext threadContext, IHTTPOutput out, Locale locale,
-			ConfigParams parameters, List<String> tabsArray) throws ManifoldCFException, IOException {
-
-		// Server tab
-		tabsArray.add(Messages.getString(locale, NUXEO_SERVER_TAB_PROPERTY));
-
-		Map<String, String> paramMap = new HashMap<String, String>();
-
-		// Fill in the parameters form each tab
-		fillInServerConfigurationMap(paramMap, out, parameters);
-
-		Messages.outputResourceWithVelocity(out, locale, EDIT_CONFIG_HEADER_FORWARD, paramMap, true);
-	}
-
-	@Override
-	public void outputConfigurationBody(IThreadContext threadContext, IHTTPOutput out, Locale locale,
-			ConfigParams parameters, String tabName) throws ManifoldCFException, IOException {
-
-		// Call the Velocity tempaltes for each tab
-		Map<String, String> paramMap = new HashMap<String, String>();
-
-		// Set the tab name
-		paramMap.put("TabName", tabName);
-
-		// Fill in the parameters
-		fillInServerConfigurationMap(paramMap, out, parameters);
-
-		// Server tab
-		Messages.outputResourceWithVelocity(out, locale, EDIT_CONFIG_FORWARD_SERVER, paramMap, true);
-
-	}
-
-	private static void fillInServerConfigurationMap(Map<String, String> serverMap, IPasswordMapperActivity mapper,
-			ConfigParams parameters) {
-
-		String nuxeoProtocol = parameters.getParameter(NuxeoConfiguration.Server.PROTOCOL);
-		String nuxeoHost = parameters.getParameter(NuxeoConfiguration.Server.HOST);
-		String nuxeoPort = parameters.getParameter(NuxeoConfiguration.Server.PORT);
-		String nuxeoPath = parameters.getParameter(NuxeoConfiguration.Server.PATH);
-		String nuxeoUsername = parameters.getParameter(NuxeoConfiguration.Server.USERNAME);
-		String nuxeoPassword = parameters.getParameter(NuxeoConfiguration.Server.PASSWORD);
-
-		if (nuxeoProtocol == null)
-			nuxeoProtocol = NuxeoConfiguration.Server.PROTOCOL_DEFAULT_VALUE;
-		if (nuxeoHost == null)
-			nuxeoHost = NuxeoConfiguration.Server.HOST_DEFAULT_VALUE;
-		if (nuxeoPort == null)
-			nuxeoPort = NuxeoConfiguration.Server.PORT_DEFAULT_VALUE;
-		if (nuxeoPath == null)
-			nuxeoPath = NuxeoConfiguration.Server.PATH_DEFAULT_VALUE;
-		if (nuxeoUsername == null)
-			nuxeoUsername = NuxeoConfiguration.Server.USERNAME_DEFAULT_VALUE;
-		if (nuxeoPassword == null)
-			nuxeoPassword = NuxeoConfiguration.Server.PASSWORD_DEFAULT_VALUE;
-		else
-			nuxeoPassword = mapper.mapKeyToPassword(nuxeoPassword);
-
-		serverMap.put(PARAMETER_PREFIX + NuxeoConfiguration.Server.PROTOCOL, nuxeoProtocol);
-		serverMap.put(PARAMETER_PREFIX + NuxeoConfiguration.Server.HOST, nuxeoHost);
-		serverMap.put(PARAMETER_PREFIX + NuxeoConfiguration.Server.PORT, nuxeoPort);
-		serverMap.put(PARAMETER_PREFIX + NuxeoConfiguration.Server.PATH, nuxeoPath);
-		serverMap.put(PARAMETER_PREFIX + NuxeoConfiguration.Server.USERNAME, nuxeoUsername);
-		serverMap.put(PARAMETER_PREFIX + NuxeoConfiguration.Server.PASSWORD, nuxeoPassword);
-
-	}
-
-	@Override
-	public String processConfigurationPost(IThreadContext thredContext, IPostParameters variableContext,
-			ConfigParams parameters) {
-
-		String nuxeoProtocol = variableContext.getParameter(PARAMETER_PREFIX + NuxeoConfiguration.Server.PROTOCOL);
-		if (nuxeoProtocol != null)
-			parameters.setParameter(NuxeoConfiguration.Server.PROTOCOL, nuxeoProtocol);
-
-		String nuxeoHost = variableContext.getParameter(PARAMETER_PREFIX + NuxeoConfiguration.Server.HOST);
-		if (nuxeoHost != null)
-			parameters.setParameter(NuxeoConfiguration.Server.HOST, nuxeoHost);
-
-		String nuxeoPort = variableContext.getParameter(PARAMETER_PREFIX + NuxeoConfiguration.Server.PORT);
-		if (nuxeoPort != null)
-			parameters.setParameter(NuxeoConfiguration.Server.PORT, nuxeoPort);
-
-		String nuxeoPath = variableContext.getParameter(PARAMETER_PREFIX + NuxeoConfiguration.Server.PATH);
-		if (nuxeoPath != null)
-			parameters.setParameter(NuxeoConfiguration.Server.PATH, nuxeoPath);
-
-		String nuxeoUsername = variableContext.getParameter(PARAMETER_PREFIX + NuxeoConfiguration.Server.USERNAME);
-		if (nuxeoUsername != null)
-			parameters.setParameter(NuxeoConfiguration.Server.USERNAME, nuxeoUsername);
-
-		String nuxeoPassword = variableContext.getParameter(PARAMETER_PREFIX + NuxeoConfiguration.Server.PASSWORD);
-		if (nuxeoPassword != null)
-			parameters.setObfuscatedParameter(NuxeoConfiguration.Server.PASSWORD,
-					variableContext.mapKeyToPassword(nuxeoPassword));
-
-		return null;
-	}
-
-	@Override
-	public void viewConfiguration(IThreadContext threadContext, IHTTPOutput out, Locale locale, ConfigParams parameters)
-			throws ManifoldCFException, IOException {
-
-		Map<String, String> paramMap = new HashMap<String, String>();
-
-		fillInServerConfigurationMap(paramMap, out, parameters);
-
-		Messages.outputResourceWithVelocity(out, locale, VIEW_CONFIG_FORWARD, paramMap, true);
-	}
-
-	/** CONNECTION **/
-	@Override
-	public void connect(ConfigParams configParams) {
-		super.connect(configParams);
-
-		protocol = params.getParameter(NuxeoConfiguration.Server.PROTOCOL);
-		host = params.getParameter(NuxeoConfiguration.Server.HOST);
-		port = params.getParameter(NuxeoConfiguration.Server.PORT);
-		path = params.getParameter(NuxeoConfiguration.Server.PATH);
-		username = params.getParameter(NuxeoConfiguration.Server.USERNAME);
-		password = params.getObfuscatedParameter(NuxeoConfiguration.Server.PASSWORD);
-
-		try {
-			initNuxeoClient();
-		} catch (ManifoldCFException manifoldCFException) {
-			logger.debug("Not possible to initialize Nuxeo client. Reason: {}", manifoldCFException.getMessage());
-			manifoldCFException.printStackTrace();
-		}
-	}
-
-	// Check the connection
-	@Override
-	public String check() throws ManifoldCFException {
-		try {
-			if (!isConnected()) {
-				initNuxeoClient();
-			}
-
-			Boolean result = nuxeoClient.check();
-
-			if (result)
-				return super.check();
-			else
-				throw new ManifoldCFException("Nuxeo instance could not be reached");
-
-		} catch (ServiceInterruption serviceInterruption) {
-			return "Connection temporarily failed: " + serviceInterruption.getMessage();
-		} catch (ManifoldCFException manifoldCFException) {
-			return "Connection failed: " + manifoldCFException.getMessage();
-		} catch (Exception e) {
-			return "Connection failed: " + e.getMessage();
-		}
-	}
-
-	/**
-	 * Initialize Nuxeo client using the configured parameters.
-	 * 
-	 * @throws ManifoldCFException
-	 */
-	private void initNuxeoClient() throws ManifoldCFException {
-		int portInt;
-
-		if (nuxeoClient == null) {
-
-			if (StringUtils.isEmpty(protocol)) {
-				throw new ManifoldCFException(
-						"Parameter " + NuxeoConfiguration.Server.PROTOCOL + " required but not set");
-			}
-
-			if (StringUtils.isEmpty(host)) {
-				throw new ManifoldCFException("Parameter " + NuxeoConfiguration.Server.HOST + " required but not set");
-			}
-
-			if (port != null && port.length() > 0) {
-				try {
-					portInt = Integer.parseInt(port);
-				} catch (NumberFormatException formatException) {
-					throw new ManifoldCFException("Bad number: " + formatException.getMessage(), formatException);
-				}
-			} else {
-				if (protocol.toLowerCase(Locale.ROOT).equals("http")) {
-					portInt = 80;
-				} else {
-					portInt = 443;
-				}
-			}
-
-			nuxeoClient = new NuxeoClient(protocol, host, portInt, path, username, password);
-
-			lastSessionFetch = System.currentTimeMillis();
-
-		}
-
-	}
-
-	@Override
-	public boolean isConnected() {
-		return nuxeoClient != null;
-	}
-
-	@Override
-	public void poll() throws ManifoldCFException {
-		if (lastSessionFetch == -1L) {
-			return;
-		}
-
-		long currentTime = System.currentTimeMillis();
-
-		if (currentTime > lastSessionFetch + timeToRelease) {
-			nuxeoClient.close();
-			nuxeoClient = null;
-			lastSessionFetch = -1;
-		}
-	}
-
-	/** SEEDING **/
-	@Override
-	public String addSeedDocuments(ISeedingActivity activities, Specification spec, String lastSeedVersion,
-			long seedTime, int jobMode) throws ManifoldCFException, ServiceInterruption {
-
-		if (!isConnected())
-			initNuxeoClient();
-
-		try {
-
-			int lastStart = 0;
-			int defaultSize = 50;
-			Boolean isLast = true;
-			NuxeoSpecification ns = NuxeoSpecification.from(spec);
-			List<String> domains = ns.getDomains();
-			List<String> documentsType = ns.getDocumentsType();
-
-			do {
-				final NuxeoResponse<Document> response = nuxeoClient.getDocuments(domains, documentsType,
-						lastSeedVersion, lastStart, defaultSize, isLast);
-
-				for (Document doc : response.getResults()) {
-					activities.addSeedDocument(doc.getUid());
-				}
-
-				lastStart++;
-				isLast = response.isLast();
-
-			} while (!isLast);
-
-			SimpleDateFormat sdf = new SimpleDateFormat("yyyy-MM-dd'T'HH:mm:ss'Z'");
-			sdf.setTimeZone(TimeZone.getTimeZone("GMT"));
-
-			lastSeedVersion = sdf.format(new Date());
-
-			return lastSeedVersion;
-		} catch (Exception exception) {
-			long interruptionRetryTime = 5L * 60L * 1000L;
-			String message = "Server appears down during seeding: " + exception.getMessage();
-			throw new ServiceInterruption(message, exception, System.currentTimeMillis() + interruptionRetryTime, -1L,
-					3, true);
-		}
-	}
-
-	/** PROCESS DOCUMENTS **/
-	@Override
-	public void processDocuments(String[] documentsIdentifieres, IExistingVersions statuses, Specification spec,
-			IProcessActivity activities, int jobMode, boolean usesDefaultAuthority)
-			throws ManifoldCFException, ServiceInterruption {
-
-		for (int i = 0; i < documentsIdentifieres.length; i++) {
-
-			String documentId = documentsIdentifieres[i];
-			String version = statuses.getIndexedVersionString(documentId);
-
-			long startTime = System.currentTimeMillis();
-			ProcessResult pResult = null;
-			boolean doLog = true;
-
-			try {
-
-				if (!isConnected()) {
-					initNuxeoClient();
-				}
-
-				pResult = processDocument(documentId, spec, version, activities, doLog,
-						Maps.<String, String> newHashMap());
-			} catch (Exception exception) {
-				long interruptionRetryTime = 5L * 60L * 1000L;
-				String message = "Server appears down during seeding: " + exception.getMessage();
-				throw new ServiceInterruption(message, exception, System.currentTimeMillis() + interruptionRetryTime,
-						-1L, 3, true);
-			} finally {
-				if (doLog)
-					if (pResult != null && pResult.errorCode != null && !pResult.errorCode.isEmpty())
-						activities.recordActivity(new Long(startTime), ACTIVITY_READ, pResult.fileSize, documentId,
-								pResult.errorCode, pResult.errorDecription, null);
-			}
-
-		}
-	}
-
-	/**
-	 * @param documentId
-	 * @param version
-	 * @param activities
-	 * @param doLog
-	 * @param newHashMap
-	 * @return
-	 */
-	private ProcessResult processDocument(String documentId, Specification spec, String version,
-			IProcessActivity activities, boolean doLog, HashMap<String, String> extraProperties)
-			throws ManifoldCFException, ServiceInterruption, IOException {
-
-		Document doc = nuxeoClient.getDocument(documentId);
-
-		return processDocumentInternal(doc, documentId, spec, version, activities, doLog, extraProperties);
-	}
-
-	/**
-	 * @param doc
-	 * @param documentId
-	 * @param version
-	 * @param activities
-	 * @param doLog
-	 * @param extraProperties
-	 * @return
-	 */
-	private ProcessResult processDocumentInternal(Document doc, String manifoldDocumentIdentifier, Specification spec,
-			String version, IProcessActivity activities, boolean doLog, HashMap<String, String> extraProperties)
-			throws ManifoldCFException, ServiceInterruption, IOException {
-
-		RepositoryDocument rd = new RepositoryDocument();
-		NuxeoSpecification ns = NuxeoSpecification.from(spec);
-
-		Date lastModified = doc.getLastModified();
-
-		DateFormat df = DateFormat.getDateTimeInstance();
-
-		String lastVersion = null;
-
-		if (lastModified != null)
-			lastVersion = df.format(lastModified);
-
-		if (doc.getState() != null && doc.getState().equalsIgnoreCase(Document.DELETED)) {
-			activities.deleteDocument(manifoldDocumentIdentifier);
-			return new ProcessResult(doc.getLenght(), "DELETED", "");
-		}
-
-		if (!activities.checkDocumentNeedsReindexing(manifoldDocumentIdentifier, lastVersion)) {
-			return new ProcessResult(doc.getLenght(), "RETAINED", "");
-		}
-
-		if (doc.getUid() == null) {
-			activities.deleteDocument(manifoldDocumentIdentifier);
-			return new ProcessResult(doc.getLenght(), "DELETED", "");
-		}
-
-		// Add respository document information
-		rd.setMimeType(doc.getMediatype());
-		if (lastModified != null)
-			rd.setModifiedDate(lastModified);
-		rd.setIndexingDate(new Date());
-
-		// Adding Document Metadata
-		Map<String, Object> docMetadata = doc.getMetadataAsMap();
-
-		for (Entry<String, Object> entry : docMetadata.entrySet()) {
-			if (entry.getValue() instanceof List) {
-				List<?> list = (List<?>) entry.getValue();
-				rd.addField(entry.getKey(), list.toArray(new String[list.size()]));
-			} else {
-				rd.addField(entry.getKey(), entry.getValue().toString());
-			}
-
-		}
-
-		if (ns.isProcessTags())
-			rd.addField("Tags", getTagsFromDocument(doc));
-
-		String documentUri = nuxeoClient.getPathDocument(doc.getUid());
-
-		// Set repository ACLs
-		String[] permissions = getPermissionDocument(doc);
-		rd.setSecurityACL(RepositoryDocument.SECURITY_TYPE_DOCUMENT, permissions);
-		rd.setSecurityDenyACL(RepositoryDocument.SECURITY_TYPE_DOCUMENT, new String[] { GLOBAL_DENY_TOKEN });
-		rd.setBinary(doc.getContentStream(), doc.getLenght());
-
-		// Action
-		activities.ingestDocumentWithException(manifoldDocumentIdentifier, lastVersion, documentUri, rd);
-
-		if (ns.isProcessAttachments())
-			for (Attachment att : doc.getAttachments()) {
-				RepositoryDocument att_rd = new RepositoryDocument();
-				String attDocumentUri = nuxeoClient.getPathDocument(doc.getUid()) + "_" + att.getName();
-
-				att_rd.setMimeType(att.getMime_type());
-				att_rd.setBinary(doc.getContentStream(), att.getLength());
-
-				if (lastModified != null)
-					att_rd.setModifiedDate(lastModified);
-				att_rd.setIndexingDate(new Date());
-
-				att_rd.addField(Attachment.ATT_KEY_NAME, att.getName());
-				att_rd.addField(Attachment.ATT_KEY_LENGTH, String.valueOf(att.getLength()));
-				att_rd.addField(Attachment.ATT_KEY_URL, att.getUrl());
-
-				// Set repository ACLs
-				att_rd.setSecurityACL(RepositoryDocument.SECURITY_TYPE_DOCUMENT, permissions);
-				att_rd.setSecurityDenyACL(RepositoryDocument.SECURITY_TYPE_DOCUMENT,
-						new String[] { GLOBAL_DENY_TOKEN });
-
-				activities.ingestDocumentWithException(manifoldDocumentIdentifier, attDocumentUri, lastVersion,
-						attDocumentUri, att_rd);
-			}
-
-		return new ProcessResult(doc.getLenght(), "OK", StringUtils.EMPTY);
-	}
-
-	public String[] getPermissionDocument(Document doc) {
-
-		List<String> permissions = new ArrayList<String>();
-		try {
-			Acl acl = nuxeoClient.getAcl(doc.getUid());
-
-			for (Ace ace : acl.getAces()) {
-				if (ace.getStatus().equalsIgnoreCase("effective") && ace.isGranted()) {
-					permissions.add(ace.getName());
-				}
-			}
-
-			return permissions.toArray(new String[0]);
-
-		} catch (Exception e) {
-			return new String[] {};
-		}
-	}
-
-	public String[] getTagsFromDocument(Document doc) {
-		try {
-			return nuxeoClient.getTags(doc.getUid());
-		} catch (Exception e) {
-			return new String[] {};
-		}
-	}
-
-	private class ProcessResult {
-		private long fileSize;
-		private String errorCode;
-		private String errorDecription;
-
-		private ProcessResult(long fileSize, String errorCode, String errorDescription) {
-			this.fileSize = fileSize;
-			this.errorCode = errorCode;
-			this.errorDecription = errorDescription;
-		}
-
-	}
-
-	@Override
-	public int getConnectorModel() {
-		return IRepositoryConnector.MODEL_ADD_CHANGE_DELETE;
-	}
-
-	/** Specifications **/
-
-	@Override
-	public void viewSpecification(IHTTPOutput out, Locale locale, Specification spec, int connectionSequenceNumber)
-			throws ManifoldCFException, IOException {
-
-		Map<String, Object> paramMap = new HashMap<String, Object>();
-		paramMap.put("SeqNum", Integer.toString(connectionSequenceNumber));
-
-		NuxeoSpecification ns = NuxeoSpecification.from(spec);
-
-		paramMap.put(NuxeoConfiguration.Specification.DOMAINS.toUpperCase(), ns.getDomains());
-		paramMap.put(NuxeoConfiguration.Specification.DOCUMENTS_TYPE.toUpperCase(), ns.documentsType);
-		paramMap.put(NuxeoConfiguration.Specification.PROCESS_TAGS.toUpperCase(), ns.isProcessTags().toString());
-		paramMap.put(NuxeoConfiguration.Specification.PROCESS_ATTACHMENTS.toUpperCase(),
-				ns.isProcessAttachments().toString());
-
-		Messages.outputResourceWithVelocity(out, locale, VIEW_SPEC_FORWARD, paramMap);
-	}
-
-	@Override
-	public String processSpecificationPost(IPostParameters variableContext, Locale locale, Specification ds,
-			int connectionSequenceNumber) throws ManifoldCFException {
-
-		String seqPrefix = "s" + connectionSequenceNumber + "_";
-
-		// DOMAINS
-		String xc = variableContext.getParameter(seqPrefix + "domainscount");
-
-		if (xc != null) {
-			// Delete all preconfigured domains
-			int i = 0;
-			while (i < ds.getChildCount()) {
-				SpecificationNode sn = ds.getChild(i);
-				if (sn.getType().equals(NuxeoConfiguration.Specification.DOMAINS)) {
-					ds.removeChild(i);
-				} else {
-					i++;
-				}
-			}
-
-			SpecificationNode domains = new SpecificationNode(NuxeoConfiguration.Specification.DOMAINS);
-			ds.addChild(ds.getChildCount(), domains);
-			int domainsCount = Integer.parseInt(xc);
-			i = 0;
-			while (i < domainsCount) {
-				String domainDescription = "_" + Integer.toString(i);
-				String domainOpName = seqPrefix + "domainop" + domainDescription;
-				xc = variableContext.getParameter(domainOpName);
-				if (xc != null && xc.equals("Delete")) {
-					i++;
-					continue;
-				}
-
-				String domainKey = variableContext.getParameter(seqPrefix + "domain" + domainDescription);
-				SpecificationNode node = new SpecificationNode(NuxeoConfiguration.Specification.DOMAIN);
-				node.setAttribute(NuxeoConfiguration.Specification.DOMAIN_KEY, domainKey);
-				domains.addChild(domains.getChildCount(), node);
-				i++;
-			}
-
-			String op = variableContext.getParameter(seqPrefix + "domainop");
-			if (op != null && op.equals("Add")) {
-				String domainSpec = variableContext.getParameter(seqPrefix + "domain");
-				SpecificationNode node = new SpecificationNode(NuxeoConfiguration.Specification.DOMAIN);
-				node.setAttribute(NuxeoConfiguration.Specification.DOMAIN_KEY, domainSpec);
-				domains.addChild(domains.getChildCount(), node);
-			}
-		}
-
-		// TYPE OF DOCUMENTS
-		String xt = variableContext.getParameter(seqPrefix + "documentsTypecount");
-
-		if (xt != null) {
-			// Delete all preconfigured type of documents
-			int i = 0;
-			while (i < ds.getChildCount()) {
-				SpecificationNode sn = ds.getChild(i);
-				if (sn.getType().equals(NuxeoConfiguration.Specification.DOCUMENTS_TYPE)) {
-					ds.removeChild(i);
-				} else {
-					i++;
-				}
-			}
-
-			SpecificationNode documentsType = new SpecificationNode(NuxeoConfiguration.Specification.DOCUMENTS_TYPE);
-			ds.addChild(ds.getChildCount(), documentsType);
-			int documentsTypeCount = Integer.parseInt(xt);
-			i = 0;
-			while (i < documentsTypeCount) {
-				String documentTypeDescription = "_" + Integer.toString(i);
-				String documentTypeOpName = seqPrefix + "documentTypeop" + documentTypeDescription;
-				xt = variableContext.getParameter(documentTypeOpName);
-				if (xt != null && xt.equals("Delete")) {
-					i++;
-					continue;
-				}
-
-				String documentTypeKey = variableContext
-						.getParameter(seqPrefix + "documentType" + documentTypeDescription);
-				SpecificationNode node = new SpecificationNode(NuxeoConfiguration.Specification.DOCUMENT_TYPE);
-				node.setAttribute(NuxeoConfiguration.Specification.DOCUMENT_TYPE_KEY, documentTypeKey);
-				documentsType.addChild(documentsType.getChildCount(), node);
-				i++;
-			}
-
-			String op = variableContext.getParameter(seqPrefix + "documentTypeop");
-			if (op != null && op.equals("Add")) {
-				String documentTypeSpec = variableContext.getParameter(seqPrefix + "documentType");
-				SpecificationNode node = new SpecificationNode(NuxeoConfiguration.Specification.DOCUMENT_TYPE);
-				node.setAttribute(NuxeoConfiguration.Specification.DOCUMENT_TYPE_KEY, documentTypeSpec);
-				documentsType.addChild(documentsType.getChildCount(), node);
-			}
-
-		}
-
-		// TAGS
-		SpecificationNode documents = new SpecificationNode(NuxeoConfiguration.Specification.DOCUMENTS);
-		ds.addChild(ds.getChildCount(), documents);
-
-		String processTags = variableContext.getParameter(seqPrefix + NuxeoConfiguration.Specification.PROCESS_TAGS);
-		String processAttachments = variableContext
-				.getParameter(seqPrefix + NuxeoConfiguration.Specification.PROCESS_ATTACHMENTS);
-
-		if (processTags != null && !processTags.isEmpty()) {
-			documents.setAttribute(NuxeoConfiguration.Specification.PROCESS_TAGS, String.valueOf(processTags));
-		}
-		if (processAttachments != null && !processAttachments.isEmpty()) {
-			documents.setAttribute(NuxeoConfiguration.Specification.PROCESS_ATTACHMENTS,
-					String.valueOf(processAttachments));
-		}
-
-		return null;
-	}
-
-	@Override
-	public void outputSpecificationBody(IHTTPOutput out, Locale locale, Specification spec,
-			int connectionSequenceNumber, int actualSequenceNumber, String tabName)
-			throws ManifoldCFException, IOException {
-
-		Map<String, Object> paramMap = new HashMap<String, Object>();
-		paramMap.put("TabName", tabName);
-		paramMap.put("SeqNum", Integer.toString(connectionSequenceNumber));
-		paramMap.put("SelectedNum", Integer.toString(actualSequenceNumber));
-
-		NuxeoSpecification ns = NuxeoSpecification.from(spec);
-
-		paramMap.put(NuxeoConfiguration.Specification.DOMAINS.toUpperCase(), ns.getDomains());
-		paramMap.put(NuxeoConfiguration.Specification.DOCUMENTS_TYPE.toUpperCase(), ns.getDocumentsType());
-		paramMap.put(NuxeoConfiguration.Specification.PROCESS_TAGS.toUpperCase(), ns.isProcessTags());
-		paramMap.put(NuxeoConfiguration.Specification.PROCESS_ATTACHMENTS.toUpperCase(), ns.isProcessAttachments());
-
-		Messages.outputResourceWithVelocity(out, locale, EDIT_SPEC_FORWARD_CONF_DOMAINS, paramMap);
-		Messages.outputResourceWithVelocity(out, locale, EDIT_SPEC_FORWARD_CONF_DOCUMENTS_TYPE, paramMap);
-		Messages.outputResourceWithVelocity(out, locale, EDIT_SPEC_FORWARD_CONF_DOCUMENTS, paramMap);
-
-	}
-
-	@Override
-	public void outputSpecificationHeader(IHTTPOutput out, Locale locale, Specification spec,
-			int connectionSequenceNumber, List<String> tabsArray) throws ManifoldCFException, IOException {
-
-		tabsArray.add(Messages.getString(locale, CONF_DOMAINS_TAB_PROPERTY));
-		tabsArray.add(Messages.getString(locale, CONF_DOCUMENTS_TYPE_TAB_PROPERTY));
-		tabsArray.add(Messages.getString(locale, CONF_DOCUMENT_PROPERTY));
-
-		Map<String, Object> paramMap = new HashMap<String, Object>();
-		paramMap.put("SeqNum", Integer.toString(connectionSequenceNumber));
-
-		Messages.outputResourceWithVelocity(out, locale, EDIT_SPEC_HEADER_FORWARD, paramMap);
-	}
-
-	public static class NuxeoSpecification {
-
-		private List<String> domains;
-		private List<String> documentsType;
-		private Boolean processTags = false;
-		private Boolean processAttahcments = false;
-
-		public List<String> getDomains() {
-			return this.domains;
-		}
-
-		public List<String> getDocumentsType() {
-			return this.documentsType;
-		}
-
-		public Boolean isProcessTags() {
-			return this.processTags;
-		}
-
-		public Boolean isProcessAttachments() {
-			return this.processAttahcments;
-		}
-
-		/**
-		 * @param spec
-		 * @return
-		 */
-		public static NuxeoSpecification from(Specification spec) {
-			NuxeoSpecification ns = new NuxeoSpecification();
-
-			ns.domains = Lists.newArrayList();
-			ns.documentsType = Lists.newArrayList();
-
-			for (int i = 0, len = spec.getChildCount(); i < len; i++) {
-				SpecificationNode sn = spec.getChild(i);
-
-				if (sn.getType().equals(NuxeoConfiguration.Specification.DOMAINS)) {
-					for (int j = 0, sLen = sn.getChildCount(); j < sLen; j++) {
-						SpecificationNode spectNode = sn.getChild(j);
-						if (spectNode.getType().equals(NuxeoConfiguration.Specification.DOMAIN)) {
-							ns.domains.add(spectNode.getAttributeValue(NuxeoConfiguration.Specification.DOMAIN_KEY));
-						}
-					}
-				} else if (sn.getType().equals(NuxeoConfiguration.Specification.DOCUMENTS_TYPE)) {
-					for (int j = 0, sLen = sn.getChildCount(); j < sLen; j++) {
-						SpecificationNode spectNode = sn.getChild(j);
-						if (spectNode.getType().equals(NuxeoConfiguration.Specification.DOCUMENT_TYPE)) {
-							ns.documentsType.add(
-									spectNode.getAttributeValue(NuxeoConfiguration.Specification.DOCUMENT_TYPE_KEY));
-						}
-					}
-				} else if (sn.getType().equals(NuxeoConfiguration.Specification.DOCUMENTS)) {
-					String procTags = sn.getAttributeValue(NuxeoConfiguration.Specification.PROCESS_TAGS);
-					ns.processTags = Boolean.valueOf(procTags);
-					String procAtt = sn.getAttributeValue(NuxeoConfiguration.Specification.PROCESS_ATTACHMENTS);
-					ns.processAttahcments = Boolean.valueOf(procAtt);
-				}
-			}
+  // Specification tabs
+  private static final String CONF_DOMAINS_TAB_PROPERTY = "NuxeoRepositoryConnector.Domains";
+  private static final String CONF_DOCUMENTS_TYPE_TAB_PROPERTY = "NuxeoRepositoryConnector.DocumentsType";
+  private static final String CONF_DOCUMENT_PROPERTY = "NuxeoRepositoryConnector.Documents";
+
+  // Prefix for nuxeo configuration and specification parameters
+  private static final String PARAMETER_PREFIX = "nuxeo_";
+
+  // Templates for Nuxeo configuration
+  /**
+   * Javascript to check the configuration parameters
+   */
+  private static final String EDIT_CONFIG_HEADER_FORWARD = "editConfiguration_conf.js";
+
+  /**
+   * Server edit tab template
+   */
+  private static final String EDIT_CONFIG_FORWARD_SERVER = "editConfiguration_conf_server.html";
+
+  /**
+   * Server view tab template
+   */
+  private static final String VIEW_CONFIG_FORWARD = "viewConfiguration_conf.html";
+
+  // Templates for Nuxeo specification
+  /**
+   * Forward to the javascript to check the specification parameters for the
+   * job
+   */
+  private static final String EDIT_SPEC_HEADER_FORWARD = "editSpecification_conf.js";
+
+  /**
+   * Forward to the template to edit domains for the job
+   */
+  private static final String EDIT_SPEC_FORWARD_CONF_DOMAINS = "editSpecification_confDomains.html";
+
+  /**
+   * Forward to the template to edit documents type for the job
+   */
+  private static final String EDIT_SPEC_FORWARD_CONF_DOCUMENTS_TYPE = "editSpecification_confDocumentsType.html";
+
+  /**
+   * Forward to the template to edit document properties for the job
+   */
+  private static final String EDIT_SPEC_FORWARD_CONF_DOCUMENTS = "editSpecification_confDocuments.html";
+
+  /**
+   * Forward to the template to view the specification parameters for the job
+   */
+  private static final String VIEW_SPEC_FORWARD = "viewSpecification_conf.html";
+
+  protected long lastSessionFetch = -1L;
+  protected static final long timeToRelease = 300000L;
+
+  private Logger logger = LoggerFactory.getLogger(NuxeoRepositoryConnector.class);
+
+  /* Nuxeo instance parameters */
+  protected String protocol = null;
+  protected String host = null;
+  protected String port = null;
+  protected String path = null;
+  protected String username = null;
+  protected String password = null;
+
+  protected NuxeoClient nuxeoClient = null;
+
+  // Constructor
+  public NuxeoRepositoryConnector() {
+    super();
+  }
+
+  public void setNuxeoClient(NuxeoClient nuxeoClient) {
+    this.nuxeoClient = nuxeoClient;
+  }
+
+  @Override
+  public String[] getActivitiesList() {
+    return new String[] { ACTIVITY_READ };
+  }
+
+  @Override
+  public String[] getBinNames(String documentIdenfitier) {
+    return new String[] { host };
+  }
+
+  /** CONFIGURATION CONNECTOR **/
+  @Override
+  public void outputConfigurationHeader(IThreadContext threadContext, IHTTPOutput out, Locale locale,
+      ConfigParams parameters, List<String> tabsArray) throws ManifoldCFException, IOException {
+
+    // Server tab
+    tabsArray.add(Messages.getString(locale, NUXEO_SERVER_TAB_PROPERTY));
+
+    Map<String, String> paramMap = new HashMap<String, String>();
+
+    // Fill in the parameters form each tab
+    fillInServerConfigurationMap(paramMap, out, parameters);
+
+    Messages.outputResourceWithVelocity(out, locale, EDIT_CONFIG_HEADER_FORWARD, paramMap, true);
+  }
+
+  @Override
+  public void outputConfigurationBody(IThreadContext threadContext, IHTTPOutput out, Locale locale,
+      ConfigParams parameters, String tabName) throws ManifoldCFException, IOException {
+
+    // Call the Velocity tempaltes for each tab
+    Map<String, String> paramMap = new HashMap<String, String>();
+
+    // Set the tab name
+    paramMap.put("TabName", tabName);
+
+    // Fill in the parameters
+    fillInServerConfigurationMap(paramMap, out, parameters);
+
+    // Server tab
+    Messages.outputResourceWithVelocity(out, locale, EDIT_CONFIG_FORWARD_SERVER, paramMap, true);
+
+  }
+
+  private static void fillInServerConfigurationMap(Map<String, String> serverMap, IPasswordMapperActivity mapper,
+      ConfigParams parameters) {
+
+    String nuxeoProtocol = parameters.getParameter(NuxeoConfiguration.Server.PROTOCOL);
+    String nuxeoHost = parameters.getParameter(NuxeoConfiguration.Server.HOST);
+    String nuxeoPort = parameters.getParameter(NuxeoConfiguration.Server.PORT);
+    String nuxeoPath = parameters.getParameter(NuxeoConfiguration.Server.PATH);
+    String nuxeoUsername = parameters.getParameter(NuxeoConfiguration.Server.USERNAME);
+    String nuxeoPassword = parameters.getParameter(NuxeoConfiguration.Server.PASSWORD);
+
+    if (nuxeoProtocol == null)
+      nuxeoProtocol = NuxeoConfiguration.Server.PROTOCOL_DEFAULT_VALUE;
+    if (nuxeoHost == null)
+      nuxeoHost = NuxeoConfiguration.Server.HOST_DEFAULT_VALUE;
+    if (nuxeoPort == null)
+      nuxeoPort = NuxeoConfiguration.Server.PORT_DEFAULT_VALUE;
+    if (nuxeoPath == null)
+      nuxeoPath = NuxeoConfiguration.Server.PATH_DEFAULT_VALUE;
+    if (nuxeoUsername == null)
+      nuxeoUsername = NuxeoConfiguration.Server.USERNAME_DEFAULT_VALUE;
+    if (nuxeoPassword == null)
+      nuxeoPassword = NuxeoConfiguration.Server.PASSWORD_DEFAULT_VALUE;
+    else
+      nuxeoPassword = mapper.mapKeyToPassword(nuxeoPassword);
+
+    serverMap.put(PARAMETER_PREFIX + NuxeoConfiguration.Server.PROTOCOL, nuxeoProtocol);
+    serverMap.put(PARAMETER_PREFIX + NuxeoConfiguration.Server.HOST, nuxeoHost);
+    serverMap.put(PARAMETER_PREFIX + NuxeoConfiguration.Server.PORT, nuxeoPort);
+    serverMap.put(PARAMETER_PREFIX + NuxeoConfiguration.Server.PATH, nuxeoPath);
+    serverMap.put(PARAMETER_PREFIX + NuxeoConfiguration.Server.USERNAME, nuxeoUsername);
+    serverMap.put(PARAMETER_PREFIX + NuxeoConfiguration.Server.PASSWORD, nuxeoPassword);
+
+  }
+
+  @Override
+  public String processConfigurationPost(IThreadContext thredContext, IPostParameters variableContext,
+      ConfigParams parameters) {
+
+    String nuxeoProtocol = variableContext.getParameter(PARAMETER_PREFIX + NuxeoConfiguration.Server.PROTOCOL);
+    if (nuxeoProtocol != null)
+      parameters.setParameter(NuxeoConfiguration.Server.PROTOCOL, nuxeoProtocol);
+
+    String nuxeoHost = variableContext.getParameter(PARAMETER_PREFIX + NuxeoConfiguration.Server.HOST);
+    if (nuxeoHost != null)
+      parameters.setParameter(NuxeoConfiguration.Server.HOST, nuxeoHost);
+
+    String nuxeoPort = variableContext.getParameter(PARAMETER_PREFIX + NuxeoConfiguration.Server.PORT);
+    if (nuxeoPort != null)
+      parameters.setParameter(NuxeoConfiguration.Server.PORT, nuxeoPort);
+
+    String nuxeoPath = variableContext.getParameter(PARAMETER_PREFIX + NuxeoConfiguration.Server.PATH);
+    if (nuxeoPath != null)
+      parameters.setParameter(NuxeoConfiguration.Server.PATH, nuxeoPath);
+
+    String nuxeoUsername = variableContext.getParameter(PARAMETER_PREFIX + NuxeoConfiguration.Server.USERNAME);
+    if (nuxeoUsername != null)
+      parameters.setParameter(NuxeoConfiguration.Server.USERNAME, nuxeoUsername);
+
+    String nuxeoPassword = variableContext.getParameter(PARAMETER_PREFIX + NuxeoConfiguration.Server.PASSWORD);
+    if (nuxeoPassword != null)
+      parameters.setObfuscatedParameter(NuxeoConfiguration.Server.PASSWORD,
+          variableContext.mapKeyToPassword(nuxeoPassword));
+
+    return null;
+  }
+
+  @Override
+  public void viewConfiguration(IThreadContext threadContext, IHTTPOutput out, Locale locale, ConfigParams parameters)
+      throws ManifoldCFException, IOException {
+
+    Map<String, String> paramMap = new HashMap<String, String>();
+
+    fillInServerConfigurationMap(paramMap, out, parameters);
+
+    Messages.outputResourceWithVelocity(out, locale, VIEW_CONFIG_FORWARD, paramMap, true);
+  }
+
+  /** CONNECTION **/
+  @Override
+  public void connect(ConfigParams configParams) {
+    super.connect(configParams);
+
+    protocol = params.getParameter(NuxeoConfiguration.Server.PROTOCOL);
+    host = params.getParameter(NuxeoConfiguration.Server.HOST);
+    port = params.getParameter(NuxeoConfiguration.Server.PORT);
+    path = params.getParameter(NuxeoConfiguration.Server.PATH);
+    username = params.getParameter(NuxeoConfiguration.Server.USERNAME);
+    password = params.getObfuscatedParameter(NuxeoConfiguration.Server.PASSWORD);
+
+    try {
+      initNuxeoClient();
+    } catch (ManifoldCFException manifoldCFException) {
+      logger.debug("Not possible to initialize Nuxeo client. Reason: {}", manifoldCFException.getMessage());
+      manifoldCFException.printStackTrace();
+    }
+  }
+
+  // Check the connection
+  @Override
+  public String check() throws ManifoldCFException {
+    try {
+      if (!isConnected()) {
+        initNuxeoClient();
+      }
+
+      Boolean result = nuxeoClient.check();
+
+      if (result)
+        return super.check();
+      else
+        throw new ManifoldCFException("Nuxeo instance could not be reached");
+
+    } catch (ServiceInterruption serviceInterruption) {
+      return "Connection temporarily failed: " + serviceInterruption.getMessage();
+    } catch (ManifoldCFException manifoldCFException) {
+      return "Connection failed: " + manifoldCFException.getMessage();
+    } catch (Exception e) {
+      return "Connection failed: " + e.getMessage();
+    }
+  }
+
+  /**
+   * Initialize Nuxeo client using the configured parameters.
+   * 
+   * @throws ManifoldCFException
+   */
+  private void initNuxeoClient() throws ManifoldCFException {
+    int portInt;
+
+    if (nuxeoClient == null) {
+
+      if (StringUtils.isEmpty(protocol)) {
+        throw new ManifoldCFException(
+            "Parameter " + NuxeoConfiguration.Server.PROTOCOL + " required but not set");
+      }
+
+      if (StringUtils.isEmpty(host)) {
+        throw new ManifoldCFException("Parameter " + NuxeoConfiguration.Server.HOST + " required but not set");
+      }
+
+      if (port != null && port.length() > 0) {
+        try {
+          portInt = Integer.parseInt(port);
+        } catch (NumberFormatException formatException) {
+          throw new ManifoldCFException("Bad number: " + formatException.getMessage(), formatException);
+        }
+      } else {
+        if (protocol.toLowerCase(Locale.ROOT).equals("http")) {
+          portInt = 80;
+        } else {
+          portInt = 443;
+        }
+      }
+
+      nuxeoClient = new NuxeoClient(protocol, host, portInt, path, username, password);
+
+      lastSessionFetch = System.currentTimeMillis();
+
+    }
+
+  }
+
+  @Override
+  public boolean isConnected() {
+    return nuxeoClient != null;
+  }
+
+  @Override
+  public void poll() throws ManifoldCFException {
+    if (lastSessionFetch == -1L) {
+      return;
+    }
+
+    long currentTime = System.currentTimeMillis();
+
+    if (currentTime > lastSessionFetch + timeToRelease) {
+      nuxeoClient.close();
+      nuxeoClient = null;
+      lastSessionFetch = -1;
+    }
+  }
+
+  /** SEEDING **/
+  @Override
+  public String addSeedDocuments(ISeedingActivity activities, Specification spec, String lastSeedVersion,
+      long seedTime, int jobMode) throws ManifoldCFException, ServiceInterruption {
+
+    if (!isConnected())
+      initNuxeoClient();
+
+    try {
+
+      int lastStart = 0;
+      int defaultSize = 50;
+      Boolean isLast = true;
+      NuxeoSpecification ns = NuxeoSpecification.from(spec);
+      List<String> domains = ns.getDomains();
+      List<String> documentsType = ns.getDocumentsType();
+
+      do {
+        final NuxeoResponse<Document> response = nuxeoClient.getDocuments(domains, documentsType,
+            lastSeedVersion, lastStart, defaultSize, isLast);
+
+        for (Document doc : response.getResults()) {
+          activities.addSeedDocument(doc.getUid());
+        }
+
+        lastStart++;
+        isLast = response.isLast();
+
+      } while (!isLast);
+
+      SimpleDateFormat sdf = new SimpleDateFormat("yyyy-MM-dd'T'HH:mm:ss'Z'");
+      sdf.setTimeZone(TimeZone.getTimeZone("GMT"));
+
+      lastSeedVersion = sdf.format(new Date());
+
+      return lastSeedVersion;
+    } catch (Exception exception) {
+      long interruptionRetryTime = 5L * 60L * 1000L;
+      String message = "Server appears down during seeding: " + exception.getMessage();
+      throw new ServiceInterruption(message, exception, System.currentTimeMillis() + interruptionRetryTime, -1L,
+          3, true);
+    }
+  }
+
+  /** PROCESS DOCUMENTS **/
+  @Override
+  public void processDocuments(String[] documentsIdentifieres, IExistingVersions statuses, Specification spec,
+      IProcessActivity activities, int jobMode, boolean usesDefaultAuthority)
+      throws ManifoldCFException, ServiceInterruption {
+
+    for (int i = 0; i < documentsIdentifieres.length; i++) {
+
+      String documentId = documentsIdentifieres[i];
+      String version = statuses.getIndexedVersionString(documentId);
+
+      long startTime = System.currentTimeMillis();
+      ProcessResult pResult = null;
+      boolean doLog = true;
+
+      try {
+
+        if (!isConnected()) {
+          initNuxeoClient();
+        }
+
+        pResult = processDocument(documentId, spec, version, activities, doLog,
+            Maps.<String, String> newHashMap());
+      } catch (Exception exception) {
+        long interruptionRetryTime = 5L * 60L * 1000L;
+        String message = "Server appears down during seeding: " + exception.getMessage();
+        throw new ServiceInterruption(message, exception, System.currentTimeMillis() + interruptionRetryTime,
+            -1L, 3, true);
+      } finally {
+        if (doLog)
+          if (pResult != null && pResult.errorCode != null && !pResult.errorCode.isEmpty())
+            activities.recordActivity(new Long(startTime), ACTIVITY_READ, pResult.fileSize, documentId,
+                pResult.errorCode, pResult.errorDecription, null);
+      }
+
+    }
+  }
+
+  /**
+   * @param documentId
+   * @param version
+   * @param activities
+   * @param doLog
+   * @param newHashMap
+   * @return
+   */
+  private ProcessResult processDocument(String documentId, Specification spec, String version,
+      IProcessActivity activities, boolean doLog, HashMap<String, String> extraProperties)
+      throws ManifoldCFException, ServiceInterruption, IOException {
+
+    Document doc = nuxeoClient.getDocument(documentId);
+
+    return processDocumentInternal(doc, documentId, spec, version, activities, doLog, extraProperties);
+  }
+
+  /**
+   * @param doc
+   * @param documentId
+   * @param version
+   * @param activities
+   * @param doLog
+   * @param extraProperties
+   * @return
+   */
+  private ProcessResult processDocumentInternal(Document doc, String manifoldDocumentIdentifier, Specification spec,
+      String version, IProcessActivity activities, boolean doLog, HashMap<String, String> extraProperties)
+      throws ManifoldCFException, ServiceInterruption, IOException {
+
+    RepositoryDocument rd = new RepositoryDocument();
+    NuxeoSpecification ns = NuxeoSpecification.from(spec);
+
+    Date lastModified = doc.getLastModified();
+
+    DateFormat df = DateFormat.getDateTimeInstance();
+
+    String lastVersion = null;
+
+    if (lastModified != null)
+      lastVersion = df.format(lastModified);
+
+    if (doc.getState() != null && doc.getState().equalsIgnoreCase(Document.DELETED)) {
+      activities.deleteDocument(manifoldDocumentIdentifier);
+      return new ProcessResult(doc.getLenght(), "DELETED", "");
+    }
+
+    if (!activities.checkDocumentNeedsReindexing(manifoldDocumentIdentifier, lastVersion)) {
+      return new ProcessResult(doc.getLenght(), "RETAINED", "");
+    }
+
+    if (doc.getUid() == null) {
+      activities.deleteDocument(manifoldDocumentIdentifier);
+      return new ProcessResult(doc.getLenght(), "DELETED", "");
+    }
+
+    // Add respository document information
+    rd.setMimeType(doc.getMediatype());
+    if (lastModified != null)
+      rd.setModifiedDate(lastModified);
+    rd.setIndexingDate(new Date());
+
+    // Adding Document Metadata
+    Map<String, Object> docMetadata = doc.getMetadataAsMap();
+
+    for (Entry<String, Object> entry : docMetadata.entrySet()) {
+      if (entry.getValue() instanceof List) {
+        List<?> list = (List<?>) entry.getValue();
+        rd.addField(entry.getKey(), list.toArray(new String[list.size()]));
+      } else {
+        rd.addField(entry.getKey(), entry.getValue().toString());
+      }
+
+    }
+
+    if (ns.isProcessTags())
+      rd.addField("Tags", getTagsFromDocument(doc));
+
+    String documentUri = nuxeoClient.getPathDocument(doc.getUid());
+
+    // Set repository ACLs
+    String[] permissions = getPermissionDocument(doc);
+    rd.setSecurityACL(RepositoryDocument.SECURITY_TYPE_DOCUMENT, permissions);
+    rd.setSecurityDenyACL(RepositoryDocument.SECURITY_TYPE_DOCUMENT, new String[] { GLOBAL_DENY_TOKEN });
+    rd.setBinary(doc.getContentStream(), doc.getLenght());
+
+    // Action
+    activities.ingestDocumentWithException(manifoldDocumentIdentifier, lastVersion, documentUri, rd);
+
+    if (ns.isProcessAttachments())
+      for (Attachment att : doc.getAttachments()) {
+        RepositoryDocument att_rd = new RepositoryDocument();
+        String attDocumentUri = nuxeoClient.getPathDocument(doc.getUid()) + "_" + att.getName();
+
+        att_rd.setMimeType(att.getMime_type());
+        att_rd.setBinary(doc.getContentStream(), att.getLength());
+
+        if (lastModified != null)
+          att_rd.setModifiedDate(lastModified);
+        att_rd.setIndexingDate(new Date());
+
+        att_rd.addField(Attachment.ATT_KEY_NAME, att.getName());
+        att_rd.addField(Attachment.ATT_KEY_LENGTH, String.valueOf(att.getLength()));
+        att_rd.addField(Attachment.ATT_KEY_URL, att.getUrl());
+
+        // Set repository ACLs
+        att_rd.setSecurityACL(RepositoryDocument.SECURITY_TYPE_DOCUMENT, permissions);
+        att_rd.setSecurityDenyACL(RepositoryDocument.SECURITY_TYPE_DOCUMENT,
+            new String[] { GLOBAL_DENY_TOKEN });
+
+        activities.ingestDocumentWithException(manifoldDocumentIdentifier, attDocumentUri, lastVersion,
+            attDocumentUri, att_rd);
+      }
+
+    return new ProcessResult(doc.getLenght(), "OK", StringUtils.EMPTY);
+  }
+
+  public String[] getPermissionDocument(Document doc) {
+
+    List<String> permissions = new ArrayList<String>();
+    try {
+      Acl acl = nuxeoClient.getAcl(doc.getUid());
+
+      for (Ace ace : acl.getAces()) {
+        if (ace.getStatus().equalsIgnoreCase("effective") && ace.isGranted()) {
+          permissions.add(ace.getName());
+        }
+      }
+
+      return permissions.toArray(new String[0]);
+
+    } catch (Exception e) {
+      return new String[] {};
+    }
+  }
+
+  public String[] getTagsFromDocument(Document doc) {
+    try {
+      return nuxeoClient.getTags(doc.getUid());
+    } catch (Exception e) {
+      return new String[] {};
+    }
+  }
+
+  private class ProcessResult {
+    private long fileSize;
+    private String errorCode;
+    private String errorDecription;
+
+    private ProcessResult(long fileSize, String errorCode, String errorDescription) {
+      this.fileSize = fileSize;
+      this.errorCode = errorCode;
+      this.errorDecription = errorDescription;
+    }
+
+  }
+
+  @Override
+  public int getConnectorModel() {
+    return IRepositoryConnector.MODEL_ADD_CHANGE_DELETE;
+  }
+
+  /** Specifications **/
+
+  @Override
+  public void viewSpecification(IHTTPOutput out, Locale locale, Specification spec, int connectionSequenceNumber)
+      throws ManifoldCFException, IOException {
+
+    Map<String, Object> paramMap = new HashMap<String, Object>();
+    paramMap.put("SeqNum", Integer.toString(connectionSequenceNumber));
+
+    NuxeoSpecification ns = NuxeoSpecification.from(spec);
+
+    paramMap.put(NuxeoConfiguration.Specification.DOMAINS.toUpperCase(), ns.getDomains());
+    paramMap.put(NuxeoConfiguration.Specification.DOCUMENTS_TYPE.toUpperCase(), ns.documentsType);
+    paramMap.put(NuxeoConfiguration.Specification.PROCESS_TAGS.toUpperCase(), ns.isProcessTags().toString());
+    paramMap.put(NuxeoConfiguration.Specification.PROCESS_ATTACHMENTS.toUpperCase(),
+        ns.isProcessAttachments().toString());
+
+    Messages.outputResourceWithVelocity(out, locale, VIEW_SPEC_FORWARD, paramMap);
+  }
+
+  @Override
+  public String processSpecificationPost(IPostParameters variableContext, Locale locale, Specification ds,
+      int connectionSequenceNumber) throws ManifoldCFException {
+
+    String seqPrefix = "s" + connectionSequenceNumber + "_";
+
+    // DOMAINS
+    String xc = variableContext.getParameter(seqPrefix + "domainscount");
+
+    if (xc != null) {
+      // Delete all preconfigured domains
+      int i = 0;
+      while (i < ds.getChildCount()) {
+        SpecificationNode sn = ds.getChild(i);
+        if (sn.getType().equals(NuxeoConfiguration.Specification.DOMAINS)) {
+          ds.removeChild(i);
+        } else {
+          i++;
+        }
+      }
+
+      SpecificationNode domains = new SpecificationNode(NuxeoConfiguration.Specification.DOMAINS);
+      ds.addChild(ds.getChildCount(), domains);
+      int domainsCount = Integer.parseInt(xc);
+      i = 0;
+      while (i < domainsCount) {
+        String domainDescription = "_" + Integer.toString(i);
+        String domainOpName = seqPrefix + "domainop" + domainDescription;
+        xc = variableContext.getParameter(domainOpName);
+        if (xc != null && xc.equals("Delete")) {
+          i++;
+          continue;
+        }
+
+        String domainKey = variableContext.getParameter(seqPrefix + "domain" + domainDescription);
+        SpecificationNode node = new SpecificationNode(NuxeoConfiguration.Specification.DOMAIN);
+        node.setAttribute(NuxeoConfiguration.Specification.DOMAIN_KEY, domainKey);
+        domains.addChild(domains.getChildCount(), node);
+        i++;
+      }
+
+      String op = variableContext.getParameter(seqPrefix + "domainop");
+      if (op != null && op.equals("Add")) {
+        String domainSpec = variableContext.getParameter(seqPrefix + "domain");
+        SpecificationNode node = new SpecificationNode(NuxeoConfiguration.Specification.DOMAIN);
+        node.setAttribute(NuxeoConfiguration.Specification.DOMAIN_KEY, domainSpec);
+        domains.addChild(domains.getChildCount(), node);
+      }
+    }
+
+    // TYPE OF DOCUMENTS
+    String xt = variableContext.getParameter(seqPrefix + "documentsTypecount");
+
+    if (xt != null) {
+      // Delete all preconfigured type of documents
+      int i = 0;
+      while (i < ds.getChildCount()) {
+        SpecificationNode sn = ds.getChild(i);
+        if (sn.getType().equals(NuxeoConfiguration.Specification.DOCUMENTS_TYPE)) {
+          ds.removeChild(i);
+        } else {
+          i++;
+        }
+      }
+
+      SpecificationNode documentsType = new SpecificationNode(NuxeoConfiguration.Specification.DOCUMENTS_TYPE);
+      ds.addChild(ds.getChildCount(), documentsType);
+      int documentsTypeCount = Integer.parseInt(xt);
+      i = 0;
+      while (i < documentsTypeCount) {
+        String documentTypeDescription = "_" + Integer.toString(i);
+        String documentTypeOpName = seqPrefix + "documentTypeop" + documentTypeDescription;
+        xt = variableContext.getParameter(documentTypeOpName);
+        if (xt != null && xt.equals("Delete")) {
+          i++;
+          continue;
+        }
+
+        String documentTypeKey = variableContext
+            .getParameter(seqPrefix + "documentType" + documentTypeDescription);
+        SpecificationNode node = new SpecificationNode(NuxeoConfiguration.Specification.DOCUMENT_TYPE);
+        node.setAttribute(NuxeoConfiguration.Specification.DOCUMENT_TYPE_KEY, documentTypeKey);
+        documentsType.addChild(documentsType.getChildCount(), node);
+        i++;
+      }
+
+      String op = variableContext.getParameter(seqPrefix + "documentTypeop");
+      if (op != null && op.equals("Add")) {
+        String documentTypeSpec = variableContext.getParameter(seqPrefix + "documentType");
+        SpecificationNode node = new SpecificationNode(NuxeoConfiguration.Specification.DOCUMENT_TYPE);
+        node.setAttribute(NuxeoConfiguration.Specification.DOCUMENT_TYPE_KEY, documentTypeSpec);
+        documentsType.addChild(documentsType.getChildCount(), node);
+      }
+
+    }
+
+    // TAGS
+    SpecificationNode documents = new SpecificationNode(NuxeoConfiguration.Specification.DOCUMENTS);
+    ds.addChild(ds.getChildCount(), documents);
+
+    String processTags = variableContext.getParameter(seqPrefix + NuxeoConfiguration.Specification.PROCESS_TAGS);
+    String processAttachments = variableContext
+        .getParameter(seqPrefix + NuxeoConfiguration.Specification.PROCESS_ATTACHMENTS);
+
+    if (processTags != null && !processTags.isEmpty()) {
+      documents.setAttribute(NuxeoConfiguration.Specification.PROCESS_TAGS, String.valueOf(processTags));
+    }
+    if (processAttachments != null && !processAttachments.isEmpty()) {
+      documents.setAttribute(NuxeoConfiguration.Specification.PROCESS_ATTACHMENTS,
+          String.valueOf(processAttachments));
+    }
+
+    return null;
+  }
+
+  @Override
+  public void outputSpecificationBody(IHTTPOutput out, Locale locale, Specification spec,
+      int connectionSequenceNumber, int actualSequenceNumber, String tabName)
+      throws ManifoldCFException, IOException {
+
+    Map<String, Object> paramMap = new HashMap<String, Object>();
+    paramMap.put("TabName", tabName);
+    paramMap.put("SeqNum", Integer.toString(connectionSequenceNumber));
+    paramMap.put("SelectedNum", Integer.toString(actualSequenceNumber));
+
+    NuxeoSpecification ns = NuxeoSpecification.from(spec);
+
+    paramMap.put(NuxeoConfiguration.Specification.DOMAINS.toUpperCase(), ns.getDomains());
+    paramMap.put(NuxeoConfiguration.Specification.DOCUMENTS_TYPE.toUpperCase(), ns.getDocumentsType());
+    paramMap.put(NuxeoConfiguration.Specification.PROCESS_TAGS.toUpperCase(), ns.isProcessTags());
+    paramMap.put(NuxeoConfiguration.Specification.PROCESS_ATTACHMENTS.toUpperCase(), ns.isProcessAttachments());
+
+    Messages.outputResourceWithVelocity(out, locale, EDIT_SPEC_FORWARD_CONF_DOMAINS, paramMap);
+    Messages.outputResourceWithVelocity(out, locale, EDIT_SPEC_FORWARD_CONF_DOCUMENTS_TYPE, paramMap);
+    Messages.outputResourceWithVelocity(out, locale, EDIT_SPEC_FORWARD_CONF_DOCUMENTS, paramMap);
+
+  }
+
+  @Override
+  public void outputSpecificationHeader(IHTTPOutput out, Locale locale, Specification spec,
+      int connectionSequenceNumber, List<String> tabsArray) throws ManifoldCFException, IOException {
+
+    tabsArray.add(Messages.getString(locale, CONF_DOMAINS_TAB_PROPERTY));
+    tabsArray.add(Messages.getString(locale, CONF_DOCUMENTS_TYPE_TAB_PROPERTY));
+    tabsArray.add(Messages.getString(locale, CONF_DOCUMENT_PROPERTY));
+
+    Map<String, Object> paramMap = new HashMap<String, Object>();
+    paramMap.put("SeqNum", Integer.toString(connectionSequenceNumber));
+
+    Messages.outputResourceWithVelocity(out, locale, EDIT_SPEC_HEADER_FORWARD, paramMap);
+  }
+
+  public static class NuxeoSpecification {
+
+    private List<String> domains;
+    private List<String> documentsType;
+    private Boolean processTags = false;
+    private Boolean processAttahcments = false;
+
+    public List<String> getDomains() {
+      return this.domains;
+    }
+
+    public List<String> getDocumentsType() {
+      return this.documentsType;
+    }
+
+    public Boolean isProcessTags() {
+      return this.processTags;
+    }
+
+    public Boolean isProcessAttachments() {
+      return this.processAttahcments;
+    }
+
+    /**
+     * @param spec
+     * @return
+     */
+    public static NuxeoSpecification from(Specification spec) {
+      NuxeoSpecification ns = new NuxeoSpecification();
+
+      ns.domains = Lists.newArrayList();
+      ns.documentsType = Lists.newArrayList();
+
+      for (int i = 0, len = spec.getChildCount(); i < len; i++) {
+        SpecificationNode sn = spec.getChild(i);
+
+        if (sn.getType().equals(NuxeoConfiguration.Specification.DOMAINS)) {
+          for (int j = 0, sLen = sn.getChildCount(); j < sLen; j++) {
+            SpecificationNode spectNode = sn.getChild(j);
+            if (spectNode.getType().equals(NuxeoConfiguration.Specification.DOMAIN)) {
+              ns.domains.add(spectNode.getAttributeValue(NuxeoConfiguration.Specification.DOMAIN_KEY));
+            }
+          }
+        } else if (sn.getType().equals(NuxeoConfiguration.Specification.DOCUMENTS_TYPE)) {
+          for (int j = 0, sLen = sn.getChildCount(); j < sLen; j++) {
+            SpecificationNode spectNode = sn.getChild(j);
+            if (spectNode.getType().equals(NuxeoConfiguration.Specification.DOCUMENT_TYPE)) {
+              ns.documentsType.add(
+                  spectNode.getAttributeValue(NuxeoConfiguration.Specification.DOCUMENT_TYPE_KEY));
+            }
+          }
+        } else if (sn.getType().equals(NuxeoConfiguration.Specification.DOCUMENTS)) {
+          String procTags = sn.getAttributeValue(NuxeoConfiguration.Specification.PROCESS_TAGS);
+          ns.processTags = Boolean.valueOf(procTags);
+          String procAtt = sn.getAttributeValue(NuxeoConfiguration.Specification.PROCESS_ATTACHMENTS);
+          ns.processAttahcments = Boolean.valueOf(procAtt);
+        }
+      }
 
-			return ns;
-		}
+      return ns;
+    }
 
-	}
+  }
 }

Modified: manifoldcf/branches/CONNECTORS-1290/connectors/nuxeo/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/nuxeo/client/NuxeoClient.java
URL: http://svn.apache.org/viewvc/manifoldcf/branches/CONNECTORS-1290/connectors/nuxeo/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/nuxeo/client/NuxeoClient.java?rev=1770925&r1=1770924&r2=1770925&view=diff
==============================================================================
--- manifoldcf/branches/CONNECTORS-1290/connectors/nuxeo/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/nuxeo/client/NuxeoClient.java (original)
+++ manifoldcf/branches/CONNECTORS-1290/connectors/nuxeo/connector/src/main/java/org/apache/manifoldcf/crawler/connectors/nuxeo/client/NuxeoClient.java Wed Nov 23 07:28:32 2016
@@ -1,6 +1,21 @@
+/* $Id: DefaultAuthenticator.java 1688076 2015-06-28 23:04:30Z kwright $ */
+
 /**
- * 
- */
+* Licensed to the Apache Software Foundation (ASF) under one or more
+* contributor license agreements. See the NOTICE file distributed with
+* this work for additional information regarding copyright ownership.
+* The ASF licenses this file to You under the Apache License, Version 2.0
+* (the "License"); you may not use this file except in compliance with
+* the License. You may obtain a copy of the License at
+*
+* http://www.apache.org/licenses/LICENSE-2.0
+*
+* Unless required by applicable law or agreed to in writing, software
+* distributed under the License is distributed on an "AS IS" BASIS,
+* WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+* See the License for the specific language governing permissions and
+* limitations under the License.
+*/
 package org.apache.manifoldcf.crawler.connectors.nuxeo.client;
 
 import java.io.IOException;
@@ -52,429 +67,429 @@ import org.slf4j.LoggerFactory;
  *
  */
 public class NuxeoClient {
-	private static final String CONTENT_PATH = "site/api/v1/";
-	private static final String CONTENT_QUERY = CONTENT_PATH + "query";
-	private static final String CONTENT_UUID = CONTENT_PATH + "id";
-	public static final String CONTENT_AUTHORITY = CONTENT_PATH + "user";
-	public static final String CONTENT_TAG = CONTENT_PATH + "";
-
-	private Logger logger = LoggerFactory.getLogger(NuxeoClient.class);
-
-	private String protocol;
-	private Integer port;
-	private String host;
-	private String path;
-	private String username;
-	private String password;
-
-	private CloseableHttpClient httpClient;
-	private HttpClientContext httpContext;
-
-	public NuxeoClient(String protocol, String host, Integer port, String path, String username, String password)
-			throws ManifoldCFException {
-
-		this.protocol = protocol;
-		this.host = host;
-		this.port = port;
-		this.path = path;
-		this.username = username;
-		this.password = password;
-
-		connect();
-	}
-
-	private void connect() throws ManifoldCFException {
-		int socketTimeout = 900000;
-		int connectionTimeout = 60000;
-		int inactivityTimeout = 2000;
-
-		SSLSocketFactory httpsSocketFactory = KeystoreManagerFactory.getTrustingSecureSocketFactory();
-		SSLConnectionSocketFactory sslConnectionSocketFactory = new SSLConnectionSocketFactory(
-				new InterruptibleSocketFactory(httpsSocketFactory, connectionTimeout), NoopHostnameVerifier.INSTANCE);
-
-		PoolingHttpClientConnectionManager poolingHttpClientConnectionManager = new PoolingHttpClientConnectionManager(
-				RegistryBuilder.<ConnectionSocketFactory> create()
-						.register("http", PlainConnectionSocketFactory.getSocketFactory())
-						.register("https", sslConnectionSocketFactory).build());
-
-		poolingHttpClientConnectionManager.setDefaultMaxPerRoute(1);
-		poolingHttpClientConnectionManager.setValidateAfterInactivity(inactivityTimeout);
-		poolingHttpClientConnectionManager
-				.setDefaultSocketConfig(SocketConfig.custom().setTcpNoDelay(true).setSoTimeout(socketTimeout).build());
-
-		RequestConfig.Builder requestBuilder = RequestConfig.custom().setCircularRedirectsAllowed(true)
-				.setSocketTimeout(socketTimeout).setExpectContinueEnabled(true).setConnectTimeout(connectionTimeout)
-				.setConnectionRequestTimeout(socketTimeout);
-
-		httpClient = HttpClients.custom().setConnectionManager(poolingHttpClientConnectionManager)
-				.disableAutomaticRetries().setDefaultRequestConfig(requestBuilder.build())
-				.setRequestExecutor(new HttpRequestExecutor(socketTimeout))
-				.setRedirectStrategy(new DefaultRedirectStrategy()).build();
-	}
-
-	public Boolean check() throws Exception {
-		HttpResponse response;
-
-		try {
-			if (httpClient == null)
-				connect();
-
-			String url = String.format("%s://%s:%s%s/%s?pageSize=1", protocol, host, port, path, CONTENT_QUERY);
-
-			HttpGet httpGet = createGetRequest(url);
-			response = httpClient.execute(httpGet);
-			int statusCode = response.getStatusLine().getStatusCode();
-			if (statusCode != 200)
-				throw new Exception("[Checking connection] Nuxeo server appears to be down");
-			else
-				return true;
-		} catch (IOException e) {
-			throw new Exception("Nuxeo apeears to be down", e);
-		}
-	}
-
-	public boolean checkAuth() throws Exception {
-		// HttpResponse response;
-
-		// try {
-		if (httpClient == null)
-			connect();
-
-		try {
-			getUserAuthorities("Administrator");
-			return true;
-		} catch (IOException e) {
-			throw new Exception("Nuxeo apeears to be down", e);
-		}
-	}
-
-	/**
-	 * @param url
-	 * @return
-	 */
-	private HttpGet createGetRequest(String url) {
-		String sanitizedUrl = sanitizedUrl(url);
-
-		HttpGet httpGet = new HttpGet(sanitizedUrl);
-
-		httpGet.addHeader("accepted", "application/json");
-
-		if (useBasicAuthentication())
-			httpGet.addHeader("Authorization", "Basic " + Base64.encodeBase64String(
-					String.format("%s:%s", this.username, this.password).getBytes(Charset.forName("UTF-8"))));
-
-		return httpGet;
-	}
-
-	/**
-	 * @param url
-	 * @return
-	 */
-	private String sanitizedUrl(String url) {
-		int colonIndex = url.indexOf(":");
-
-		String urlWithoutProtocol = url.startsWith("http") ? url.substring(colonIndex + 3) : url;
-		String sanitizedUrl = urlWithoutProtocol.replace("\\/+", "/");
-		return url.substring(0, colonIndex) + "://" + sanitizedUrl;
-	}
-
-	/**
-	 * @return
-	 */
-	private boolean useBasicAuthentication() {
-		return this.username != null && !"".equals(this.username) && this.password != null;
-	}
-
-	/**
-	 * @param lastStart
-	 * @param defaultSize
-	 * @param object
-	 * @return
-	 */
-	@SuppressWarnings("unchecked")
-	public NuxeoResponse<Document> getDocuments(List<String> domains, List<String> documentsType,
-			String lastSeedVersion, int start, int limit, Object object) throws Exception {
-
-		String url = null;
-
-		String q = createQuery(lastSeedVersion, domains, documentsType);
-		if (lastSeedVersion == null || lastSeedVersion.isEmpty())
-			url = String.format("%s://%s:%s/%s/%s?%s&pageSize=%s&currentPageIndex=%s", protocol, host, port, path,
-					CONTENT_QUERY, q, limit, start);
-		else
-			url = String.format("%s://%s:%s/%s/%s?%s&pageSize=%s&currentPageIndex=%s&queryParams=%s", protocol, host,
-					port, path, CONTENT_QUERY, q, limit, start, lastSeedVersion);
-
-		url = sanitizedUrl(url);
-
-		return (NuxeoResponse<Document>) getNuxeoResource(url, Document.builder());
-	}
-
-	public String createQuery(String lastSeedVersion, List<String> domains, List<String> documentsType) {
-		String query = "SELECT * FROM Document";
-
-		if (!domains.isEmpty() || !documentsType.isEmpty() || (lastSeedVersion != null && !lastSeedVersion.isEmpty())) {
-			query += " WHERE ";
-
-			if (lastSeedVersion != null && !lastSeedVersion.isEmpty()) {
-				query += "dc:modified > ?";
-			}
-
-			if (!domains.isEmpty()) {
-				Iterator<String> itdom = domains.iterator();
-
-				if (lastSeedVersion != null && !lastSeedVersion.isEmpty())
-					query = String.format("%s %s", query, " AND ");
-
-				query = String.format("%s ( ecm:path STARTSWITH '/%s'", query, itdom.next());
-
-				while (itdom.hasNext()) {
-					query = String.format("%s OR ecm:path STARTSWITH '/%s'", query, itdom.next());
-				}
-
-				query = String.format("%s)", query);
-			}
-
-			if (!documentsType.isEmpty()) {
-				Iterator<String> itDocTy = documentsType.iterator();
-
-				if ((lastSeedVersion != null && !lastSeedVersion.isEmpty()) || !domains.isEmpty())
-					query = String.format("%s %s", query, " AND ");
-				query = String.format("%s ( ecm:primaryType = '%s'", query, itDocTy.next());
-
-				while (itDocTy.hasNext()) {
-					query = String.format("%s OR ecm:primaryType = '%s'", query, itDocTy.next());
-				}
-
-				query = String.format("%s)", query);
-			}
-
-		}
-
-		query = URLEncoder.encode(query);
-		query = String.format("%s%s", "query=", query);
-		return query;
-	}
-
-	/**
-	 * @param url
-	 * @param builder
-	 * @return
-	 */
-	private NuxeoResponse<? extends NuxeoResource> getNuxeoResource(String url,
-			NuxeoResourceBuilder<? extends Document> builder) throws Exception {
-
-		try {
-			HttpGet httpGet = createGetRequest(url);
-			HttpResponse response = executeRequest(httpGet);
-
-			NuxeoResponse<? extends NuxeoResource> nuxeoResponse = responseFromHttpEntity(response.getEntity(),
-					builder);
-			EntityUtils.consume(response.getEntity());
-			return nuxeoResponse;
-		} catch (IOException e) {
-			throw new Exception("Nuxeo appears to be down", e);
-		}
-	}
-
-	/**
-	 * @param entity
-	 * @param builder
-	 * @return
-	 */
-	private <T extends NuxeoResource> NuxeoResponse<T> responseFromHttpEntity(HttpEntity entity,
-			NuxeoResourceBuilder<T> builder) throws Exception {
-
-		String stringEntity = EntityUtils.toString(entity);
-
-		JSONObject responseObject;
-
-		try {
-			responseObject = new JSONObject(stringEntity);
-			NuxeoResponse<T> response = NuxeoResponse.fromJson(responseObject, builder);
-
-			return response;
-		} catch (JSONException e) {
-			throw new Exception();
-		}
-	}
-
-	/**
-	 * @param httpGet
-	 * @return
-	 */
-	private HttpResponse executeRequest(HttpUriRequest request) throws Exception {
-
-		HttpResponse response = httpClient.execute(request, httpContext);
-
-		if (response.getStatusLine().getStatusCode() != 200) {
-			throw new Exception("Nuxeo error. " + response.getStatusLine().getStatusCode() + " "
-					+ response.getStatusLine().getReasonPhrase());
-		}
-		return response;
-	}
-
-	/**
-	 * @param documentId
-	 * @return
-	 * @throws ServiceInterruption 
-	 */
-	public Document getDocument(String documentId) throws ServiceInterruption {
-
-		String url = getPathDocument(documentId);
-
-		url = sanitizedUrl(url);
-
-		try {
-
-			HttpGet httpGet = createGetRequest(url);
-			httpGet.addHeader("X-NXDocumentProperties", "*");
-			HttpResponse response = executeRequest(httpGet);
-			HttpEntity entity = response.getEntity();
-			MutableDocument mDocument = documentFromHttpEmpty(entity);
-			EntityUtils.consume(entity);
-
-			return mDocument;
-		} catch (Exception e) {
-			logger.debug("Failed documentId:" + documentId,e);
-			long interruptionRetryTime = 5L * 60L * 1000L;
-			String message = "Server appears down during seeding: " + e.getMessage();
-			throw new ServiceInterruption(message, e, System.currentTimeMillis() + interruptionRetryTime,
-					-1L, 3, true);
-		}
-	}
-
-	public Acl getAcl(String documentId) {
-
-		String url = getPathDocument(documentId);
-		url += "/@acl";
-
-		url = sanitizedUrl(url);
-
-		try {
-
-			HttpGet httpGet = createGetRequest(url);
-			HttpResponse response = executeRequest(httpGet);
-			HttpEntity entity = response.getEntity();
-			MutableAcl mAcl = aclFromHttpEmpty(entity);
-			EntityUtils.consume(entity);
-
-			return mAcl;
-		} catch (Exception e) {
-		}
-
-		return new Acl();
-	}
-
-	public String getPathDocument(String documentId) {
-		return String.format("%s://%s:%s%s/%s/%s", protocol, host, port, path, CONTENT_UUID, documentId);
-	}
-
-	/**
-	 * @param entity
-	 * @return
-	 */
-	private MutableDocument documentFromHttpEmpty(HttpEntity entity) throws Exception {
-		String stringEntity = EntityUtils.toString(entity);
-
-		JSONObject responseObject;
-
-		try {
-			responseObject = new JSONObject(stringEntity);
-
-			@SuppressWarnings("unchecked")
-			MutableDocument mDocument = ((NuxeoResourceBuilder<MutableDocument>) MutableDocument.builder())
-					.fromJson(responseObject, new MutableDocument());
-
-			return mDocument;
-		} catch (JSONException jsonException) {
-			throw new Exception("Error parsing JSON document response data");
-		}
-	}
-
-	private MutableAcl aclFromHttpEmpty(HttpEntity entity) throws Exception {
-		String stringEntity = EntityUtils.toString(entity);
-
-		JSONObject responseObject;
-
-		try {
-			responseObject = new JSONObject(stringEntity);
-
-			@SuppressWarnings("unchecked")
-			MutableAcl mAcl = ((NuxeoResourceBuilder<MutableAcl>) MutableAcl.builder()).fromJson(responseObject,
-					new MutableAcl());
-
-			return mAcl;
-		} catch (JSONException jsonException) {
-			throw new Exception("Error parsing JSON document response data");
-		}
-	}
-
-	public void close() {
-		if (httpClient != null) {
-			try {
-				httpClient.close();
-			} catch (IOException ioException) {
-				ioException.printStackTrace();
-			}
-		}
-
-	}
-
-	public List<String> getUserAuthorities(String username) throws Exception {
-		List<String> authorities = new ArrayList<String>();
-
-		String url = String.format("%s://%s:%s/%s/%s/%s", protocol, host, port, path, CONTENT_AUTHORITY, username);
-
-		url = sanitizedUrl(url);
-
-		HttpGet httpGet = createGetRequest(url);
-		HttpResponse response = executeRequest(httpGet);
-		HttpEntity entity = response.getEntity();
-		String stringEntity = EntityUtils.toString(entity);
-		EntityUtils.consume(entity);
-
-		JSONObject user = new JSONObject(stringEntity);
-		authorities.add(user.getString("id"));
-
-		JSONObject properties = user.optJSONObject("properties");
-
-		if (properties != null) {
-			JSONArray groups = properties.optJSONArray("groups");
-
-			for (int i = 0; i < groups.length(); i++) {
-				authorities.add(groups.getString(i));
-			}
-		}
-
-		return authorities;
-	}
-
-	/**
-	 * @param uid
-	 * @return
-	 * @throws Exception
-	 */
-	public String[] getTags(String uid) throws Exception {
-		List<String> tags = new ArrayList<>();
-
-		String query = "select%20*%20from%20Tagging%20where%20relation%3Asource='" + uid + "'";
-		String url = String.format("%s://%s:%s/%s/%s?query=%s", protocol, host, port, path, CONTENT_QUERY, query);
-		url = sanitizedUrl(url);
-
-		HttpGet httpGet = createGetRequest(url);
-		HttpResponse response = executeRequest(httpGet);
-		HttpEntity entity = response.getEntity();
-		String stringEntity = EntityUtils.toString(entity);
-		EntityUtils.consume(entity);
-
-		JSONArray tagsObject = new JSONObject(stringEntity).getJSONArray("entries");
-
-		for (int i = 0; i < tagsObject.length(); i++) {
-			tags.add(tagsObject.getJSONObject(i).getString("title"));
-		}
+  private static final String CONTENT_PATH = "site/api/v1/";
+  private static final String CONTENT_QUERY = CONTENT_PATH + "query";
+  private static final String CONTENT_UUID = CONTENT_PATH + "id";
+  public static final String CONTENT_AUTHORITY = CONTENT_PATH + "user";
+  public static final String CONTENT_TAG = CONTENT_PATH + "";
+
+  private Logger logger = LoggerFactory.getLogger(NuxeoClient.class);
+
+  private String protocol;
+  private Integer port;
+  private String host;
+  private String path;
+  private String username;
+  private String password;
+
+  private CloseableHttpClient httpClient;
+  private HttpClientContext httpContext;
+
+  public NuxeoClient(String protocol, String host, Integer port, String path, String username, String password)
+      throws ManifoldCFException {
+
+    this.protocol = protocol;
+    this.host = host;
+    this.port = port;
+    this.path = path;
+    this.username = username;
+    this.password = password;
+
+    connect();
+  }
+
+  private void connect() throws ManifoldCFException {
+    int socketTimeout = 900000;
+    int connectionTimeout = 60000;
+    int inactivityTimeout = 2000;
+
+    SSLSocketFactory httpsSocketFactory = KeystoreManagerFactory.getTrustingSecureSocketFactory();
+    SSLConnectionSocketFactory sslConnectionSocketFactory = new SSLConnectionSocketFactory(
+        new InterruptibleSocketFactory(httpsSocketFactory, connectionTimeout), NoopHostnameVerifier.INSTANCE);
+
+    PoolingHttpClientConnectionManager poolingHttpClientConnectionManager = new PoolingHttpClientConnectionManager(
+        RegistryBuilder.<ConnectionSocketFactory> create()
+            .register("http", PlainConnectionSocketFactory.getSocketFactory())
+            .register("https", sslConnectionSocketFactory).build());
+
+    poolingHttpClientConnectionManager.setDefaultMaxPerRoute(1);
+    poolingHttpClientConnectionManager.setValidateAfterInactivity(inactivityTimeout);
+    poolingHttpClientConnectionManager
+        .setDefaultSocketConfig(SocketConfig.custom().setTcpNoDelay(true).setSoTimeout(socketTimeout).build());
+
+    RequestConfig.Builder requestBuilder = RequestConfig.custom().setCircularRedirectsAllowed(true)
+        .setSocketTimeout(socketTimeout).setExpectContinueEnabled(true).setConnectTimeout(connectionTimeout)
+        .setConnectionRequestTimeout(socketTimeout);
+
+    httpClient = HttpClients.custom().setConnectionManager(poolingHttpClientConnectionManager)
+        .disableAutomaticRetries().setDefaultRequestConfig(requestBuilder.build())
+        .setRequestExecutor(new HttpRequestExecutor(socketTimeout))
+        .setRedirectStrategy(new DefaultRedirectStrategy()).build();
+  }
+
+  public Boolean check() throws Exception {
+    HttpResponse response;
+
+    try {
+      if (httpClient == null)
+        connect();
+
+      String url = String.format("%s://%s:%s%s/%s?pageSize=1", protocol, host, port, path, CONTENT_QUERY);
+
+      HttpGet httpGet = createGetRequest(url);
+      response = httpClient.execute(httpGet);
+      int statusCode = response.getStatusLine().getStatusCode();
+      if (statusCode != 200)
+        throw new Exception("[Checking connection] Nuxeo server appears to be down");
+      else
+        return true;
+    } catch (IOException e) {
+      throw new Exception("Nuxeo apeears to be down", e);
+    }
+  }
+
+  public boolean checkAuth() throws Exception {
+    // HttpResponse response;
+
+    // try {
+    if (httpClient == null)
+      connect();
+
+    try {
+      getUserAuthorities("Administrator");
+      return true;
+    } catch (IOException e) {
+      throw new Exception("Nuxeo apeears to be down", e);
+    }
+  }
+
+  /**
+   * @param url
+   * @return
+   */
+  private HttpGet createGetRequest(String url) {
+    String sanitizedUrl = sanitizedUrl(url);
+
+    HttpGet httpGet = new HttpGet(sanitizedUrl);
+
+    httpGet.addHeader("accepted", "application/json");
+
+    if (useBasicAuthentication())
+      httpGet.addHeader("Authorization", "Basic " + Base64.encodeBase64String(
+          String.format("%s:%s", this.username, this.password).getBytes(Charset.forName("UTF-8"))));
+
+    return httpGet;
+  }
+
+  /**
+   * @param url
+   * @return
+   */
+  private String sanitizedUrl(String url) {
+    int colonIndex = url.indexOf(":");
+
+    String urlWithoutProtocol = url.startsWith("http") ? url.substring(colonIndex + 3) : url;
+    String sanitizedUrl = urlWithoutProtocol.replace("\\/+", "/");
+    return url.substring(0, colonIndex) + "://" + sanitizedUrl;
+  }
+
+  /**
+   * @return
+   */
+  private boolean useBasicAuthentication() {
+    return this.username != null && !"".equals(this.username) && this.password != null;
+  }
+
+  /**
+   * @param lastStart
+   * @param defaultSize
+   * @param object
+   * @return
+   */
+  @SuppressWarnings("unchecked")
+  public NuxeoResponse<Document> getDocuments(List<String> domains, List<String> documentsType,
+      String lastSeedVersion, int start, int limit, Object object) throws Exception {
+
+    String url = null;
+
+    String q = createQuery(lastSeedVersion, domains, documentsType);
+    if (lastSeedVersion == null || lastSeedVersion.isEmpty())
+      url = String.format("%s://%s:%s/%s/%s?%s&pageSize=%s&currentPageIndex=%s", protocol, host, port, path,
+          CONTENT_QUERY, q, limit, start);
+    else
+      url = String.format("%s://%s:%s/%s/%s?%s&pageSize=%s&currentPageIndex=%s&queryParams=%s", protocol, host,
+          port, path, CONTENT_QUERY, q, limit, start, lastSeedVersion);
+
+    url = sanitizedUrl(url);
+
+    return (NuxeoResponse<Document>) getNuxeoResource(url, Document.builder());
+  }
+
+  public String createQuery(String lastSeedVersion, List<String> domains, List<String> documentsType) {
+    String query = "SELECT * FROM Document";
+
+    if (!domains.isEmpty() || !documentsType.isEmpty() || (lastSeedVersion != null && !lastSeedVersion.isEmpty())) {
+      query += " WHERE ";
+
+      if (lastSeedVersion != null && !lastSeedVersion.isEmpty()) {
+        query += "dc:modified > ?";
+      }
+
+      if (!domains.isEmpty()) {
+        Iterator<String> itdom = domains.iterator();
+
+        if (lastSeedVersion != null && !lastSeedVersion.isEmpty())
+          query = String.format("%s %s", query, " AND ");
+
+        query = String.format("%s ( ecm:path STARTSWITH '/%s'", query, itdom.next());
+
+        while (itdom.hasNext()) {
+          query = String.format("%s OR ecm:path STARTSWITH '/%s'", query, itdom.next());
+        }
+
+        query = String.format("%s)", query);
+      }
+
+      if (!documentsType.isEmpty()) {
+        Iterator<String> itDocTy = documentsType.iterator();
+
+        if ((lastSeedVersion != null && !lastSeedVersion.isEmpty()) || !domains.isEmpty())
+          query = String.format("%s %s", query, " AND ");
+        query = String.format("%s ( ecm:primaryType = '%s'", query, itDocTy.next());
+
+        while (itDocTy.hasNext()) {
+          query = String.format("%s OR ecm:primaryType = '%s'", query, itDocTy.next());
+        }
+
+        query = String.format("%s)", query);
+      }
+
+    }
+
+    query = URLEncoder.encode(query);
+    query = String.format("%s%s", "query=", query);
+    return query;
+  }
+
+  /**
+   * @param url
+   * @param builder
+   * @return
+   */
+  private NuxeoResponse<? extends NuxeoResource> getNuxeoResource(String url,
+      NuxeoResourceBuilder<? extends Document> builder) throws Exception {
+
+    try {
+      HttpGet httpGet = createGetRequest(url);
+      HttpResponse response = executeRequest(httpGet);
+
+      NuxeoResponse<? extends NuxeoResource> nuxeoResponse = responseFromHttpEntity(response.getEntity(),
+          builder);
+      EntityUtils.consume(response.getEntity());
+      return nuxeoResponse;
+    } catch (IOException e) {
+      throw new Exception("Nuxeo appears to be down", e);
+    }
+  }
+
+  /**
+   * @param entity
+   * @param builder
+   * @return
+   */
+  private <T extends NuxeoResource> NuxeoResponse<T> responseFromHttpEntity(HttpEntity entity,
+      NuxeoResourceBuilder<T> builder) throws Exception {
+
+    String stringEntity = EntityUtils.toString(entity);
+
+    JSONObject responseObject;
+
+    try {
+      responseObject = new JSONObject(stringEntity);
+      NuxeoResponse<T> response = NuxeoResponse.fromJson(responseObject, builder);
+
+      return response;
+    } catch (JSONException e) {
+      throw new Exception();
+    }
+  }
+
+  /**
+   * @param httpGet
+   * @return
+   */
+  private HttpResponse executeRequest(HttpUriRequest request) throws Exception {
+
+    HttpResponse response = httpClient.execute(request, httpContext);
+
+    if (response.getStatusLine().getStatusCode() != 200) {
+      throw new Exception("Nuxeo error. " + response.getStatusLine().getStatusCode() + " "
+          + response.getStatusLine().getReasonPhrase());
+    }
+    return response;
+  }
+
+  /**
+   * @param documentId
+   * @return
+   * @throws ServiceInterruption 
+   */
+  public Document getDocument(String documentId) throws ServiceInterruption {
+
+    String url = getPathDocument(documentId);
+
+    url = sanitizedUrl(url);
+
+    try {
+
+      HttpGet httpGet = createGetRequest(url);
+      httpGet.addHeader("X-NXDocumentProperties", "*");
+      HttpResponse response = executeRequest(httpGet);
+      HttpEntity entity = response.getEntity();
+      MutableDocument mDocument = documentFromHttpEmpty(entity);
+      EntityUtils.consume(entity);
+
+      return mDocument;
+    } catch (Exception e) {
+      logger.debug("Failed documentId:" + documentId,e);
+      long interruptionRetryTime = 5L * 60L * 1000L;
+      String message = "Server appears down during seeding: " + e.getMessage();
+      throw new ServiceInterruption(message, e, System.currentTimeMillis() + interruptionRetryTime,
+          -1L, 3, true);
+    }
+  }
+
+  public Acl getAcl(String documentId) {
+
+    String url = getPathDocument(documentId);
+    url += "/@acl";
+
+    url = sanitizedUrl(url);
+
+    try {
+
+      HttpGet httpGet = createGetRequest(url);
+      HttpResponse response = executeRequest(httpGet);
+      HttpEntity entity = response.getEntity();
+      MutableAcl mAcl = aclFromHttpEmpty(entity);
+      EntityUtils.consume(entity);
+
+      return mAcl;
+    } catch (Exception e) {
+    }
+
+    return new Acl();
+  }
+
+  public String getPathDocument(String documentId) {
+    return String.format("%s://%s:%s%s/%s/%s", protocol, host, port, path, CONTENT_UUID, documentId);
+  }
+
+  /**
+   * @param entity
+   * @return
+   */
+  private MutableDocument documentFromHttpEmpty(HttpEntity entity) throws Exception {
+    String stringEntity = EntityUtils.toString(entity);
+
+    JSONObject responseObject;
+
+    try {
+      responseObject = new JSONObject(stringEntity);
+
+      @SuppressWarnings("unchecked")
+      MutableDocument mDocument = ((NuxeoResourceBuilder<MutableDocument>) MutableDocument.builder())
+          .fromJson(responseObject, new MutableDocument());
+
+      return mDocument;
+    } catch (JSONException jsonException) {
+      throw new Exception("Error parsing JSON document response data");
+    }
+  }
+
+  private MutableAcl aclFromHttpEmpty(HttpEntity entity) throws Exception {
+    String stringEntity = EntityUtils.toString(entity);
+
+    JSONObject responseObject;
+
+    try {
+      responseObject = new JSONObject(stringEntity);
+
+      @SuppressWarnings("unchecked")
+      MutableAcl mAcl = ((NuxeoResourceBuilder<MutableAcl>) MutableAcl.builder()).fromJson(responseObject,
+          new MutableAcl());
+
+      return mAcl;
+    } catch (JSONException jsonException) {
+      throw new Exception("Error parsing JSON document response data");
+    }
+  }
+
+  public void close() {
+    if (httpClient != null) {
+      try {
+        httpClient.close();
+      } catch (IOException ioException) {
+        ioException.printStackTrace();
+      }
+    }
+
+  }
+
+  public List<String> getUserAuthorities(String username) throws Exception {
+    List<String> authorities = new ArrayList<String>();
+
+    String url = String.format("%s://%s:%s/%s/%s/%s", protocol, host, port, path, CONTENT_AUTHORITY, username);
+
+    url = sanitizedUrl(url);
+
+    HttpGet httpGet = createGetRequest(url);
+    HttpResponse response = executeRequest(httpGet);
+    HttpEntity entity = response.getEntity();
+    String stringEntity = EntityUtils.toString(entity);
+    EntityUtils.consume(entity);
+
+    JSONObject user = new JSONObject(stringEntity);
+    authorities.add(user.getString("id"));
+
+    JSONObject properties = user.optJSONObject("properties");
+
+    if (properties != null) {
+      JSONArray groups = properties.optJSONArray("groups");
+
+      for (int i = 0; i < groups.length(); i++) {
+        authorities.add(groups.getString(i));
+      }
+    }
+
+    return authorities;
+  }
+
+  /**
+   * @param uid
+   * @return
+   * @throws Exception
+   */
+  public String[] getTags(String uid) throws Exception {
+    List<String> tags = new ArrayList<>();
+
+    String query = "select%20*%20from%20Tagging%20where%20relation%3Asource='" + uid + "'";
+    String url = String.format("%s://%s:%s/%s/%s?query=%s", protocol, host, port, path, CONTENT_QUERY, query);
+    url = sanitizedUrl(url);
+
+    HttpGet httpGet = createGetRequest(url);
+    HttpResponse response = executeRequest(httpGet);
+    HttpEntity entity = response.getEntity();
+    String stringEntity = EntityUtils.toString(entity);
+    EntityUtils.consume(entity);
+
+    JSONArray tagsObject = new JSONObject(stringEntity).getJSONArray("entries");
+
+    for (int i = 0; i < tagsObject.length(); i++) {
+      tags.add(tagsObject.getJSONObject(i).getString("title"));
+    }
 
-		return tags.toArray(new String[tags.size()]);
-	}
+    return tags.toArray(new String[tags.size()]);
+  }
 
 }