You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@commons.apache.org by se...@apache.org on 2013/08/13 17:49:14 UTC

svn commit: r1513565 - in /commons/proper/vfs/trunk/core/src: main/java/org/apache/commons/vfs2/ main/java/org/apache/commons/vfs2/auth/ main/java/org/apache/commons/vfs2/provider/ftp/ main/java/org/apache/commons/vfs2/provider/ftps/ main/java/org/apac...

Author: sebb
Date: Tue Aug 13 15:49:14 2013
New Revision: 1513565

URL: http://svn.apache.org/r1513565
Log:
Tab police

Modified:
    commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/FileSystemConfigBuilder.java
    commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/auth/StaticUserAuthenticator.java
    commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FTPClientWrapper.java
    commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FtpClientFactory.java
    commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FtpFileSystemConfigBuilder.java
    commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsClientFactory.java
    commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsClientWrapper.java
    commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsDataChannelProtectionLevel.java
    commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsFileSystemConfigBuilder.java
    commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsMode.java
    commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/hdfs/HdfsFileSystem.java
    commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/auth/StaticUserAuthenticatorTestCase.java
    commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/AbstractFtpsProviderTestCase.java
    commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/FtpsProviderExplicitTestCase.java
    commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/FtpsProviderImplicitTestCase.java
    commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/https/test/GetContentInfoFunctionalTest.java

Modified: commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/FileSystemConfigBuilder.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/FileSystemConfigBuilder.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/FileSystemConfigBuilder.java (original)
+++ commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/FileSystemConfigBuilder.java Tue Aug 13 15:49:14 2013
@@ -230,7 +230,7 @@ public abstract class FileSystemConfigBu
     protected <E extends Enum<E>> E getEnum(final Class<E> enumClass, final FileSystemOptions opts, final String name, final E defaultValue)
     {
         @SuppressWarnings("unchecked")
-		E value = (E) getParam(opts, name);
+        E value = (E) getParam(opts, name);
         if (value == null)
         {
             final String str = getProperty(name);

Modified: commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/auth/StaticUserAuthenticator.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/auth/StaticUserAuthenticator.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/auth/StaticUserAuthenticator.java (original)
+++ commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/auth/StaticUserAuthenticator.java Tue Aug 13 15:49:14 2013
@@ -27,8 +27,8 @@ import org.apache.commons.vfs2.util.User
  */
 public class StaticUserAuthenticator implements UserAuthenticator, Comparable<StaticUserAuthenticator>
 {
-	private final static Log LOG = LogFactory.getLog(StaticUserAuthenticator.class);
-	
+    private final static Log LOG = LogFactory.getLog(StaticUserAuthenticator.class);
+
     /** The user name */
     private final String username;
 
@@ -51,27 +51,27 @@ public class StaticUserAuthenticator imp
         final UserAuthenticationData data = new UserAuthenticationData();
         for(final UserAuthenticationData.Type type : types)
         {
-        	if (type == UserAuthenticationData.DOMAIN)
-        	{
+            if (type == UserAuthenticationData.DOMAIN)
+            {
                 data.setData(UserAuthenticationData.DOMAIN, UserAuthenticatorUtils.toChar(domain));
-        	}
-        	else if (type == UserAuthenticationData.USERNAME)
-        	{
+            }
+            else if (type == UserAuthenticationData.USERNAME)
+            {
                 data.setData(UserAuthenticationData.USERNAME, UserAuthenticatorUtils.toChar(username));
-        	}
-        	else if (type == UserAuthenticationData.PASSWORD)
-        	{
+            }
+            else if (type == UserAuthenticationData.PASSWORD)
+            {
                 data.setData(UserAuthenticationData.PASSWORD, UserAuthenticatorUtils.toChar(password));
-        	}
-        	else
-        	{
-        		if (LOG.isDebugEnabled())
-        		{
+            }
+            else
+            {
+                if (LOG.isDebugEnabled())
+                {
                     LOG.debug(StaticUserAuthenticator.class.getSimpleName()
-                    	+ " does not support authentication data type '" + type 
-                    	+ "'; authentication request for this type ignored.");
-        		}
-        	}
+                        + " does not support authentication data type '" + type
+                        + "'; authentication request for this type ignored.");
+                }
+            }
         }
         return data;
     }

Modified: commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FTPClientWrapper.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FTPClientWrapper.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FTPClientWrapper.java (original)
+++ commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FTPClientWrapper.java Tue Aug 13 15:49:14 2013
@@ -74,18 +74,18 @@ public class FTPClientWrapper implements
         }
     }
 
