Allow some pre-/post-xfer exec shell restrictions.
[rsync.git] / main.c
diff --git a/main.c b/main.c
index 4c040b997d8c4fa8c5bdb169ebded06a2c4ed080..99dae1c1998562b1a371cb21464016a5482c9880 100644 (file)
--- a/main.c
+++ b/main.c
@@ -4,7 +4,7 @@
  * Copyright (C) 1996-2001 Andrew Tridgell <tridge@samba.org>
  * Copyright (C) 1996 Paul Mackerras
  * Copyright (C) 2001, 2002 Martin Pool <mbp@samba.org>
- * Copyright (C) 2003-2007 Wayne Davison
+ * Copyright (C) 2003-2018 Wayne Davison
  *
  * This program is free software; you can redistribute it and/or modify
  * it under the terms of the GNU General Public License as published by
  */
 
 #include "rsync.h"
-#include "ifuncs.h"
+#include "inums.h"
 #include "io.h"
 #if defined CONFIG_LOCALE && defined HAVE_LOCALE_H
 #include <locale.h>
 #endif
 
-extern int verbose;
 extern int dry_run;
 extern int list_only;
+extern int io_timeout;
 extern int am_root;
 extern int am_server;
 extern int am_sender;
-extern int am_generator;
 extern int am_daemon;
 extern int inc_recurse;
 extern int blocking_io;
+extern int always_checksum;
 extern int remove_source_files;
+extern int output_needs_newline;
 extern int need_messages_from_generator;
 extern int kluge_around_eof;
-extern int do_stats;
 extern int got_xfer_error;
+extern int msgs2stderr;
 extern int module_id;
+extern int read_only;
 extern int copy_links;
 extern int copy_dirlinks;
+extern int copy_unsafe_links;
 extern int keep_dirlinks;
 extern int preserve_hard_links;
 extern int protocol_version;
@@ -62,27 +65,45 @@ extern int whole_file;
 extern int read_batch;
 extern int write_batch;
 extern int batch_fd;
+extern int sock_f_in;
+extern int sock_f_out;
 extern int filesfrom_fd;
+extern int connect_timeout;
+extern int send_msgs_to_gen;
+extern dev_t filesystem_dev;
 extern pid_t cleanup_child_pid;
+extern size_t bwlimit_writemax;
+extern unsigned int module_dirlen;
+extern BOOL flist_receiving_enabled;
+extern BOOL shutting_down;
+extern int backup_dir_len;
+extern int basis_dir_cnt;
 extern struct stats stats;
+extern char *stdout_format;
+extern char *logfile_format;
 extern char *filesfrom_host;
 extern char *partial_dir;
-extern char *basis_dir[];
+extern char *dest_option;
 extern char *rsync_path;
 extern char *shell_cmd;
 extern char *batch_name;
 extern char *password_file;
+extern char *backup_dir;
 extern char curr_dir[MAXPATHLEN];
+extern char backup_dir_buf[MAXPATHLEN];
+extern char *basis_dir[MAX_BASIS_DIRS+1];
 extern struct file_list *first_flist;
-extern struct filter_list_struct server_filter_list;
-#ifdef ICONV_OPTION
-extern iconv_t ic_send;
-#endif
+extern filter_rule_list daemon_filter_list;
 
+uid_t our_uid;
+gid_t our_gid;
+int am_receiver = 0;  /* Only set to 1 after the receiver/generator fork. */
+int am_generator = 0; /* Only set to 1 after the receiver/generator fork. */
 int local_server = 0;
 int daemon_over_rsh = 0;
 mode_t orig_umask = 0;
 int batch_gen_fd = -1;
+int sender_keeps_checksum = 0;
 
 /* There's probably never more than at most 2 outstanding child processes,
  * but set it higher, just in case. */
@@ -112,7 +133,7 @@ static void show_malloc_stats(void);
 pid_t wait_process(pid_t pid, int *status_ptr, int flags)
 {
        pid_t waited_pid;
-       
+
        do {
                waited_pid = waitpid(pid, status_ptr, flags);
        } while (waited_pid == -1 && errno == EINTR);
@@ -133,6 +154,27 @@ pid_t wait_process(pid_t pid, int *status_ptr, int flags)
        return waited_pid;
 }
 
+int shell_exec(const char *cmd)
+{
+       char *shell = getenv("RSYNC_SHELL");
+       int status;
+       pid_t pid;
+
+       if (!shell)
+               return system(cmd);
+
+       if ((pid = fork()) < 0)
+               return -1;
+
+       if (pid == 0) {
+               execlp(shell, shell, "-c", cmd, NULL);
+               _exit(1);
+       }
+
+       int ret = wait_process(pid, &status, 0);
+       return ret < 0 ? -1 : status;
+}
+
 /* Wait for a process to exit, calling io_flush while waiting. */
 static void wait_process_with_flush(pid_t pid, int *exit_code_ptr)
 {
@@ -165,6 +207,30 @@ static void wait_process_with_flush(pid_t pid, int *exit_code_ptr)
                *exit_code_ptr = WEXITSTATUS(status);
 }
 
+void write_del_stats(int f)
+{
+       if (read_batch)
+               write_int(f, NDX_DEL_STATS);
+       else
+               write_ndx(f, NDX_DEL_STATS);
+       write_varint(f, stats.deleted_files - stats.deleted_dirs
+                     - stats.deleted_symlinks - stats.deleted_devices
+                     - stats.deleted_specials);
+       write_varint(f, stats.deleted_dirs);
+       write_varint(f, stats.deleted_symlinks);
+       write_varint(f, stats.deleted_devices);
+       write_varint(f, stats.deleted_specials);
+}
+
+void read_del_stats(int f)
+{
+       stats.deleted_files = read_varint(f);
+       stats.deleted_files += stats.deleted_dirs = read_varint(f);
+       stats.deleted_files += stats.deleted_symlinks = read_varint(f);
+       stats.deleted_files += stats.deleted_devices = read_varint(f);
+       stats.deleted_files += stats.deleted_specials = read_varint(f);
+}
+
 /* This function gets called from all 3 processes.  We want the client side
  * to actually output the text, but the sender is the only process that has
  * all the stats we need.  So, if we're a client sender, we do the report.
@@ -181,7 +247,7 @@ static void handle_stats(int f)
        total_read = stats.total_read;
        total_written = stats.total_written;
 
-       if (do_stats && verbose > 1) {
+       if (INFO_GTE(STATS, 3)) {
                /* These come out from every process */
                show_malloc_stats();
                show_flist_stats();
