You are viewing a plain text version of this content. The canonical link for it is here.
Posted to cvs@httpd.apache.org by ji...@apache.org on 2011/09/23 15:42:37 UTC

svn commit: r1174758 - in /httpd/mod_ftp/trunk/modules/ftp: ftp_commands.c ftp_connection.c ftp_data_connection.c ftp_lowportd.c ftp_protocol.c ftp_util.c mod_ftp.c mod_ftp_example.c

Author: jim
Date: Fri Sep 23 13:42:36 2011
New Revision: 1174758

URL: http://svn.apache.org/viewvc?rev=1174758&view=rev
Log:
Cleanup effort in prep for GA push:
Trim trailing whitespace... no func change


Modified:
    httpd/mod_ftp/trunk/modules/ftp/ftp_commands.c
    httpd/mod_ftp/trunk/modules/ftp/ftp_connection.c
    httpd/mod_ftp/trunk/modules/ftp/ftp_data_connection.c
    httpd/mod_ftp/trunk/modules/ftp/ftp_lowportd.c
    httpd/mod_ftp/trunk/modules/ftp/ftp_protocol.c
    httpd/mod_ftp/trunk/modules/ftp/ftp_util.c
    httpd/mod_ftp/trunk/modules/ftp/mod_ftp.c
    httpd/mod_ftp/trunk/modules/ftp/mod_ftp_example.c