-	protected FTPClient createClient(final GenericFileName rootName, final UserAuthenticationData authData)
-		throws FileSystemException
-	{
-		return FtpClientFactory.createConnection(
-			rootName.getHostName(),
-			rootName.getPort(),
-			UserAuthenticatorUtils.getData(
-				authData, UserAuthenticationData.USERNAME, UserAuthenticatorUtils.toChar(rootName.getUserName())),
-			UserAuthenticatorUtils.getData(
-				authData, UserAuthenticationData.PASSWORD, UserAuthenticatorUtils.toChar(rootName.getPassword())),
-			rootName.getPath(), getFileSystemOptions());
-	}
+    protected FTPClient createClient(final GenericFileName rootName, final UserAuthenticationData authData)
+        throws FileSystemException
+    {
+        return FtpClientFactory.createConnection(
+            rootName.getHostName(),
+            rootName.getPort(),
+            UserAuthenticatorUtils.getData(
+                authData, UserAuthenticationData.USERNAME, UserAuthenticatorUtils.toChar(rootName.getUserName())),
+            UserAuthenticatorUtils.getData(
+                authData, UserAuthenticationData.PASSWORD, UserAuthenticatorUtils.toChar(rootName.getPassword())),
+            rootName.getPath(), getFileSystemOptions());
+    }
 
     private FTPClient getFtpClient() throws FileSystemException
     {

Modified: commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FtpClientFactory.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FtpClientFactory.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FtpClientFactory.java (original)
+++ commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FtpClientFactory.java Tue Aug 13 15:49:14 2013
@@ -40,7 +40,7 @@ public final class FtpClientFactory
     private FtpClientFactory()
     {
     }
-    
+
     /**
      * Creates a new connection to the server.
      *
@@ -57,231 +57,231 @@ public final class FtpClientFactory
                                              final String workingDirectory, final FileSystemOptions fileSystemOptions)
         throws FileSystemException
     {
-    	final FtpConnectionFactory factory = new FtpConnectionFactory(FtpFileSystemConfigBuilder.getInstance());
-		return factory.createConnection(hostname, port, username, password, workingDirectory, fileSystemOptions);
+        final FtpConnectionFactory factory = new FtpConnectionFactory(FtpFileSystemConfigBuilder.getInstance());
+        return factory.createConnection(hostname, port, username, password, workingDirectory, fileSystemOptions);
     }
-    
+
     public static class FtpConnectionFactory extends ConnectionFactory<FTPClient, FtpFileSystemConfigBuilder> {
-		private FtpConnectionFactory(FtpFileSystemConfigBuilder builder)
-		{
-			super(builder);
-		}
-		
-		@Override
-		protected FTPClient createClient(final FileSystemOptions fileSystemOptions)
-		{
-			return new FTPClient();
-		}
-
-		@Override
-		protected void setupOpenConnection(final FTPClient client, final FileSystemOptions fileSystemOptions)
-		{
-			// nothing to do for FTP
-		}
+        private FtpConnectionFactory(FtpFileSystemConfigBuilder builder)
+        {
+            super(builder);
+        }
+
+        @Override
+        protected FTPClient createClient(final FileSystemOptions fileSystemOptions)
+        {
+            return new FTPClient();
+        }
+
+        @Override
+        protected void setupOpenConnection(final FTPClient client, final FileSystemOptions fileSystemOptions)
+        {
+            // nothing to do for FTP
+        }
     }
-    
+
     public static abstract class ConnectionFactory<C extends FTPClient, B extends FtpFileSystemConfigBuilder> {
         private static final char[] ANON_CHAR_ARRAY = "anonymous".toCharArray();
-    	private static final int BUFSZ = 40;
+        private static final int BUFSZ = 40;
 
-    	protected Log log = LogFactory.getLog(getClass());
-    	protected B builder;
+        protected Log log = LogFactory.getLog(getClass());
+        protected B builder;
 
         protected ConnectionFactory(B builder)
         {
-    		this.builder = builder;
+            this.builder = builder;
+        }
+
+        public C createConnection(final String hostname, final int port, char[] username, char[] password,
+            final String workingDirectory, final FileSystemOptions fileSystemOptions) throws FileSystemException
+        {
+            // Determine the username and password to use
+            if (username == null)
+            {
+                username = ANON_CHAR_ARRAY;
+            }
+
+            if (password == null)
+            {
+                password = ANON_CHAR_ARRAY;
+            }
+
+            try
+            {
+                final C client = createClient(fileSystemOptions);
+
+                if (log.isDebugEnabled()) {
+                    final Writer writer = new StringWriter(1024){
+                        @Override
+                        public void flush()
+                        {
+                            final StringBuffer buffer = getBuffer();
+                            String message = buffer.toString();
+                            if (message.toUpperCase().startsWith("PASS ") && message.length() > 5) {
+                                message = "PASS ***";
+                            }
+                            log.debug(message);
+                            buffer.setLength(0);
+                        }
+                    };
+                    client.addProtocolCommandListener(new PrintCommandListener(new PrintWriter(writer)));
+                }
+
+                configureClient(fileSystemOptions, client);
+
+                final FTPFileEntryParserFactory myFactory =
+                    builder.getEntryParserFactory(fileSystemOptions);
+                if (myFactory != null)
+                {
+                    client.setParserFactory(myFactory);
+                }
+
+                try
+                {
+                    // Set connect timeout
+                    final Integer connectTimeout = builder.getConnectTimeout(fileSystemOptions);
+                    if (connectTimeout != null)
+                    {
+                        client.setDefaultTimeout(connectTimeout.intValue());
+                    }
+
+                    final String controlEncoding = builder.getControlEncoding(fileSystemOptions);
+                    if (controlEncoding != null)
+                    {
+                        client.setControlEncoding(controlEncoding);
+                    }
+
+                    client.connect(hostname, port);
+
+                    final int reply = client.getReplyCode();
+                    if (!FTPReply.isPositiveCompletion(reply))
+                    {
+                        throw new FileSystemException("vfs.provider.ftp/connect-rejected.error", hostname);
+                    }
+
+                    // Login
+                    if (!client.login(
+                        UserAuthenticatorUtils.toString(username),
+                        UserAuthenticatorUtils.toString(password)))
+                    {
+                        throw new FileSystemException("vfs.provider.ftp/login.error",
+                            hostname, UserAuthenticatorUtils.toString(username));
+                    }
+
+                    FtpFileType fileType = builder.getFileType(fileSystemOptions);
+                    if (fileType == null)
+                    {
+                        fileType = FtpFileType.BINARY;
+                    }
+                    // Set binary mode
+                    if (!client.setFileType(fileType.getValue()))
+                    {
+                        throw new FileSystemException("vfs.provider.ftp/set-file-type.error", fileType);
+                    }
+
+                    // Set dataTimeout value
+                    final Integer dataTimeout = builder.getDataTimeout(fileSystemOptions);
+                    if (dataTimeout != null)
+                    {
+                        client.setDataTimeout(dataTimeout.intValue());
+                    }
+
+                    final Integer socketTimeout = builder.getSoTimeout(fileSystemOptions);
+                    if (socketTimeout != null)
+                    {
+                        client.setSoTimeout(socketTimeout.intValue());
+                    }
+
+                    // Change to root by default
+                    // All file operations a relative to the filesystem-root
+                    // String root = getRoot().getName().getPath();
+
+                    final Boolean userDirIsRoot = builder.getUserDirIsRoot(fileSystemOptions);
+                    if (workingDirectory != null && (userDirIsRoot == null || !userDirIsRoot.booleanValue()))
+                    {
+                        if (!client.changeWorkingDirectory(workingDirectory))
+                        {
+                            throw new FileSystemException("vfs.provider.ftp/change-work-directory.error", workingDirectory);
+                        }
+                    }
+
+                    final Boolean passiveMode = builder.getPassiveMode(fileSystemOptions);
+                    if (passiveMode != null && passiveMode.booleanValue())
+                    {
+                        client.enterLocalPassiveMode();
+                    }
+
+                    setupOpenConnection(client, fileSystemOptions);
+                }
+                catch (final IOException e)
+                {
+                    if (client.isConnected())
+                    {
+                        client.disconnect();
+                    }
+                    throw e;
+                }
+
+                return client;
+            }
+            catch (final Exception exc)
+            {
+                throw new FileSystemException("vfs.provider.ftp/connect.error", exc, hostname);
+            }
+        }
+
+        protected abstract C createClient(FileSystemOptions fileSystemOptions) throws FileSystemException;
+        protected abstract void setupOpenConnection(C client, FileSystemOptions fileSystemOptions) throws IOException;
+
+        private void configureClient(final FileSystemOptions fileSystemOptions, final C client)
+        {
+            final String key = builder.getEntryParser(fileSystemOptions);
+            if (key != null)
+            {
+                final FTPClientConfig config = new FTPClientConfig(key);
+
+                final String serverLanguageCode =
+                    builder.getServerLanguageCode(fileSystemOptions);
+                if (serverLanguageCode != null)
+                {
+                    config.setServerLanguageCode(serverLanguageCode);
+                }
+                final String defaultDateFormat =
+                    builder.getDefaultDateFormat(fileSystemOptions);
+                if (defaultDateFormat != null)
+                {
+                    config.setDefaultDateFormatStr(defaultDateFormat);
+                }
+                final String recentDateFormat =
+                    builder.getRecentDateFormat(fileSystemOptions);
+                if (recentDateFormat != null)
+                {
+                    config.setRecentDateFormatStr(recentDateFormat);
+                }
+                final String serverTimeZoneId =
+                    builder.getServerTimeZoneId(fileSystemOptions);
+                if (serverTimeZoneId != null)
+                {
+                    config.setServerTimeZoneId(serverTimeZoneId);
+                }
+                final String[] shortMonthNames =
+                    builder.getShortMonthNames(fileSystemOptions);
+                if (shortMonthNames != null)
+                {
+                    final StringBuilder shortMonthNamesStr = new StringBuilder(BUFSZ);
+                    for (final String shortMonthName : shortMonthNames)
+                    {
+                        if (shortMonthNamesStr.length() > 0)
+                        {
+                            shortMonthNamesStr.append("|");
+                        }
+                        shortMonthNamesStr.append(shortMonthName);
+                    }
+                    config.setShortMonthNames(shortMonthNamesStr.toString());
+                }
+
+                client.configure(config);
+            }
         }
-    	
-		public C createConnection(final String hostname, final int port, char[] username, char[] password, 
-			final String workingDirectory, final FileSystemOptions fileSystemOptions) throws FileSystemException
-		{
-	        // Determine the username and password to use
-	        if (username == null)
-	        {
-	            username = ANON_CHAR_ARRAY;
-	        }
-	
-	        if (password == null)
-	        {
-	            password = ANON_CHAR_ARRAY;
-	        }
-	
-	        try
-	        {
-	            final C client = createClient(fileSystemOptions);
-	
-	            if (log.isDebugEnabled()) {
-					final Writer writer = new StringWriter(1024){
-						@Override
-						public void flush()
-						{
-							final StringBuffer buffer = getBuffer();
-							String message = buffer.toString();
-							if (message.toUpperCase().startsWith("PASS ") && message.length() > 5) {
-								message = "PASS ***";
-							}
-							log.debug(message);
-							buffer.setLength(0);
-						}
-	            	};
-	            	client.addProtocolCommandListener(new PrintCommandListener(new PrintWriter(writer)));
-	            }
-	            
-	            configureClient(fileSystemOptions, client);
-	
-				final FTPFileEntryParserFactory myFactory =
-	                builder.getEntryParserFactory(fileSystemOptions);
-	            if (myFactory != null)
-	            {
-	                client.setParserFactory(myFactory);
-	            }
-	
-	            try
-	            {
-	                // Set connect timeout
-	                final Integer connectTimeout = builder.getConnectTimeout(fileSystemOptions);
-	                if (connectTimeout != null)
-	                {
-	                    client.setDefaultTimeout(connectTimeout.intValue());
-	                }
-	
-	                final String controlEncoding = builder.getControlEncoding(fileSystemOptions);
-	                if (controlEncoding != null)
-	                {
-	                    client.setControlEncoding(controlEncoding);
-	                }
-	
-	                client.connect(hostname, port);
-	
-	                final int reply = client.getReplyCode();
-	                if (!FTPReply.isPositiveCompletion(reply))
-	                {
-	                    throw new FileSystemException("vfs.provider.ftp/connect-rejected.error", hostname);
-	                }
-	
-	                // Login
-	                if (!client.login(
-	                    UserAuthenticatorUtils.toString(username),
-	                    UserAuthenticatorUtils.toString(password)))
-	                {
-	                    throw new FileSystemException("vfs.provider.ftp/login.error",
-	                        hostname, UserAuthenticatorUtils.toString(username));
-	                }
-	
-	                FtpFileType fileType = builder.getFileType(fileSystemOptions);
-	                if (fileType == null)
-	                {
-	                    fileType = FtpFileType.BINARY;
-	                }
-	                // Set binary mode
-	                if (!client.setFileType(fileType.getValue()))
-	                {
-	                    throw new FileSystemException("vfs.provider.ftp/set-file-type.error", fileType);
-	                }
-	
-	                // Set dataTimeout value
-	                final Integer dataTimeout = builder.getDataTimeout(fileSystemOptions);
-	                if (dataTimeout != null)
-	                {
-	                    client.setDataTimeout(dataTimeout.intValue());
-	                }
-	
-	                final Integer socketTimeout = builder.getSoTimeout(fileSystemOptions);
-	                if (socketTimeout != null)
-	                {
-	                    client.setSoTimeout(socketTimeout.intValue());
-	                }
-	
-	                // Change to root by default
-	                // All file operations a relative to the filesystem-root
-	                // String root = getRoot().getName().getPath();
-	
-	                final Boolean userDirIsRoot = builder.getUserDirIsRoot(fileSystemOptions);
-	                if (workingDirectory != null && (userDirIsRoot == null || !userDirIsRoot.booleanValue()))
-	                {
-	                    if (!client.changeWorkingDirectory(workingDirectory))
-	                    {
-	                        throw new FileSystemException("vfs.provider.ftp/change-work-directory.error", workingDirectory);
-	                    }
-	                }
-	
-	                final Boolean passiveMode = builder.getPassiveMode(fileSystemOptions);
-	                if (passiveMode != null && passiveMode.booleanValue())
-	                {
-	                    client.enterLocalPassiveMode();
-	                }
-	                
-	                setupOpenConnection(client, fileSystemOptions);
-	            }
-	            catch (final IOException e)
-	            {
-	                if (client.isConnected())
-	                {
-	                    client.disconnect();
-	                }
-	                throw e;
-	            }
-	
-	            return client;
-	        }
-	        catch (final Exception exc)
-	        {
-	            throw new FileSystemException("vfs.provider.ftp/connect.error", exc, hostname);
-	        }
-	    }
-
-		protected abstract C createClient(FileSystemOptions fileSystemOptions) throws FileSystemException;
-		protected abstract void setupOpenConnection(C client, FileSystemOptions fileSystemOptions) throws IOException;
-	
-	    private void configureClient(final FileSystemOptions fileSystemOptions, final C client)
-	    {
-			final String key = builder.getEntryParser(fileSystemOptions);
-	        if (key != null)
-	        {
-	            final FTPClientConfig config = new FTPClientConfig(key);
-	
-	            final String serverLanguageCode =
-	                builder.getServerLanguageCode(fileSystemOptions);
-	            if (serverLanguageCode != null)
-	            {
-	                config.setServerLanguageCode(serverLanguageCode);
-	            }
-	            final String defaultDateFormat =
-	                builder.getDefaultDateFormat(fileSystemOptions);
-	            if (defaultDateFormat != null)
-	            {
-	                config.setDefaultDateFormatStr(defaultDateFormat);
-	            }
-	            final String recentDateFormat =
-	                builder.getRecentDateFormat(fileSystemOptions);
-	            if (recentDateFormat != null)
-	            {
-	                config.setRecentDateFormatStr(recentDateFormat);
-	            }
-	            final String serverTimeZoneId =
-	                builder.getServerTimeZoneId(fileSystemOptions);
-	            if (serverTimeZoneId != null)
-	            {
-	                config.setServerTimeZoneId(serverTimeZoneId);
-	            }
-	            final String[] shortMonthNames =
-	                builder.getShortMonthNames(fileSystemOptions);
-	            if (shortMonthNames != null)
-	            {
-	                final StringBuilder shortMonthNamesStr = new StringBuilder(BUFSZ);
-	                for (final String shortMonthName : shortMonthNames)
-	                {
-	                    if (shortMonthNamesStr.length() > 0)
-	                    {
-	                        shortMonthNamesStr.append("|");
-	                    }
-	                    shortMonthNamesStr.append(shortMonthName);
-	                }
-	                config.setShortMonthNames(shortMonthNamesStr.toString());
-	            }
-	
-	            client.configure(config);
-	        }
-	    }
     }
 }

Modified: commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FtpFileSystemConfigBuilder.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FtpFileSystemConfigBuilder.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FtpFileSystemConfigBuilder.java (original)
+++ commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftp/FtpFileSystemConfigBuilder.java Tue Aug 13 15:49:14 2013
@@ -59,10 +59,10 @@ public class FtpFileSystemConfigBuilder 
     {
         super("ftp.");
     }
-    
+
     /** @since 2.1 */
     protected FtpFileSystemConfigBuilder(String prefix) {
-    	super(prefix);
+        super(prefix);
     }
 
     @Override

Modified: commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsClientFactory.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsClientFactory.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsClientFactory.java (original)
+++ commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsClientFactory.java Tue Aug 13 15:49:14 2013
@@ -53,58 +53,58 @@ public final class FtpsClientFactory
     public static FTPSClient createConnection(final String hostname, final int port, char[] username, char[] password,
             final String workingDirectory, final FileSystemOptions fileSystemOptions) throws FileSystemException
     {
-    	final FtpsConnectionFactory factory = new FtpsConnectionFactory(FtpsFileSystemConfigBuilder.getInstance());
-		return factory.createConnection(hostname, port, username, password, workingDirectory, fileSystemOptions);
+        final FtpsConnectionFactory factory = new FtpsConnectionFactory(FtpsFileSystemConfigBuilder.getInstance());
+        return factory.createConnection(hostname, port, username, password, workingDirectory, fileSystemOptions);
     }
-    
+
     private static final class FtpsConnectionFactory extends FtpClientFactory.ConnectionFactory<FTPSClient, FtpsFileSystemConfigBuilder> {
 
-		private FtpsConnectionFactory(final FtpsFileSystemConfigBuilder builder)
-		{
-			super(builder);
-		}
-
-		@Override
-		protected FTPSClient createClient(final FileSystemOptions fileSystemOptions) throws FileSystemException
-		{
-			final FTPSClient client;
-	        if (builder.getFtpsMode(fileSystemOptions) == FtpsMode.IMPLICIT)
-	        {
-	            client = new FTPSClient(true);
-	        }
-	        else 
-	        {
-	            client = new FTPSClient();
-	        }
-	        
-			final TrustManager trustManager = builder.getTrustManager(fileSystemOptions);
-			if (trustManager != null)
-			{
-			    client.setTrustManager(trustManager);
-			}
-			
-			final KeyManager keyManager = builder.getKeyManager(fileSystemOptions);
-			if (keyManager != null)
-			{
-			    client.setKeyManager(keyManager);
-			}
-	        return client;
-		}
-
-		@Override
-		protected void setupOpenConnection(final FTPSClient client, final FileSystemOptions fileSystemOptions)
-			throws IOException
-		{
-			final FtpsDataChannelProtectionLevel level = builder.getDataChannelProtectionLevel(fileSystemOptions);
-			if (level != null) {
-				// '0' means streaming, that's what we do!
-				try {
-					client.execPBSZ(0);
-					client.execPROT(level.name());
-				} catch (final SSLException e) {
-					throw new FileSystemException("vfs.provider.ftps/data-channel.level", e, level.toString());
-				}
-			}
-		}
+        private FtpsConnectionFactory(final FtpsFileSystemConfigBuilder builder)
+        {
+            super(builder);
+        }
+
+        @Override
+        protected FTPSClient createClient(final FileSystemOptions fileSystemOptions) throws FileSystemException
+        {
+            final FTPSClient client;
+            if (builder.getFtpsMode(fileSystemOptions) == FtpsMode.IMPLICIT)
+            {
+                client = new FTPSClient(true);
+            }
+            else
+            {
+                client = new FTPSClient();
+            }
+
+            final TrustManager trustManager = builder.getTrustManager(fileSystemOptions);
+            if (trustManager != null)
+            {
+                client.setTrustManager(trustManager);
+            }
+
+            final KeyManager keyManager = builder.getKeyManager(fileSystemOptions);
+            if (keyManager != null)
+            {
+                client.setKeyManager(keyManager);
+            }
+            return client;
+        }
+
+        @Override
+        protected void setupOpenConnection(final FTPSClient client, final FileSystemOptions fileSystemOptions)
+            throws IOException
+        {
+            final FtpsDataChannelProtectionLevel level = builder.getDataChannelProtectionLevel(fileSystemOptions);
+            if (level != null) {
+                // '0' means streaming, that's what we do!
+                try {
+                    client.execPBSZ(0);
+                    client.execPROT(level.name());
+                } catch (final SSLException e) {
+                    throw new FileSystemException("vfs.provider.ftps/data-channel.level", e, level.toString());
+                }
+            }
+        }
     }
 }