@@ -235,13 +301,46 @@ static void handle_stats(int f)
        }
 }
 
+static void output_itemized_counts(const char *prefix, int *counts)
+{
+       static char *labels[] = { "reg", "dir", "link", "dev", "special" };
+       char buf[1024], *pre = " (";
+       int j, len = 0;
+       int total = counts[0];
+       if (total) {
+               counts[0] -= counts[1] + counts[2] + counts[3] + counts[4];
+               for (j = 0; j < 5; j++) {
+                       if (counts[j]) {
+                               len += snprintf(buf+len, sizeof buf - len - 2,
+                                       "%s%s: %s",
+                                       pre, labels[j], comma_num(counts[j]));
+                               pre = ", ";
+                       }
+               }
+               buf[len++] = ')';
+       }
+       buf[len] = '\0';
+       rprintf(FINFO, "%s: %s%s\n", prefix, comma_num(total), buf);
+}
+
+static const char *bytes_per_sec_human_dnum(void)
+{
+       if (starttime == (time_t)-1 || endtime == (time_t)-1)
+               return "UNKNOWN";
+       return human_dnum((total_written + total_read) / (0.5 + (endtime - starttime)), 2);
+}
+
 static void output_summary(void)
 {
-       if (do_stats) {
+       if (INFO_GTE(STATS, 2)) {
                rprintf(FCLIENT, "\n");
-               rprintf(FINFO,"Number of files: %d\n", stats.num_files);
-               rprintf(FINFO,"Number of files transferred: %d\n",
-                       stats.num_transferred_files);
+               output_itemized_counts("Number of files", &stats.num_files);
+               if (protocol_version >= 29)
+                       output_itemized_counts("Number of created files", &stats.created_files);
+               if (protocol_version >= 31)
+                       output_itemized_counts("Number of deleted files", &stats.deleted_files);
+               rprintf(FINFO,"Number of regular files transferred: %s\n",
+                       comma_num(stats.xferred_files));
                rprintf(FINFO,"Total file size: %s bytes\n",
                        human_num(stats.total_size));
                rprintf(FINFO,"Total transferred file size: %s bytes\n",
@@ -254,11 +353,11 @@ static void output_summary(void)
                        human_num(stats.flist_size));
                if (stats.flist_buildtime) {
                        rprintf(FINFO,
-                               "File list generation time: %.3f seconds\n",
-                               (double)stats.flist_buildtime / 1000);
+                               "File list generation time: %s seconds\n",
+                               comma_dnum((double)stats.flist_buildtime / 1000, 3));
                        rprintf(FINFO,
-                               "File list transfer time: %.3f seconds\n",
-                               (double)stats.flist_xfertime / 1000);
+                               "File list transfer time: %s seconds\n",
+                               comma_dnum((double)stats.flist_xfertime / 1000, 3));
                }
                rprintf(FINFO,"Total bytes sent: %s\n",
                        human_num(total_written));
@@ -266,16 +365,16 @@ static void output_summary(void)
                        human_num(total_read));
        }
 
-       if (verbose || do_stats) {
+       if (INFO_GTE(STATS, 1)) {
                rprintf(FCLIENT, "\n");
                rprintf(FINFO,
                        "sent %s bytes  received %s bytes  %s bytes/sec\n",
                        human_num(total_written), human_num(total_read),
-                       human_dnum((total_written + total_read)/(0.5 + (endtime - starttime)), 2));
-               rprintf(FINFO, "total size is %s  speedup is %.2f%s\n",
+                       bytes_per_sec_human_dnum());
+               rprintf(FINFO, "total size is %s  speedup is %s%s\n",
                        human_num(stats.total_size),
-                       (double)stats.total_size / (total_written+total_read),
-                       dry_run ? " (DRY RUN)" : "");
+                       comma_dnum((double)stats.total_size / (total_written+total_read), 2),
+                       write_batch < 0 ? " (BATCH ONLY)" : dry_run ? " (DRY RUN)" : "");
        }
 
        fflush(stdout);
@@ -295,7 +394,7 @@ static void show_malloc_stats(void)
 
        rprintf(FCLIENT, "\n");
        rprintf(FINFO, RSYNC_NAME "[%d] (%s%s%s) heap statistics:\n",
-               getpid(), am_server ? "server " : "",
+               (int)getpid(), am_server ? "server " : "",
                am_daemon ? "daemon " : "", who_am_i());
        rprintf(FINFO, "  arena:     %10ld   (bytes from sbrk)\n",
                (long)mi.arena);