Modified: httpd/mod_ftp/trunk/modules/ftp/ftp_commands.c
URL: http://svn.apache.org/viewvc/httpd/mod_ftp/trunk/modules/ftp/ftp_commands.c?rev=1174758&r1=1174757&r2=1174758&view=diff
==============================================================================
--- httpd/mod_ftp/trunk/modules/ftp/ftp_commands.c (original)
+++ httpd/mod_ftp/trunk/modules/ftp/ftp_commands.c Fri Sep 23 13:42:36 2011
@@ -157,7 +157,7 @@ static int ftp_run_handler(request_rec *
 
     /*
      * XXX - JKS
-     * 
+     *
      * This will check authz for the *CURRENT* location.  For commands where the
      * URI can change, the command handler will need to rerun the auth/authz
      * checks to ensure the user also has permission for the new URI.
@@ -240,7 +240,7 @@ void ftp_cmd_finalize(apr_pool_t *pool, 
             --i;
 
         if (cmd->flags & FTP_NEW_FEAT)
-            FTPFeatText = apr_pstrcat(ptemp, FTPFeatText, CRLF " ", 
+            FTPFeatText = apr_pstrcat(ptemp, FTPFeatText, CRLF " ",
                                       cmd->key, NULL);
     }
 
@@ -306,7 +306,7 @@ int ftp_run_cmd(request_rec *r, const ch
         /*
          * Commands must have been traslated to their real equivilants back
          * in ftp_read_request_line, by the ftp_get_cmd_alias function above.
-         * 
+         *
          * Note: recursive aliases are unsupported
          */
         if (cmd->pf == NULL) {
@@ -811,7 +811,7 @@ static int common_list(request_rec *r, c
     {
         if (dirp->modestring[0] == 'd')
         {
-            if (is_list && decend) 
+            if (is_list && decend)
                 continue;
             else if (!is_list && !(fsc->options & FTP_OPT_NLSTSHOWDIRS))
                 continue;
@@ -989,7 +989,7 @@ static int ftp_cmd_mkd(request_rec *r, c
     if (rv != APR_SUCCESS) {
         char error_str[120];
         char *err = apr_strerror(rv, error_str, sizeof(error_str));
-        fc->response_notes = apr_psprintf(r->pool, FTP_MSG_PERM_DENIED, 
+        fc->response_notes = apr_psprintf(r->pool, FTP_MSG_PERM_DENIED,
                                  ftp_escape_control_text(err, r->pool));
         return FTP_REPLY_FILE_NOT_FOUND;
     }
@@ -1013,7 +1013,7 @@ static int ftp_cmd_mode(request_rec *r, 
             return FTP_REPLY_COMMAND_OK;
         }
     }
-    fc->response_notes = apr_psprintf(r->pool, "Mode %s not implemented", 
+    fc->response_notes = apr_psprintf(r->pool, "Mode %s not implemented",
                              ftp_escape_control_text(arg, r->pool));
     return FTP_REPLY_COMMAND_NOT_IMPL_PARAM;
 }
@@ -1241,14 +1241,14 @@ static int ftp_cmd_pass(request_rec *r, 
          * don't see another server in the ready state, that means we are the
          * last available server, and must send the client a message that the
          * server is full.
-         * 
+         *
          * For those wondering, there is a race condition here that could cause
          * a client to be put in the accept queue, but we should be able to
          * recover from this once a client disconnects.
-         * 
+         *
          * This has a few side effects: - We can really only service Max - 1 FTP
          * sessions concurrently.
-         * 
+         *
          * - If a hybid server is heavily loaded, such that all servers are busy
          * serving HTTP traffic, it is possible to starve FTP requests, since
          * when we check the scoreboard, all servers will be busy.
@@ -1576,7 +1576,7 @@ static int ftp_cmd_epsv(request_rec *r, 
     }
 
     apr_socket_addr_get(&sa, APR_LOCAL, fc->csock);
-    fc->response_notes = apr_psprintf(r->pool, 
+    fc->response_notes = apr_psprintf(r->pool,
                                       "Entering Extended Passive Mode (|||%u|)",
                                       sa->port);
 
@@ -1740,7 +1740,7 @@ static int get_outbound_port(apr_sockadd
         sa->sa.sin.sin_port = htons(local_port);
     }
     else {
-        /* Long way around, create a fresh sa, attempt to use 
+        /* Long way around, create a fresh sa, attempt to use
          * the original port, before falling back on the nul adapter
          * TODO: this could use a config option to specify the
          * preferred interface/local address
@@ -1864,9 +1864,9 @@ static int ftp_cmd_eprt(request_rec *r, 
      * Open data connection only if the EPRT connection is to the client's IP
      * address. All other EPRT connection requests are denied, unless
      * disabled using:
-     * 
+     *
      * FTPOptions AllowProxyPORT
-     * 
+     *
      * We must canonicalize the IP address first to compare it to our own idea
      * of the client's IP address.
      */
@@ -1921,7 +1921,7 @@ static int ftp_cmd_port(request_rec *r, 
      * Open data connection only if the PORT connection is to the client's IP
      * address. All other PORT connection requests are denied, unless
      * enabled using:
-     * 
+     *
      * FTPOptions AllowProxyPORT
      */
     if (!(fsc->options & FTP_OPT_ALLOWPROXYPORT)) {
@@ -1988,7 +1988,7 @@ static int ftp_cmd_pwd(request_rec *r, c
 {
     ftp_connection *fc = ftp_get_module_config(r->connection->conn_config);
 
-    fc->response_notes = apr_psprintf(r->pool, FTP_MSG_DIR_CUR, 
+    fc->response_notes = apr_psprintf(r->pool, FTP_MSG_DIR_CUR,
                              ftp_escape_control_text(fc->cwd, r->pool));
     return FTP_REPLY_PATH_CREATED;
 }
@@ -2061,7 +2061,7 @@ static int ftp_cmd_retr(request_rec *r, 
     ftp_reply(fc, c->output_filters, r->pool, FTP_REPLY_FILE_STATUS_OK, 0,
               apr_pstrcat(r->pool, "Opening ",
                           (fc->type == TYPE_A) ? "ASCII" : "BINARY",
-                          " mode data connection for ", 
+                          " mode data connection for ",
                           ftp_escape_control_text(arg, r->pool), NULL));
 
     if (!(cdata = ftp_open_dataconn(r, 1))) {
@@ -2155,7 +2155,7 @@ static int ftp_cmd_retr(request_rec *r, 
      * information to be lost.  Here we hack around that by setting values in
      * r->main, but in the future, we may just want to do away with running
      * the subrequest, and run the main request.
-     * 
+     *
      * There may be other values we need to save here.
      */
     rr->main->sent_bodyct = 1;
@@ -2537,7 +2537,7 @@ static int ftp_cmd_stor(request_rec *r, 
     ftp_reply(fc, c->output_filters, r->pool, FTP_REPLY_FILE_STATUS_OK, 0,
               apr_pstrcat(r->pool, "Opening ",
                           (fc->type == TYPE_A) ? "ASCII" : "BINARY",
-                          " mode data connection for ", 
+                          " mode data connection for ",
                           ftp_escape_control_text(arg, r->pool), NULL));
 
     /*
@@ -2918,7 +2918,7 @@ void ftp_register_core_cmds(apr_pool_t *
                  FTP_NEED_LOGIN | FTP_TAKE1 | FTP_EXTENSIBLE,
                  "<sp> command [ <sp> options ]");
 
-    /* Pass must be handled literally to ensure leading, trailing spaces 
+    /* Pass must be handled literally to ensure leading, trailing spaces
      * or empty string are recognized
      */
     ftp_hook_cmd("PASS", ftp_cmd_pass, FTP_HOOK_LAST,

Modified: httpd/mod_ftp/trunk/modules/ftp/ftp_connection.c
URL: http://svn.apache.org/viewvc/httpd/mod_ftp/trunk/modules/ftp/ftp_connection.c?rev=1174758&r1=1174757&r2=1174758&view=diff
==============================================================================
--- httpd/mod_ftp/trunk/modules/ftp/ftp_connection.c (original)
+++ httpd/mod_ftp/trunk/modules/ftp/ftp_connection.c Fri Sep 23 13:42:36 2011
@@ -221,7 +221,7 @@ int ftp_process_connection(conn_rec *c)
          * connection should be implicitly protected (i.e. the PBSZ 0, PROT P
          * command sequence is not required but the client and server will
          * protect the data channel as if it had).
-         * 
+         *
          * Support for Implicit SSL was declared deprecated as of
          * draft-murray-auth-ftp-ssl-07.txt, and is not documented whatsoever
          * within RFC4217.

Modified: httpd/mod_ftp/trunk/modules/ftp/ftp_data_connection.c
URL: http://svn.apache.org/viewvc/httpd/mod_ftp/trunk/modules/ftp/ftp_data_connection.c?rev=1174758&r1=1174757&r2=1174758&view=diff
==============================================================================
--- httpd/mod_ftp/trunk/modules/ftp/ftp_data_connection.c (original)
+++ httpd/mod_ftp/trunk/modules/ftp/ftp_data_connection.c Fri Sep 23 13:42:36 2011
@@ -240,7 +240,7 @@ conn_rec *ftp_open_dataconn(request_rec 
      * Open data connection only if the connection is from the client's IP
      * address. All other PASV connection attempts are denied, unless
      * disabled using:
-     * 
+     *
      * FTPOptions AllowProxyPASV
      */
     if (fc->clientsa == NULL) { /* Only check PASV, never PORT connections */
@@ -274,7 +274,7 @@ conn_rec *ftp_open_dataconn(request_rec 
          * idea of a core socket, based on our own ftp_datasock bucket,
          * instead of the socket_bucket. This will capture any abort command
          * on the control socket while actually reading from the data socket.
-         * 
+         *
          * Insert this bucket type only for read connections
          */
         for (f = cdata->input_filters; f; f = f->next) {

Modified: httpd/mod_ftp/trunk/modules/ftp/ftp_lowportd.c
URL: http://svn.apache.org/viewvc/httpd/mod_ftp/trunk/modules/ftp/ftp_lowportd.c?rev=1174758&r1=1174757&r2=1174758&view=diff
==============================================================================
--- httpd/mod_ftp/trunk/modules/ftp/ftp_lowportd.c (original)
+++ httpd/mod_ftp/trunk/modules/ftp/ftp_lowportd.c Fri Sep 23 13:42:36 2011
@@ -142,7 +142,7 @@ static int connect_to_daemon(int *sdptr,
             return errno;
         }
         if (connect(sd, (struct sockaddr *)daemon_addr, daemon_addr_len) < 0) {
-            if (errno == ECONNREFUSED 
+            if (errno == ECONNREFUSED
                     && connect_tries < DEFAULT_CONNECT_ATTEMPTS) {
                 ap_log_rerror(APLOG_MARK, APLOG_DEBUG, errno, r,
                               "connect #%d to cgi daemon failed, "
@@ -262,7 +262,7 @@ apr_status_t ftp_request_lowport(apr_soc
 #endif
     sockinfo.local = (struct sockaddr *)&sa->sa;
 
-    stat = apr_os_sock_make(sock, &sockinfo, p); 
+    stat = apr_os_sock_make(sock, &sockinfo, p);
     if (stat != APR_SUCCESS) {
         ap_log_rerror(APLOG_MARK, APLOG_DEBUG, stat, r,
                       "ftp low numbered port request; sock_make failed");

Modified: httpd/mod_ftp/trunk/modules/ftp/ftp_protocol.c
URL: http://svn.apache.org/viewvc/httpd/mod_ftp/trunk/modules/ftp/ftp_protocol.c?rev=1174758&r1=1174757&r2=1174758&view=diff
==============================================================================
--- httpd/mod_ftp/trunk/modules/ftp/ftp_protocol.c (original)
+++ httpd/mod_ftp/trunk/modules/ftp/ftp_protocol.c Fri Sep 23 13:42:36 2011
@@ -263,7 +263,7 @@ static apr_status_t ftp_read_line(char *
                 /*
                  * Return the result string, and the actual bytes read from
                  * the network (before we truncated characters)
-                 * 
+                 *
                  * We may have moved from a pool to another pool, or to a heap
                  * bucket.  Reallocate from the current pool in these cases.
                  */
@@ -503,7 +503,7 @@ request_rec *ftp_read_request(ftp_connec
     /*
      * We don't use r->uri for every request, but some modules (SSL) require
      * r->uri to not be NULL in the post_read_request hook
-     * 
+     *
      * The canonical (http) form of "Any location" is *, e.g. the http OPTIONS *
      * request.  It's not a bad pattern to keep with module author's
      * expectations.

Modified: httpd/mod_ftp/trunk/modules/ftp/ftp_util.c
URL: http://svn.apache.org/viewvc/httpd/mod_ftp/trunk/modules/ftp/ftp_util.c?rev=1174758&r1=1174757&r2=1174758&view=diff
==============================================================================
--- httpd/mod_ftp/trunk/modules/ftp/ftp_util.c (original)
+++ httpd/mod_ftp/trunk/modules/ftp/ftp_util.c Fri Sep 23 13:42:36 2011
@@ -593,10 +593,10 @@ char *ftp_toupper(apr_pool_t *p, const c
     return upper;
 }
 
-/* ftp_escape_control_text: 
+/* ftp_escape_control_text:
  *                 Expand <CR> to <CR> <IAC> <NOP> (because it is impossible to
  *                 distinguish <CR> <NUL> from end of string while retaining
- *                 multiline C strings) and a single 0xFF to <IAC> <IAC> 
+ *                 multiline C strings) and a single 0xFF to <IAC> <IAC>
  *                 as documented in RFC854 and clarified by RFC2640 and RFC3659
  *
  * Arguments: s - The string (not deliberately multiline)
@@ -633,7 +633,7 @@ FTP_DECLARE(const char *) ftp_escape_con
             d[++j] = '\xFF'; /* IAC */
     }
 
-    return d;    
+    return d;
 }
 
 /* ftp_check_maxclients: Check the scoreboard for other available servers.

Modified: httpd/mod_ftp/trunk/modules/ftp/mod_ftp.c
URL: http://svn.apache.org/viewvc/httpd/mod_ftp/trunk/modules/ftp/mod_ftp.c?rev=1174758&r1=1174757&r2=1174758&view=diff
==============================================================================
--- httpd/mod_ftp/trunk/modules/ftp/mod_ftp.c (original)
+++ httpd/mod_ftp/trunk/modules/ftp/mod_ftp.c Fri Sep 23 13:42:36 2011
@@ -40,7 +40,7 @@ static int ftp_pre_config(apr_pool_t *p,
 
     /*
      * Find the handles of non-ftp filters we will be using
-     * 
+     *
      * This must be done after register_hooks since SSL may not be loaded before
      * FTP, but before we actually process the config because we test those
      * filter handles to determine if SSL-related directives are valid.

Modified: httpd/mod_ftp/trunk/modules/ftp/mod_ftp_example.c
URL: http://svn.apache.org/viewvc/httpd/mod_ftp/trunk/modules/ftp/mod_ftp_example.c?rev=1174758&r1=1174757&r2=1174758&view=diff
==============================================================================
--- httpd/mod_ftp/trunk/modules/ftp/mod_ftp_example.c (original)
+++ httpd/mod_ftp/trunk/modules/ftp/mod_ftp_example.c Fri Sep 23 13:42:36 2011
@@ -47,7 +47,7 @@ static int mod_ftp_cmd_site(request_rec 
 
     if (!strncasecmp(arg, "PING", 4))
     {
-        for (arg += 4; *arg == ' '; ++arg) 
+        for (arg += 4; *arg == ' '; ++arg)
             /* noop */;
 
         if (*arg) {