Modified: commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsClientWrapper.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsClientWrapper.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsClientWrapper.java (original)
+++ commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsClientWrapper.java Tue Aug 13 15:49:14 2013
@@ -35,20 +35,20 @@ class FtpsClientWrapper extends FTPClien
 {
     FtpsClientWrapper(final GenericFileName root, final FileSystemOptions fileSystemOptions) throws FileSystemException
     {
-    	super(root, fileSystemOptions);
+        super(root, fileSystemOptions);
     }
 
     @Override
-	protected FTPClient createClient(final GenericFileName rootName, final UserAuthenticationData authData)
-    	throws FileSystemException
+    protected FTPClient createClient(final GenericFileName rootName, final UserAuthenticationData authData)
+        throws FileSystemException
     {
-		return FtpsClientFactory.createConnection(
-			rootName.getHostName(),
-			rootName.getPort(),
-			UserAuthenticatorUtils.getData(
-				authData, UserAuthenticationData.USERNAME, UserAuthenticatorUtils.toChar(rootName.getUserName())),
-			UserAuthenticatorUtils.getData(
-				authData, UserAuthenticationData.PASSWORD, UserAuthenticatorUtils.toChar(rootName.getPassword())),
-			rootName.getPath(), getFileSystemOptions());
+        return FtpsClientFactory.createConnection(
+            rootName.getHostName(),
+            rootName.getPort(),
+            UserAuthenticatorUtils.getData(
+                authData, UserAuthenticationData.USERNAME, UserAuthenticatorUtils.toChar(rootName.getUserName())),
+            UserAuthenticatorUtils.getData(
+                authData, UserAuthenticationData.PASSWORD, UserAuthenticatorUtils.toChar(rootName.getPassword())),
+            rootName.getPath(), getFileSystemOptions());
     }
 }