@@ -328,9 +427,8 @@ static pid_t do_cmd(char *cmd, char *machine, char *user, char **remote_argv, in
                    int *f_in_p, int *f_out_p)
 {
        int i, argc = 0;
-       char *args[MAX_ARGS];
-       pid_t ret;
-       char *dir = NULL;
+       char *args[MAX_ARGS], *need_to_free = NULL;
+       pid_t pid;
        int dash_l_set = 0;
 
        if (!read_batch && !local_server) {
@@ -340,7 +438,7 @@ static pid_t do_cmd(char *cmd, char *machine, char *user, char **remote_argv, in
                        cmd = rsh_env;
                if (!cmd)
                        cmd = RSYNC_RSH;
-               cmd = strdup(cmd);
+               cmd = need_to_free = strdup(cmd);
                if (!cmd)
                        goto oom;
 
@@ -426,14 +524,18 @@ static pid_t do_cmd(char *cmd, char *machine, char *user, char **remote_argv, in
                                rprintf(FERROR, "internal: args[] overflowed in do_cmd()\n");
                                exit_cleanup(RERR_SYNTAX);
                        }
-                       args[argc++] = *remote_argv++;
+                       if (**remote_argv == '-') {
+                               if (asprintf(args + argc++, "./%s", *remote_argv++) < 0)
+                                       out_of_memory("do_cmd");
+                       } else
+                               args[argc++] = *remote_argv++;
                        remote_argc--;
                }
        }
 
        args[argc] = NULL;
 
-       if (verbose > 3) {
+       if (DEBUG_GTE(CMD, 2)) {
                for (i = 0; i < argc; i++)
                        rprintf(FCLIENT, "cmd[%d]=%s ", i, args[i]);
                rprintf(FCLIENT, "\n");
@@ -449,7 +551,7 @@ static pid_t do_cmd(char *cmd, char *machine, char *user, char **remote_argv, in
                batch_gen_fd = from_gen_pipe[0];
                *f_out_p = from_gen_pipe[1];
                *f_in_p = batch_fd;
-               ret = -1; /* no child pid */
+               pid = (pid_t)-1; /* no child pid */
 #ifdef ICONV_CONST
                setup_iconv();
 #endif
@@ -459,57 +561,23 @@ static pid_t do_cmd(char *cmd, char *machine, char *user, char **remote_argv, in
                if (whole_file < 0 && !write_batch)
                        whole_file = 1;
                set_allow_inc_recurse();
-               ret = local_child(argc, args, f_in_p, f_out_p, child_main);
+               pid = local_child(argc, args, f_in_p, f_out_p, child_main);
 #ifdef ICONV_CONST
                setup_iconv();
 #endif
        } else {
+               pid = piped_child(args, f_in_p, f_out_p);
 #ifdef ICONV_CONST
                setup_iconv();
 #endif
-               if (protect_args) {
-                       int fd;
-#ifdef ICONV_OPTION
-                       int convert = ic_send != (iconv_t)-1;
-                       xbuf outbuf, inbuf;
-
-                       if (convert)
-                               alloc_xbuf(&outbuf, 1024);
-#endif
-
-                       ret = piped_child(args, f_in_p, f_out_p);
-
-                       for (i = 0; args[i]; i++) {} /* find first NULL */
-                       args[i] = "rsync"; /* set a new arg0 */
-                       if (verbose > 1)
-                               print_child_argv("protected args:", args + i + 1);
-                       fd = *f_out_p;
-                       do {
-#ifdef ICONV_OPTION
-                               if (convert) {
-                                       INIT_XBUF_STRLEN(inbuf, args[i]);
-                                       iconvbufs(ic_send, &inbuf, &outbuf,
-                                                 ICB_EXPAND_OUT | ICB_INCLUDE_BAD | ICB_INCLUDE_INCOMPLETE);
-                                       outbuf.buf[outbuf.len] = '\0';
-                                       write_buf(fd, outbuf.buf, outbuf.len + 1);
-                                       outbuf.len = 0;
-                               } else
-#endif
-                                       write_buf(fd, args[i], strlen(args[i]) + 1);
-                       } while (args[++i]);
-                       write_byte(fd, 0);
-#ifdef ICONV_OPTION
-                       if (convert)
-                               free(outbuf.buf);
-#endif
-               } else
-                       ret = piped_child(args, f_in_p, f_out_p);
+               if (protect_args && !daemon_over_rsh)
+                       send_protected_args(*f_out_p, args);
        }
 
-       if (dir)
-               free(dir);
+       if (need_to_free)
+               free(need_to_free);
 
-       return ret;
+       return pid;
 
   oom:
        out_of_memory("do_cmd");
@@ -535,7 +603,7 @@ static char *get_local_name(struct file_list *flist, char *dest_path)
        int statret;
        char *cp;
 
-       if (verbose > 2) {
+       if (DEBUG_GTE(RECV, 1)) {
                rprintf(FINFO, "get_local_name count=%d %s\n",
                        file_total, NS(dest_path));
        }
@@ -543,15 +611,37 @@ static char *get_local_name(struct file_list *flist, char *dest_path)
        if (!dest_path || list_only)
                return NULL;
 
+       /* Treat an empty string as a copy into the current directory. */
+       if (!*dest_path)
+           dest_path = ".";
+
+       if (daemon_filter_list.head) {
+               char *slash = strrchr(dest_path, '/');
+               if (slash && (slash[1] == '\0' || (slash[1] == '.' && slash[2] == '\0')))
+                       *slash = '\0';
+               else
+                       slash = NULL;
+               if ((*dest_path != '.' || dest_path[1] != '\0')
+                && (check_filter(&daemon_filter_list, FLOG, dest_path, 0) < 0
+                 || check_filter(&daemon_filter_list, FLOG, dest_path, 1) < 0)) {
+                       rprintf(FERROR, "ERROR: daemon has excluded destination \"%s\"\n",
+                               dest_path);
+                       exit_cleanup(RERR_FILESELECT);
+               }
+               if (slash)
+                       *slash = '/';
+       }
+
        /* See what currently exists at the destination. */
        if ((statret = do_stat(dest_path, &st)) == 0) {
                /* If the destination is a dir, enter it and use mode 1. */
                if (S_ISDIR(st.st_mode)) {
-                       if (!push_dir(dest_path, 0)) {
-                               rsyserr(FERROR, errno, "push_dir#1 %s failed",
+                       if (!change_dir(dest_path, CD_NORMAL)) {
+                               rsyserr(FERROR, errno, "change_dir#1 %s failed",
                                        full_fname(dest_path));
                                exit_cleanup(RERR_FILESELECT);
                        }
+                       filesystem_dev = st.st_dev; /* ensures --force works right w/-x */
                        return NULL;
                }
                if (file_total > 1) {
@@ -589,7 +679,7 @@ static char *get_local_name(struct file_list *flist, char *dest_path)
                        exit_cleanup(RERR_SYNTAX);
                }
 
-               if (mkdir_defmode(dest_path) != 0) {
+               if (do_mkdir(dest_path, ACCESSPERMS) != 0) {
                        rsyserr(FERROR, errno, "mkdir %s failed",
                                full_fname(dest_path));
                        exit_cleanup(RERR_FILEIO);
@@ -599,7 +689,7 @@ static char *get_local_name(struct file_list *flist, char *dest_path)
                 && strcmp(flist->files[flist->low]->basename, ".") == 0)
                        flist->files[0]->flags |= FLAG_DIR_CREATED;
 
-               if (verbose)
+               if (INFO_GTE(NAME, 1))
                        rprintf(FINFO, "created directory %s\n", dest_path);
 
                if (dry_run) {
@@ -607,8 +697,8 @@ static char *get_local_name(struct file_list *flist, char *dest_path)
                        dry_run++;
                }
 
-               if (!push_dir(dest_path, dry_run > 1)) {
-                       rsyserr(FERROR, errno, "push_dir#2 %s failed",
+               if (!change_dir(dest_path, dry_run > 1 ? CD_SKIP_CHDIR : CD_NORMAL)) {
+                       rsyserr(FERROR, errno, "change_dir#2 %s failed",
                                full_fname(dest_path));
                        exit_cleanup(RERR_FILESELECT);
                }
@@ -627,8 +717,8 @@ static char *get_local_name(struct file_list *flist, char *dest_path)
                dest_path = "/";
 
        *cp = '\0';
-       if (!push_dir(dest_path, 0)) {
-               rsyserr(FERROR, errno, "push_dir#3 %s failed",
+       if (!change_dir(dest_path, CD_NORMAL)) {
+               rsyserr(FERROR, errno, "change_dir#3 %s failed",
                        full_fname(dest_path));
                exit_cleanup(RERR_FILESELECT);
        }
@@ -637,51 +727,71 @@ static char *get_local_name(struct file_list *flist, char *dest_path)
        return cp + 1;
 }
 
-/* Call this if the destination dir (which is assumed to be in curr_dir)
- * does not yet exist and we can't create it due to being in dry-run
- * mode.  We'll fix dirs that can be relative to the non-existent dir. */
-static void fix_basis_dirs(void)
+/* This function checks on our alternate-basis directories.  If we're in
+ * dry-run mode and the destination dir does not yet exist, we'll try to
+ * tweak any dest-relative paths to make them work for a dry-run (the
+ * destination dir must be in curr_dir[] when this function is called).
+ * We also warn about any arg that is non-existent or not a directory. */
+static void check_alt_basis_dirs(void)
 {
-       char **dir, *new, *slash;
-       int len;
-
-       if (dry_run <= 1)
-               return;
-
-       slash = strrchr(curr_dir, '/');
-
-       for (dir = basis_dir; *dir; dir++) {
-               if (**dir == '/')
-                       continue;
-               len = curr_dir_len + 1 + strlen(*dir) + 1;
-               if (!(new = new_array(char, len)))
-                       out_of_memory("fix_basis_dirs");
-               if (slash && strncmp(*dir, "../", 3) == 0) {
-                   /* We want to remove only one leading "../" prefix for
-                    * the directory we couldn't create in dry-run mode:
-                    * this ensures that any other ".." references get
-                    * evaluated the same as they would for a live copy. */
-                   *slash = '\0';
-                   pathjoin(new, len, curr_dir, *dir + 3);
-                   *slash = '/';
-               } else
-                   pathjoin(new, len, curr_dir, *dir);
-               *dir = new;
+       STRUCT_STAT st;
+       char *slash = strrchr(curr_dir, '/');
+       int j;
+
+       for (j = 0; j < basis_dir_cnt; j++) {
+               char *bdir = basis_dir[j];
+               int bd_len = strlen(bdir);
+               if (bd_len > 1 && bdir[bd_len-1] == '/')
+                       bdir[--bd_len] = '\0';
+               if (dry_run > 1 && *bdir != '/') {
+                       int len = curr_dir_len + 1 + bd_len + 1;
+                       char *new = new_array(char, len);
+                       if (!new)
+                               out_of_memory("check_alt_basis_dirs");
+                       if (slash && strncmp(bdir, "../", 3) == 0) {
+                           /* We want to remove only one leading "../" prefix for
+                            * the directory we couldn't create in dry-run mode:
+                            * this ensures that any other ".." references get
+                            * evaluated the same as they would for a live copy. */
+                           *slash = '\0';
+                           pathjoin(new, len, curr_dir, bdir + 3);
+                           *slash = '/';
+                       } else
+                           pathjoin(new, len, curr_dir, bdir);
+                       basis_dir[j] = bdir = new;
+               }
+               if (do_stat(bdir, &st) < 0)
+                       rprintf(FWARNING, "%s arg does not exist: %s\n", dest_option, bdir);
+               else if (!S_ISDIR(st.st_mode))
+                       rprintf(FWARNING, "%s arg is not a dir: %s\n", dest_option, bdir);
        }
 }
 
 /* This is only called by the sender. */
-static void read_final_goodbye(int f_in)
+static void read_final_goodbye(int f_in, int f_out)
 {
        int i, iflags, xlen;
        uchar fnamecmp_type;
        char xname[MAXPATHLEN];
 
+       shutting_down = True;
+
        if (protocol_version < 29)
                i = read_int(f_in);
        else {
-               i = read_ndx_and_attrs(f_in, &iflags, &fnamecmp_type,
-                                      xname, &xlen);
+               i = read_ndx_and_attrs(f_in, f_out, &iflags, &fnamecmp_type, xname, &xlen);
+               if (protocol_version >= 31 && i == NDX_DONE) {
+                       if (am_sender)
+                               write_ndx(f_out, NDX_DONE);
+                       else {
+                               if (batch_gen_fd >= 0) {
+                                       while (read_int(batch_gen_fd) != NDX_DEL_STATS) {}
+                                       read_del_stats(batch_gen_fd);
+                               }
+                               write_int(f_out, NDX_DONE);
+                       }
+                       i = read_ndx_and_attrs(f_in, f_out, &iflags, &fnamecmp_type, xname, &xlen);
+               }
        }
 
        if (i != NDX_DONE) {
@@ -694,29 +804,30 @@ static void read_final_goodbye(int f_in)
 static void do_server_sender(int f_in, int f_out, int argc, char *argv[])
 {
        struct file_list *flist;
-       char *dir = argv[0];
+       char *dir;
 
-       if (verbose > 2) {
-               rprintf(FINFO, "server_sender starting pid=%ld\n",
-                       (long)getpid());
-       }
+       if (DEBUG_GTE(SEND, 1))
+               rprintf(FINFO, "server_sender starting pid=%d\n", (int)getpid());
 
        if (am_daemon && lp_write_only(module_id)) {
                rprintf(FERROR, "ERROR: module is write only\n");
                exit_cleanup(RERR_SYNTAX);
-               return;
        }
-       if (am_daemon && lp_read_only(module_id) && remove_source_files) {
+       if (am_daemon && read_only && remove_source_files) {
                rprintf(FERROR,
-                   "ERROR: --remove-%s-files cannot be used with a read-only module\n",
-                   remove_source_files == 1 ? "source" : "sent");
+                       "ERROR: --remove-%s-files cannot be used with a read-only module\n",
+                       remove_source_files == 1 ? "source" : "sent");
+               exit_cleanup(RERR_SYNTAX);
+       }
+       if (argc < 1) {
+               rprintf(FERROR, "ERROR: do_server_sender called without args\n");
                exit_cleanup(RERR_SYNTAX);
-               return;
        }
 
+       dir = argv[0];
        if (!relative_paths) {
-               if (!push_dir(dir, 0)) {
-                       rsyserr(FERROR, errno, "push_dir#3 %s failed",
+               if (!change_dir(dir, CD_NORMAL)) {
+                       rsyserr(FERROR, errno, "change_dir#3 %s failed",
                                full_fname(dir));
                        exit_cleanup(RERR_FILESELECT);
                }
@@ -731,8 +842,12 @@ static void do_server_sender(int f_in, int f_out, int argc, char *argv[])
        }
 
        flist = send_file_list(f_out,argc,argv);
-       if (!flist || flist->used == 0)
+       if (!flist || flist->used == 0) {
+               /* Make sure input buffering is off so we can't hang in noop_io_until_death(). */
+               io_end_buffering_in(0);
+               /* TODO:  we should really exit in a more controlled manner. */
                exit_cleanup(0);
+       }
 
        io_start_buffering_in(f_in);
 
@@ -740,7 +855,7 @@ static void do_server_sender(int f_in, int f_out, int argc, char *argv[])
        io_flush(FULL_FLUSH);
        handle_stats(f_out);
        if (protocol_version >= 24)
-               read_final_goodbye(f_in);
+               read_final_goodbye(f_in, f_out);
        io_flush(FULL_FLUSH);
        exit_cleanup(0);
 }
@@ -754,7 +869,7 @@ static int do_recv(int f_in, int f_out, char *local_name)
 
        /* The receiving side mustn't obey this, or an existing symlink that
         * points to an identical file won't be replaced by the referent. */
-       copy_links = copy_dirlinks = 0;
+       copy_links = copy_dirlinks = copy_unsafe_links = 0;
 
 #ifdef SUPPORT_HARD_LINKS
        if (preserve_hard_links && !inc_recurse)
@@ -766,7 +881,30 @@ static int do_recv(int f_in, int f_out, char *local_name)
                exit_cleanup(RERR_IPC);
        }
 
-       io_flush(NORMAL_FLUSH);
+       if (backup_dir) {
+               STRUCT_STAT st;
+               int ret;
+               if (backup_dir_len > 1)
+                       backup_dir_buf[backup_dir_len-1] = '\0';
+               ret = do_stat(backup_dir_buf, &st);
+               if (ret != 0 || !S_ISDIR(st.st_mode)) {
+                       if (ret == 0) {
+                               rprintf(FERROR, "The backup-dir is not a directory: %s\n", backup_dir_buf);
+                               exit_cleanup(RERR_SYNTAX);
+                       }
+                       if (errno != ENOENT) {
+                               rprintf(FERROR, "Failed to stat %s: %s\n", backup_dir_buf, strerror(errno));
+                               exit_cleanup(RERR_FILEIO);
+                       }
+                       if (INFO_GTE(BACKUP, 1))
+                               rprintf(FINFO, "(new) backup_dir is %s\n", backup_dir_buf);
+               } else if (INFO_GTE(BACKUP, 1))
+                       rprintf(FINFO, "backup_dir is %s\n", backup_dir_buf);
+               if (backup_dir_len > 1)
+                       backup_dir_buf[backup_dir_len-1] = '/';
+       }
+
+       io_flush(FULL_FLUSH);
 
        if ((pid = do_fork()) == -1) {
                rsyserr(FERROR, errno, "fork failed in do_recv");
@@ -774,37 +912,44 @@ static int do_recv(int f_in, int f_out, char *local_name)
        }
 
        if (pid == 0) {
+               am_receiver = 1;
+               send_msgs_to_gen = am_server;
+
                close(error_pipe[0]);
+
+               /* We can't let two processes write to the socket at one time. */
+               io_end_multiplex_out(MPLX_SWITCHING);
                if (f_in != f_out)
                        close(f_out);
+               sock_f_out = -1;
+               f_out = error_pipe[1];
 
-               /* we can't let two processes write to the socket at one time */
-               io_end_multiplex_out();
+               bwlimit_writemax = 0; /* receiver doesn't need to do this */
 
-               /* set place to send errors */
-               set_msg_fd_out(error_pipe[1]);
-               io_start_buffering_out(error_pipe[1]);
+               if (read_batch)
+                       io_start_buffering_in(f_in);
+               io_start_multiplex_out(f_out);
 
-               recv_files(f_in, local_name);
+               recv_files(f_in, f_out, local_name);
                io_flush(FULL_FLUSH);
                handle_stats(f_in);
 
-               send_msg(MSG_DONE, "", 1, 0);
-               write_varlong(error_pipe[1], stats.total_read, 3);
+               if (output_needs_newline) {
+                       fputc('\n', stdout);
+                       output_needs_newline = 0;
+               }
+
+               write_int(f_out, NDX_DONE);
+               send_msg(MSG_STATS, (char*)&stats.total_read, sizeof stats.total_read, 0);
                io_flush(FULL_FLUSH);
 
                /* Handle any keep-alive packets from the post-processing work
                 * that the generator does. */
                if (protocol_version >= 29) {
-                       int iflags, xlen;
-                       uchar fnamecmp_type;
-                       char xname[MAXPATHLEN];
-
                        kluge_around_eof = -1;
 
                        /* This should only get stopped via a USR2 signal. */
-                       read_ndx_and_attrs(f_in, &iflags, &fnamecmp_type,
-                                          xname, &xlen);
+                       read_final_goodbye(f_in, f_out);
 
                        rprintf(FERROR, "Invalid packet at end of run [%s]\n",
                                who_am_i());
@@ -819,19 +964,20 @@ static int do_recv(int f_in, int f_out, char *local_name)
        }
 
        am_generator = 1;
+       flist_receiving_enabled = True;
 
-       io_end_multiplex_in();
+       io_end_multiplex_in(MPLX_SWITCHING);
        if (write_batch && !am_server)
                stop_write_batch();
 
        close(error_pipe[1]);
        if (f_in != f_out)
                close(f_in);
+       sock_f_in = -1;
+       f_in = error_pipe[0];
 
        io_start_buffering_out(f_out);
-
-       set_msg_fd_in(error_pipe[0]);
-       io_start_buffering_in(error_pipe[0]);
+       io_start_multiplex_in(f_in);
 
 #ifdef SUPPORT_HARD_LINKS
        if (preserve_hard_links && inc_recurse) {
@@ -845,13 +991,13 @@ static int do_recv(int f_in, int f_out, char *local_name)
 
        handle_stats(-1);
        io_flush(FULL_FLUSH);
+       shutting_down = True;
        if (protocol_version >= 24) {
                /* send a final goodbye message */
                write_ndx(f_out, NDX_DONE);
        }
        io_flush(FULL_FLUSH);
 
-       set_msg_fd_in(-1);
        kill(pid, SIGUSR2);
        wait_process_with_flush(pid, &exit_code);
        return exit_code;
@@ -862,39 +1008,38 @@ static void do_server_recv(int f_in, int f_out, int argc, char *argv[])
        int exit_code;
        struct file_list *flist;
        char *local_name = NULL;
-       char *dir = NULL;
-       int save_verbose = verbose;
+       int negated_levels;
 
-       if (filesfrom_fd >= 0) {
+       if (filesfrom_fd >= 0 && !msgs2stderr && protocol_version < 31) {
                /* We can't mix messages with files-from data on the socket,
-                * so temporarily turn off verbose messages. */
-               verbose = 0;
-       }
+                * so temporarily turn off info/debug messages. */
+               negate_output_levels();
+               negated_levels = 1;
+       } else
+               negated_levels = 0;
 
-       if (verbose > 2) {
-               rprintf(FINFO, "server_recv(%d) starting pid=%ld\n",
-                       argc, (long)getpid());
-       }
+       if (DEBUG_GTE(RECV, 1))
+               rprintf(FINFO, "server_recv(%d) starting pid=%d\n", argc, (int)getpid());
 
-       if (am_daemon && lp_read_only(module_id)) {
+       if (am_daemon && read_only) {
                rprintf(FERROR,"ERROR: module is read only\n");
                exit_cleanup(RERR_SYNTAX);
                return;
        }
 
        if (argc > 0) {
-               dir = argv[0];
+               char *dir = argv[0];
                argc--;
                argv++;
-               if (!am_daemon && !push_dir(dir, 0)) {
-                       rsyserr(FERROR, errno, "push_dir#4 %s failed",
+               if (!am_daemon && !change_dir(dir, CD_NORMAL)) {
+                       rsyserr(FERROR, errno, "change_dir#4 %s failed",
                                full_fname(dir));
                        exit_cleanup(RERR_FILESELECT);
                }
        }
 
        if (protocol_version >= 30)
-               io_start_multiplex_in();
+               io_start_multiplex_in(f_in);
        else
                io_start_buffering_in(f_in);
        recv_filter_list(f_in);
@@ -905,18 +1050,20 @@ static void do_server_recv(int f_in, int f_out, int argc, char *argv[])
                 * need the IO routines to automatically write out the names
                 * onto our f_out socket as we read the file-list.  This
                 * avoids both deadlock and extra delays/buffers. */
-               io_set_filesfrom_fds(filesfrom_fd, f_out);
+               start_filesfrom_forwarding(filesfrom_fd);
                filesfrom_fd = -1;
        }
 
-       flist = recv_file_list(f_in);
+       flist = recv_file_list(f_in, -1);
        if (!flist) {
                rprintf(FERROR,"server_recv: recv_file_list error\n");
                exit_cleanup(RERR_FILESELECT);
        }
        if (inc_recurse && file_total == 1)
                recv_additional_file_list(f_in);
-       verbose = save_verbose;
+
+       if (negated_levels)
+               negate_output_levels();
 
        if (argc > 0)
                local_name = get_local_name(flist,argv[0]);
@@ -924,26 +1071,27 @@ static void do_server_recv(int f_in, int f_out, int argc, char *argv[])
        /* Now that we know what our destination directory turned out to be,
         * we can sanitize the --link-/copy-/compare-dest args correctly. */
        if (sanitize_paths) {
-               char **dir;
-               for (dir = basis_dir; *dir; dir++) {
-                       *dir = sanitize_path(NULL, *dir, NULL, curr_dir_depth);
-               }
-               if (partial_dir) {
-                       partial_dir = sanitize_path(NULL, partial_dir, NULL, curr_dir_depth);
-               }
+               char **dir_p;
+               for (dir_p = basis_dir; *dir_p; dir_p++)
+                       *dir_p = sanitize_path(NULL, *dir_p, NULL, curr_dir_depth, SP_DEFAULT);
+               if (partial_dir)
+                       partial_dir = sanitize_path(NULL, partial_dir, NULL, curr_dir_depth, SP_DEFAULT);
        }
-       fix_basis_dirs();
+       check_alt_basis_dirs();
 
-       if (server_filter_list.head) {
-               char **dir;
-               struct filter_list_struct *elp = &server_filter_list;
+       if (daemon_filter_list.head) {
+               char **dir_p;
+               filter_rule_list *elp = &daemon_filter_list;
 
-               for (dir = basis_dir; *dir; dir++) {
-                       if (check_filter(elp, *dir, 1) < 0)
+               for (dir_p = basis_dir; *dir_p; dir_p++) {
+                       char *dir = *dir_p;
+                       if (*dir == '/')
+                               dir += module_dirlen;
+                       if (check_filter(elp, FLOG, dir, 1) < 0)
                                goto options_rejected;
                }
                if (partial_dir && *partial_dir == '/'
-                && check_filter(elp, partial_dir, 1) < 0) {
+                && check_filter(elp, FLOG, partial_dir + module_dirlen, 1) < 0) {
                    options_rejected:
                        rprintf(FERROR,
                                "Your options have been rejected by the server.\n");
@@ -972,12 +1120,16 @@ void start_server(int f_in, int f_out, int argc, char *argv[])
        setup_protocol(f_out, f_in);
 
        if (protocol_version >= 23)
-               io_start_multiplex_out();
+               io_start_multiplex_out(f_out);
+       if (am_daemon && io_timeout && protocol_version >= 31)
+               send_msg_int(MSG_IO_TIMEOUT, io_timeout);
 
        if (am_sender) {
                keep_dirlinks = 0; /* Must be disabled on the sender. */
                if (need_messages_from_generator)
-                       io_start_multiplex_in();
+                       io_start_multiplex_in(f_in);
+               else
+                       io_start_buffering_in(f_in);
                recv_filter_list(f_in);
                do_server_sender(f_in, f_out, argc, argv);
        } else
@@ -985,11 +1137,8 @@ void start_server(int f_in, int f_out, int argc, char *argv[])
        exit_cleanup(0);
 }
 
-
-/*
- * This is called once the connection has been negotiated.  It is used
- * for rsyncd, remote-shell, and local connections.
- */
+/* This is called once the connection has been negotiated.  It is used
+ * for rsyncd, remote-shell, and local connections. */
 int client_run(int f_in, int f_out, pid_t pid, int argc, char *argv[])
 {
        struct file_list *flist = NULL;
@@ -1017,12 +1166,20 @@ int client_run(int f_in, int f_out, pid_t pid, int argc, char *argv[])
 
        if (am_sender) {
                keep_dirlinks = 0; /* Must be disabled on the sender. */
+
+               if (always_checksum
+                && (log_format_has(stdout_format, 'C')
+                 || log_format_has(logfile_format, 'C')))
+                       sender_keeps_checksum = 1;
+
                if (protocol_version >= 30)
-                       io_start_multiplex_out();
+                       io_start_multiplex_out(f_out);
                else
                        io_start_buffering_out(f_out);
-               if (!filesfrom_host)
-                       set_msg_fd_in(f_in);
+               if (protocol_version >= 31 || (!filesfrom_host && protocol_version >= 23))
+                       io_start_multiplex_in(f_in);
+               else
+                       io_start_buffering_in(f_in);
                send_filter_list(f_out);
                if (filesfrom_host)
                        filesfrom_fd = f_in;
@@ -1030,21 +1187,20 @@ int client_run(int f_in, int f_out, pid_t pid, int argc, char *argv[])
                if (write_batch && !am_server)
                        start_write_batch(f_out);
                flist = send_file_list(f_out, argc, argv);
-               set_msg_fd_in(-1);
-               if (verbose > 3)
+               if (DEBUG_GTE(FLIST, 3))
                        rprintf(FINFO,"file list sent\n");
 
-               if (protocol_version >= 23)
-                       io_start_multiplex_in();
+               if (protocol_version < 31 && filesfrom_host && protocol_version >= 23)
+                       io_start_multiplex_in(f_in);
 
                io_flush(NORMAL_FLUSH);
                send_files(f_in, f_out);
                io_flush(FULL_FLUSH);
                handle_stats(-1);
                if (protocol_version >= 24)
-                       read_final_goodbye(f_in);
+                       read_final_goodbye(f_in, f_out);
                if (pid != -1) {
-                       if (verbose > 3)
+                       if (DEBUG_GTE(EXIT, 2))
                                rprintf(FINFO,"client_run waiting on %d\n", (int) pid);
                        io_flush(FULL_FLUSH);
                        wait_process_with_flush(pid, &exit_code);
@@ -1056,33 +1212,30 @@ int client_run(int f_in, int f_out, pid_t pid, int argc, char *argv[])
 
        if (!read_batch) {
                if (protocol_version >= 23)
-                       io_start_multiplex_in();
+                       io_start_multiplex_in(f_in);
                if (need_messages_from_generator)
-                       io_start_multiplex_out();
-       }
-
-       if (argc == 0) {
-               list_only |= 1;
-               xfer_dirs |= 1;
+                       io_start_multiplex_out(f_out);
+               else
+                       io_start_buffering_out(f_out);
        }
 
        send_filter_list(read_batch ? -1 : f_out);
 
        if (filesfrom_fd >= 0) {
-               io_set_filesfrom_fds(filesfrom_fd, f_out);
+               start_filesfrom_forwarding(filesfrom_fd);
                filesfrom_fd = -1;
        }
 
        if (write_batch && !am_server)
                start_write_batch(f_in);
-       flist = recv_file_list(f_in);
+       flist = recv_file_list(f_in, -1);
        if (inc_recurse && file_total == 1)
                recv_additional_file_list(f_in);
 
        if (flist && flist->used > 0) {
                local_name = get_local_name(flist, argv[0]);
 
-               fix_basis_dirs();
+               check_alt_basis_dirs();
 
                exit_code2 = do_recv(f_in, f_out, local_name);
        } else {
@@ -1091,7 +1244,7 @@ int client_run(int f_in, int f_out, pid_t pid, int argc, char *argv[])
        }
 
        if (pid != -1) {
-               if (verbose > 3)
+               if (DEBUG_GTE(RECV, 1))
                        rprintf(FINFO,"client_run2 waiting on %d\n", (int) pid);
                io_flush(FULL_FLUSH);
                wait_process_with_flush(pid, &exit_code);
@@ -1116,14 +1269,12 @@ static int copy_argv(char *argv[])
 }
 
 
-/**
- * Start a client for either type of remote connection.  Work out
+/* Start a client for either type of remote connection.  Work out
  * whether the arguments request a remote shell or rsyncd connection,
  * and call the appropriate connection function, then run_client.
  *
  * Calls either start_socket_client (for sockets) or do_cmd and
- * client_run (for ssh).
- **/
+ * client_run (for ssh). */
 static int start_client(int argc, char *argv[])
 {
        char *p, *shell_machine = NULL, *shell_user = NULL;
@@ -1176,8 +1327,6 @@ static int start_client(int argc, char *argv[])
                                static char *dotarg[1] = { "." };
                                p = dotarg[0];
                                remote_argv = dotarg;
-                               list_only |= 1;
-                               xfer_dirs |= 1;
                        }
                        remote_argc = 1;
 
@@ -1208,10 +1357,13 @@ static int start_client(int argc, char *argv[])
                        rprintf(FERROR, "remote destination is not allowed with --read-batch\n");
                        exit_cleanup(RERR_SYNTAX);
                }
-               remote_argv = argv + argc - 1;
-               remote_argc = 1;
+               remote_argv = argv += argc - 1;
+               remote_argc = argc = 1;
        }
 
+       if (!rsync_port && remote_argc && !**remote_argv) /* Turn an empty arg into a dot dir. */
+               *remote_argv = ".";
+
        if (am_sender) {
                char *dummy_host;
                int dummy_port = rsync_port;
@@ -1247,12 +1399,10 @@ static int start_client(int argc, char *argv[])
                                        rprintf(FERROR, "All source args must use the same port number.\n");
                                exit_cleanup(RERR_SYNTAX);
                        }
+                       if (!rsync_port && !*arg) /* Turn an empty arg into a dot dir. */
+                               arg = ".";
                        remote_argv[i] = arg;
                }
-               if (argc == 0) {
-                       list_only |= 1;
-                       xfer_dirs |= 1;
-               }
        }
 
        if (daemon_over_rsh < 0)
@@ -1264,6 +1414,12 @@ static int start_client(int argc, char *argv[])
                exit_cleanup(RERR_SYNTAX);
        }
 
+       if (connect_timeout) {
+               rprintf(FERROR, "The --contimeout option may only be "
+                               "used when connecting to an rsync daemon.\n");
+               exit_cleanup(RERR_SYNTAX);
+       }
+
        if (shell_machine) {
                p = strrchr(shell_machine,'@');
                if (p) {
@@ -1273,10 +1429,10 @@ static int start_client(int argc, char *argv[])
                }
        }
 
-       if (verbose > 3) {
+       if (DEBUG_GTE(CMD, 2)) {
                rprintf(FINFO,"cmd=%s machine=%s user=%s path=%s\n",
                        NS(shell_cmd), NS(shell_machine), NS(shell_user),
-                       remote_argv ? NS(remote_argv[0]) : "");
+                       NS(remote_argv[0]));
        }
 
        pid = do_cmd(shell_cmd, shell_machine, shell_user, remote_argv, remote_argc,
@@ -1300,12 +1456,12 @@ static int start_client(int argc, char *argv[])
 }
 
 
-static RETSIGTYPE sigusr1_handler(UNUSED(int val))
+static void sigusr1_handler(UNUSED(int val))
 {
        exit_cleanup(RERR_SIGNAL1);
 }
 
-static RETSIGTYPE sigusr2_handler(UNUSED(int val))
+static void sigusr2_handler(UNUSED(int val))
 {
        if (!am_server)
                output_summary();
@@ -1315,7 +1471,7 @@ static RETSIGTYPE sigusr2_handler(UNUSED(int val))
        _exit(0);
 }
 
-RETSIGTYPE remember_children(UNUSED(int val))
+void remember_children(UNUSED(int val))
 {
 #ifdef WNOHANG
        int cnt, status;
@@ -1362,9 +1518,7 @@ const char *get_panic_action(void)
 
        if (cmd_fmt)
                return cmd_fmt;
-       else
-               return "xterm -display :0 -T Panic -n Panic "
-                       "-e gdb /proc/%d/exe %d";
+       return "xterm -display :0 -T Panic -n Panic -e gdb /proc/%d/exe %d";
 }
 
 
@@ -1376,17 +1530,16 @@ const char *get_panic_action(void)
  * should just look at the environment variable, but I'm a bit leery
  * of a signal sending us into a busy loop.
  **/
-static RETSIGTYPE rsync_panic_handler(UNUSED(int whatsig))
+static void rsync_panic_handler(UNUSED(int whatsig))
 {
        char cmd_buf[300];
-       int ret;
+       int ret, pid_int = getpid();
 
-       snprintf(cmd_buf, sizeof cmd_buf, get_panic_action(),
-                getpid(), getpid());
+       snprintf(cmd_buf, sizeof cmd_buf, get_panic_action(), pid_int, pid_int);
 
        /* Unless we failed to execute gdb, we allow the process to
         * continue.  I'm not sure if that's right. */
-       ret = system(cmd_buf);
+       ret = shell_exec(cmd_buf);
        if (ret)
                _exit(ret);
 }
@@ -1417,7 +1570,9 @@ int main(int argc,char *argv[])
 #endif
 
        starttime = time(NULL);
-       am_root = (MY_UID() == 0);
+       our_uid = MY_UID();
+       our_gid = MY_GID();
+       am_root = our_uid == 0;
 
        memset(&stats, 0, sizeof(stats));
 
@@ -1426,15 +1581,16 @@ int main(int argc,char *argv[])
                exit_cleanup(RERR_SYNTAX);
        }
 
-       /* we set a 0 umask so that correct file permissions can be
-        * carried across */
-       orig_umask = umask(0);
+       /* Get the umask for use in permission calculations.  We no longer set
+        * it to zero; that is ugly and pointless now that all the callers that
+        * relied on it have been reeducated to work with default ACLs. */
+       umask(orig_umask = umask(0));
 
 #if defined CONFIG_LOCALE && defined HAVE_SETLOCALE
        setlocale(LC_CTYPE, "");
 #endif
 
-       if (!parse_arguments(&argc, (const char ***) &argv, 1)) {
+       if (!parse_arguments(&argc, (const char ***) &argv)) {
                /* FIXME: We ought to call the same error-handling
                 * code here, rather than relying on getopt. */
                option_error();
@@ -1455,13 +1611,11 @@ int main(int argc,char *argv[])
        SIGACTION(SIGXFSZ, SIG_IGN);
 #endif
 
-       /* Initialize push_dir here because on some old systems getcwd
+       /* Initialize change_dir() here because on some old systems getcwd
         * (implemented by forking "pwd" and reading its output) doesn't
         * work when there are other child processes.  Also, on all systems
         * that implement getcwd that way "pwd" can't be found after chroot. */
-       push_dir(NULL, 0);
-
-       init_flist();
+       change_dir(NULL, CD_NORMAL);
 
        if ((write_batch || read_batch) && !am_server) {
                if (write_batch)
@@ -1483,7 +1637,6 @@ int main(int argc,char *argv[])
                        read_stream_flags(batch_fd);
                else
                        write_stream_flags(batch_fd);
-
        }
        if (write_batch < 0)
                dry_run = 1;
@@ -1499,7 +1652,7 @@ int main(int argc,char *argv[])
                char buf[MAXPATHLEN];
                protect_args = 2;
                read_args(STDIN_FILENO, NULL, buf, sizeof buf, 1, &argv, &argc, NULL);
-               if (!parse_arguments(&argc, (const char ***) &argv, 1)) {
+               if (!parse_arguments(&argc, (const char ***) &argv)) {
                        option_error();
                        exit_cleanup(RERR_SYNTAX);
                }