Modified: commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsDataChannelProtectionLevel.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsDataChannelProtectionLevel.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsDataChannelProtectionLevel.java (original)
+++ commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsDataChannelProtectionLevel.java Tue Aug 13 15:49:14 2013
@@ -23,5 +23,5 @@ package org.apache.commons.vfs2.provider
  * @since 2.1
  */
 public enum FtpsDataChannelProtectionLevel {
-	C, S, E, P
+    C, S, E, P
 }

Modified: commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsFileSystemConfigBuilder.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsFileSystemConfigBuilder.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsFileSystemConfigBuilder.java (original)
+++ commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsFileSystemConfigBuilder.java Tue Aug 13 15:49:14 2013
@@ -83,37 +83,37 @@ public final class FtpsFileSystemConfigB
         return getEnum(FtpsMode.class, opts, FTPS_MODE, FtpsMode.EXPLICIT);
     }
 
-	/**
-	 * Set FTPS type, either "implicit" or "explicit".
-	 * <p>
-	 * Note, that implicit mode is not standardized and considered as deprecated. Some unit tests for VFS fail with
-	 * implicit mode and it is not yet clear if its a problem with Commons VFS/Commons Net or our test server Apache
-	 * FTP/SSHD.
-	 * </p>
-	 * 
-	 * @param opts The FileSystemOptions.
-	 * @param ftpsType The file type.
-	 * @see <a href="http://en.wikipedia.org/wiki/FTPS#Implicit">Wikipedia: FTPS/Implicit</a>
-	 * @deprecated As of 2.1, use {@link #setFtpsMode(FileSystemOptions, FtpsMode)}
-	 */
-	@Deprecated
-	public void setFtpsType(final FileSystemOptions opts, final String ftpsType)
-	{
-		final FtpsMode mode;
-		if (ftpsType != null)
-		{
-			mode = FtpsMode.valueOf(ftpsType.toUpperCase());
-			if (mode == null)
-			{
-				throw new IllegalArgumentException("Not a proper FTPS mode: " + ftpsType);
-			}
-		}
-		else
-		{ 
-			mode = null;
-		}
-		setFtpsMode(opts, mode);
-	}
+    /**
+     * Set FTPS type, either "implicit" or "explicit".
+     * <p>
+     * Note, that implicit mode is not standardized and considered as deprecated. Some unit tests for VFS fail with
+     * implicit mode and it is not yet clear if its a problem with Commons VFS/Commons Net or our test server Apache
+     * FTP/SSHD.
+     * </p>
+     *
+     * @param opts The FileSystemOptions.
+     * @param ftpsType The file type.
+     * @see <a href="http://en.wikipedia.org/wiki/FTPS#Implicit">Wikipedia: FTPS/Implicit</a>
+     * @deprecated As of 2.1, use {@link #setFtpsMode(FileSystemOptions, FtpsMode)}
+     */
+    @Deprecated
+    public void setFtpsType(final FileSystemOptions opts, final String ftpsType)
+    {
+        final FtpsMode mode;
+        if (ftpsType != null)
+        {
+            mode = FtpsMode.valueOf(ftpsType.toUpperCase());
+            if (mode == null)
+            {
+                throw new IllegalArgumentException("Not a proper FTPS mode: " + ftpsType);
+            }
+        }
+        else
+        {
+            mode = null;
+        }
+        setFtpsMode(opts, mode);
+    }
 
     /**
      * Return the FTPS type. Defaults to "explicit" if not defined.
@@ -121,40 +121,40 @@ public final class FtpsFileSystemConfigB
      * @param opts The FileSystemOptions.
      * @return The file type.
      * @see #setFtpsType
-	 * @deprecated As of 2.1, use {@link #getFtpsType(FileSystemOptions)}
+     * @deprecated As of 2.1, use {@link #getFtpsType(FileSystemOptions)}
      */
-	@Deprecated
+    @Deprecated
     public String getFtpsType(final FileSystemOptions opts)
     {
         return getFtpsMode(opts).name().toLowerCase();
     }
 
-	/**
-	 * Gets the data channel protection level (PROT).
-	 * 
-	 * @param opts The FileSystemOptions.
-	 * @return The PROT value.
-	 * @see org.apache.commons.net.ftp.FTPSClient#execPROT(String)
-	 * @since 2.1
-	 */
-	public FtpsDataChannelProtectionLevel getDataChannelProtectionLevel(final FileSystemOptions opts)
-	{
-		return getEnum(FtpsDataChannelProtectionLevel.class, opts, PROT);
-	}
-
-	/**
-	 * Sets the data channel protection level (PROT).
-	 * 
-	 * @param opts The FileSystemOptions.
-	 * @param prot The PROT value, {@code null} has no effect.
-	 * @see org.apache.commons.net.ftp.FTPSClient#execPROT(String)
-	 * @since 2.1
-	 */
-	public void setDataChannelProtectionLevel(final FileSystemOptions opts, final FtpsDataChannelProtectionLevel prot)
-	{
-		setParam(opts, PROT, prot);
-	}
-    
+    /**
+     * Gets the data channel protection level (PROT).
+     *
+     * @param opts The FileSystemOptions.
+     * @return The PROT value.
+     * @see org.apache.commons.net.ftp.FTPSClient#execPROT(String)
+     * @since 2.1
+     */
+    public FtpsDataChannelProtectionLevel getDataChannelProtectionLevel(final FileSystemOptions opts)
+    {
+        return getEnum(FtpsDataChannelProtectionLevel.class, opts, PROT);
+    }
+
+    /**
+     * Sets the data channel protection level (PROT).
+     *
+     * @param opts The FileSystemOptions.
+     * @param prot The PROT value, {@code null} has no effect.
+     * @see org.apache.commons.net.ftp.FTPSClient#execPROT(String)
+     * @since 2.1
+     */
+    public void setDataChannelProtectionLevel(final FileSystemOptions opts, final FtpsDataChannelProtectionLevel prot)
+    {
+        setParam(opts, PROT, prot);
+    }
+
     /**
      * Gets the KeyManager used to provide a client-side certificate if the FTPS server requests it.
      * 
@@ -167,7 +167,7 @@ public final class FtpsFileSystemConfigB
     {
         return (KeyManager)getParam(opts, KEY_MANAGER);
     }
-    
+
     /**
      * Sets the KeyManager used to provide a client-side certificate if the FTPS server requests it.
      * 
@@ -180,7 +180,7 @@ public final class FtpsFileSystemConfigB
     {
         setParam(opts, KEY_MANAGER, keyManager);
     }
-    
+
     /**
      * Gets the TrustManager that validates the FTPS server's certificate.
      * <p>
@@ -205,7 +205,7 @@ public final class FtpsFileSystemConfigB
         }
         return trustManager;
     }
-    
+
     /**
      * Sets the TrustManager that validates the FTPS server's certificate.
      * 

Modified: commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsMode.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsMode.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsMode.java (original)
+++ commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/ftps/FtpsMode.java Tue Aug 13 15:49:14 2013
@@ -28,5 +28,5 @@ package org.apache.commons.vfs2.provider
  */
 public enum FtpsMode
 {
-	IMPLICIT, EXPLICIT
+    IMPLICIT, EXPLICIT
 }

Modified: commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/hdfs/HdfsFileSystem.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/hdfs/HdfsFileSystem.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/hdfs/HdfsFileSystem.java (original)
+++ commons/proper/vfs/trunk/core/src/main/java/org/apache/commons/vfs2/provider/hdfs/HdfsFileSystem.java Tue Aug 13 15:49:14 2013
@@ -147,7 +147,7 @@ public class HdfsFileSystem extends Abst
             file = new HdfsFileObject((AbstractFileName) name, this, fs, filePath);
             if (useCache)
             {
-        	this.putFileToCache(file);
+            this.putFileToCache(file);
             }
         }
         /**

Modified: commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/auth/StaticUserAuthenticatorTestCase.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/auth/StaticUserAuthenticatorTestCase.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/auth/StaticUserAuthenticatorTestCase.java (original)
+++ commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/auth/StaticUserAuthenticatorTestCase.java Tue Aug 13 15:49:14 2013
@@ -26,30 +26,30 @@ import org.junit.Test;
 
 public class StaticUserAuthenticatorTestCase
 {
-	@Test
-	public void testAuthenticationRequest()
-	{
-		final UserAuthenticator userAuthenticator = new StaticUserAuthenticator("DOMAIN", "USER", "PWD");
-		UserAuthenticationData authenticationData =
-			userAuthenticator.requestAuthentication(ArrayUtils.toArray(UserAuthenticationData.DOMAIN));
-		assertArrayEquals("DOMAIN".toCharArray(), authenticationData.getData(UserAuthenticationData.DOMAIN));
-		assertNull(authenticationData.getData(UserAuthenticationData.USERNAME));
-		assertNull(authenticationData.getData(UserAuthenticationData.PASSWORD));
-		authenticationData = userAuthenticator.requestAuthentication(
-			ArrayUtils.toArray(UserAuthenticationData.USERNAME, UserAuthenticationData.PASSWORD));
-		assertNull(authenticationData.getData(UserAuthenticationData.DOMAIN));
-		assertArrayEquals("USER".toCharArray(), authenticationData.getData(UserAuthenticationData.USERNAME));
-		assertArrayEquals("PWD".toCharArray(), authenticationData.getData(UserAuthenticationData.PASSWORD));
-	}
-	
-	@Test
-	public void testEquality()
-	{
-		final UserAuthenticator userAuthenticator = new StaticUserAuthenticator("DOMAIN", "USER", "PWD");
-		assertEquals(new StaticUserAuthenticator("DOMAIN", "USER", "PWD"), userAuthenticator);
-		assertNotEquals(new StaticUserAuthenticator("DOMAIN", "USER", null), userAuthenticator);
-		assertNotEquals(new StaticUserAuthenticator("DOMAIN", null, "PWD"), userAuthenticator);
-		assertNotEquals(new StaticUserAuthenticator(null, "USER", "PWD"), userAuthenticator);
-		assertEquals(new StaticUserAuthenticator("DOMAIN", "USER", "PWD").hashCode(), userAuthenticator.hashCode());
-	}
+    @Test
+    public void testAuthenticationRequest()
+    {
+        final UserAuthenticator userAuthenticator = new StaticUserAuthenticator("DOMAIN", "USER", "PWD");
+        UserAuthenticationData authenticationData =
+            userAuthenticator.requestAuthentication(ArrayUtils.toArray(UserAuthenticationData.DOMAIN));
+        assertArrayEquals("DOMAIN".toCharArray(), authenticationData.getData(UserAuthenticationData.DOMAIN));
+        assertNull(authenticationData.getData(UserAuthenticationData.USERNAME));
+        assertNull(authenticationData.getData(UserAuthenticationData.PASSWORD));
+        authenticationData = userAuthenticator.requestAuthentication(
+            ArrayUtils.toArray(UserAuthenticationData.USERNAME, UserAuthenticationData.PASSWORD));
+        assertNull(authenticationData.getData(UserAuthenticationData.DOMAIN));
+        assertArrayEquals("USER".toCharArray(), authenticationData.getData(UserAuthenticationData.USERNAME));
+        assertArrayEquals("PWD".toCharArray(), authenticationData.getData(UserAuthenticationData.PASSWORD));
+    }
+
+    @Test
+    public void testEquality()
+    {
+        final UserAuthenticator userAuthenticator = new StaticUserAuthenticator("DOMAIN", "USER", "PWD");
+        assertEquals(new StaticUserAuthenticator("DOMAIN", "USER", "PWD"), userAuthenticator);
+        assertNotEquals(new StaticUserAuthenticator("DOMAIN", "USER", null), userAuthenticator);
+        assertNotEquals(new StaticUserAuthenticator("DOMAIN", null, "PWD"), userAuthenticator);
+        assertNotEquals(new StaticUserAuthenticator(null, "USER", "PWD"), userAuthenticator);
+        assertEquals(new StaticUserAuthenticator("DOMAIN", "USER", "PWD").hashCode(), userAuthenticator.hashCode());
+    }
 }

Modified: commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/AbstractFtpsProviderTestCase.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/AbstractFtpsProviderTestCase.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/AbstractFtpsProviderTestCase.java (original)
+++ commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/AbstractFtpsProviderTestCase.java Tue Aug 13 15:49:14 2013
@@ -146,29 +146,29 @@ abstract class AbstractFtpsProviderTestC
             Server = null;
         }
     }
-    
+
     static final class FtpProviderTestSuite extends ProviderTestSuite { 
-	    private boolean implicit;
-	
-		public FtpProviderTestSuite(AbstractFtpsProviderTestCase providerConfig) throws Exception
-		{
-			super(providerConfig);
-			this.implicit = providerConfig.isImplicit();
-		}
-	
-		@Override
-	    protected void setUp() throws Exception
-	    {
-	        if (getSystemTestUriOverride() == null)
-	        {
-	            setUpClass(implicit);
-	        }
-	        super.setUp();
-	    }
-	
-	    @Override
-	    protected void tearDown() throws Exception
-	    {
+        private boolean implicit;
+
+        public FtpProviderTestSuite(AbstractFtpsProviderTestCase providerConfig) throws Exception
+        {
+            super(providerConfig);
+            this.implicit = providerConfig.isImplicit();
+        }
+
+        @Override
+        protected void setUp() throws Exception
+        {
+            if (getSystemTestUriOverride() == null)
+            {
+                setUpClass(implicit);
+            }
+            super.setUp();
+        }
+
+        @Override
+        protected void tearDown() throws Exception
+        {
             try {
                 // This will report running threads of the FTP server.
                 // However, shutting down the FTP server first will always
@@ -178,9 +178,9 @@ abstract class AbstractFtpsProviderTestC
             } finally {
                 tearDownClass();
             }
-	    }
+        }
     }
-    
+
     protected abstract boolean isImplicit();
 
     /**
@@ -208,11 +208,11 @@ abstract class AbstractFtpsProviderTestC
         return fileSystemOptions;
     }
 
-	protected void setupOptions(final FtpsFileSystemConfigBuilder builder)
-	{
-		builder.setConnectTimeout(fileSystemOptions, Integer.valueOf(1000));
-		builder.setDataTimeout(fileSystemOptions, Integer.valueOf(2000));
-	}
+    protected void setupOptions(final FtpsFileSystemConfigBuilder builder)
+    {
+        builder.setConnectTimeout(fileSystemOptions, Integer.valueOf(1000));
+        builder.setDataTimeout(fileSystemOptions, Integer.valueOf(2000));
+    }
 
     /**
      * Prepares the file system manager.

Modified: commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/FtpsProviderExplicitTestCase.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/FtpsProviderExplicitTestCase.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/FtpsProviderExplicitTestCase.java (original)
+++ commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/FtpsProviderExplicitTestCase.java Tue Aug 13 15:49:14 2013
@@ -27,21 +27,21 @@ import junit.framework.Test;
  */
 public class FtpsProviderExplicitTestCase extends AbstractFtpsProviderTestCase
 {
-	@Override
-	protected boolean isImplicit()
-	{
-		return false;
-	}
+    @Override
+    protected boolean isImplicit()
+    {
+        return false;
+    }
 
-	@Override
-	protected void setupOptions(final FtpsFileSystemConfigBuilder builder)
-	{
-		super.setupOptions(builder);
-		builder.setDataChannelProtectionLevel(fileSystemOptions, FtpsDataChannelProtectionLevel.P);
-		builder.setFtpsMode(fileSystemOptions, FtpsMode.EXPLICIT);
-	}
+    @Override
+    protected void setupOptions(final FtpsFileSystemConfigBuilder builder)
+    {
+        super.setupOptions(builder);
+        builder.setDataChannelProtectionLevel(fileSystemOptions, FtpsDataChannelProtectionLevel.P);
+        builder.setFtpsMode(fileSystemOptions, FtpsMode.EXPLICIT);
+    }
 
-	/**
+    /**
      * Creates the test suite for the ftps file system.
      */
     public static Test suite() throws Exception

Modified: commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/FtpsProviderImplicitTestCase.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/FtpsProviderImplicitTestCase.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/FtpsProviderImplicitTestCase.java (original)
+++ commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/ftps/test/FtpsProviderImplicitTestCase.java Tue Aug 13 15:49:14 2013
@@ -30,20 +30,20 @@ import junit.framework.Test;
  */
 public class FtpsProviderImplicitTestCase extends AbstractFtpsProviderTestCase
 {
-	@Override
-	protected boolean isImplicit()
-	{
-		return true;
-	}
+    @Override
+    protected boolean isImplicit()
+    {
+        return true;
+    }
 
-	@Override
-	protected void setupOptions(final FtpsFileSystemConfigBuilder builder)
-	{
-		super.setupOptions(builder);
-		builder.setFtpsMode(fileSystemOptions, FtpsMode.IMPLICIT);
-	}
+    @Override
+    protected void setupOptions(final FtpsFileSystemConfigBuilder builder)
+    {
+        super.setupOptions(builder);
+        builder.setFtpsMode(fileSystemOptions, FtpsMode.IMPLICIT);
+    }
 
-	/**
+    /**
      * Creates the test suite for the ftps file system.
      */
     public static Test suite() throws Exception

Modified: commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/https/test/GetContentInfoFunctionalTest.java
URL: http://svn.apache.org/viewvc/commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/https/test/GetContentInfoFunctionalTest.java?rev=1513565&r1=1513564&r2=1513565&view=diff
==============================================================================
--- commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/https/test/GetContentInfoFunctionalTest.java (original)
+++ commons/proper/vfs/trunk/core/src/test/java/org/apache/commons/vfs2/provider/https/test/GetContentInfoFunctionalTest.java Tue Aug 13 15:49:14 2013
@@ -33,13 +33,13 @@ public class GetContentInfoFunctionalTes
     @Test
     public void testGoogle() throws FileSystemException, MalformedURLException
     {
-    	String httpsProxyHost = null;
-    	int httpsProxyPort = -1;
+        String httpsProxyHost = null;
+        int httpsProxyPort = -1;
         final String httpsProxy = System.getenv("https_proxy");
         if (httpsProxy != null) {
-        	final URL url = new URL(httpsProxy);
-        	httpsProxyHost = url.getHost();
-        	httpsProxyPort = url.getPort();
+            final URL url = new URL(httpsProxy);
+            httpsProxyHost = url.getHost();
+            httpsProxyPort = url.getPort();
         }
         final FileSystemOptions opts;
         if (httpsProxyHost != null) {
@@ -47,12 +47,12 @@ public class GetContentInfoFunctionalTes
             final HttpFileSystemConfigBuilder builder = HttpFileSystemConfigBuilder.getInstance();
             builder.setProxyHost(opts, httpsProxyHost);
             if (httpsProxyPort >= 0) {
-            	builder.setProxyPort(opts, httpsProxyPort);
+                builder.setProxyPort(opts, httpsProxyPort);
             }
         } else {
-        	opts = null;
+            opts = null;
         }
-        
+
         final FileSystemManager fsManager = VFS.getManager();
         final FileObject fo = fsManager.resolveFile("https://www.google.com/images/logos/ps_logo2.png", opts);
         final FileContent content = fo.getContent();