filesetup: add native fallocate
[fio.git] / filesetup.c
index 881aeee8f8bf2b94649046181d9892d7050face8..38ad9edc6e206fd919309087bf4590dd76231ea1 100644 (file)
@@ -24,18 +24,91 @@ static int root_warn;
 
 static FLIST_HEAD(filename_list);
 
+/*
+ * List entry for filename_list
+ */
+struct file_name {
+       struct flist_head list;
+       char *filename;
+};
+
 static inline void clear_error(struct thread_data *td)
 {
        td->error = 0;
        td->verror[0] = '\0';
 }
 
+static inline int native_fallocate(struct thread_data *td, struct fio_file *f)
+{
+       bool success;
+
+       success = fio_fallocate(f, 0, f->real_file_size);
+       dprint(FD_FILE, "native fallocate of file %s size %llu was "
+                       "%ssuccessful\n", f->file_name,
+                       (unsigned long long) f->real_file_size,
+                       !success ? "un": "");
+
+       if (success)
+               return 0;
+
+       if (errno == ENOSYS)
+               dprint(FD_FILE, "native fallocate is not implemented\n");
+
+       return -1;
+}
+
+static void fallocate_file(struct thread_data *td, struct fio_file *f)
+{
+       int r;
+
+       if (td->o.fill_device)
+               return;
+
+       switch (td->o.fallocate_mode) {
+       case FIO_FALLOCATE_NATIVE:
+               r = native_fallocate(td, f);
+               if (r != 0)
+                       log_err("fio: native_fallocate call failed: %s\n",
+                                       strerror(errno));
+               break;
+       case FIO_FALLOCATE_NONE:
+               break;
+#ifdef CONFIG_POSIX_FALLOCATE
+       case FIO_FALLOCATE_POSIX:
+               dprint(FD_FILE, "posix_fallocate file %s size %llu\n",
+                                f->file_name,
+                                (unsigned long long) f->real_file_size);
+
+               r = posix_fallocate(f->fd, 0, f->real_file_size);
+               if (r > 0)
+                       log_err("fio: posix_fallocate fails: %s\n", strerror(r));
+               break;
+#endif /* CONFIG_POSIX_FALLOCATE */
+#ifdef CONFIG_LINUX_FALLOCATE
+       case FIO_FALLOCATE_KEEP_SIZE:
+               dprint(FD_FILE, "fallocate(FALLOC_FL_KEEP_SIZE) "
+                               "file %s size %llu\n", f->file_name,
+                               (unsigned long long) f->real_file_size);
+
+               r = fallocate(f->fd, FALLOC_FL_KEEP_SIZE, 0, f->real_file_size);
+               if (r != 0)
+                       td_verror(td, errno, "fallocate");
+
+               break;
+#endif /* CONFIG_LINUX_FALLOCATE */
+       default:
+               log_err("fio: unknown fallocate mode: %d\n", td->o.fallocate_mode);
+               assert(0);
+       }
+
+}
+
 /*
  * Leaves f->fd open on success, caller must close
  */
 static int extend_file(struct thread_data *td, struct fio_file *f)
 {
-       int r, new_layout = 0, unlink_file = 0, flags;
+       int new_layout = 0, unlink_file = 0, flags;
        unsigned long long left;
        unsigned int bs;
        char *b = NULL;
@@ -52,14 +125,18 @@ static int extend_file(struct thread_data *td, struct fio_file *f)
         */
        if (td_read(td) ||
           (td_write(td) && td->o.overwrite && !td->o.file_append) ||
-           (td_write(td) && td->io_ops->flags & FIO_NOEXTEND))
+           (td_write(td) && td_ioengine_flagged(td, FIO_NOEXTEND)))
                new_layout = 1;
        if (td_write(td) && !td->o.overwrite && !td->o.file_append)
                unlink_file = 1;
 
        if (unlink_file || new_layout) {
+               int ret;
+
                dprint(FD_FILE, "layout unlink %s\n", f->file_name);
-               if ((td_io_unlink_file(td, f) < 0) && (errno != ENOENT)) {
+
+               ret = td_io_unlink_file(td, f);
+               if (ret != 0 && ret != ENOENT) {
                        td_verror(td, errno, "unlink");
                        return 1;
                }
@@ -88,44 +165,11 @@ static int extend_file(struct thread_data *td, struct fio_file *f)
                return 1;
        }
 
-#ifdef CONFIG_POSIX_FALLOCATE
-       if (!td->o.fill_device) {
-               switch (td->o.fallocate_mode) {
-               case FIO_FALLOCATE_NONE:
-                       break;
-               case FIO_FALLOCATE_POSIX:
-                       dprint(FD_FILE, "posix_fallocate file %s size %llu\n",
-                                f->file_name,
-                                (unsigned long long) f->real_file_size);
-
-                       r = posix_fallocate(f->fd, 0, f->real_file_size);
-                       if (r > 0) {
-                               log_err("fio: posix_fallocate fails: %s\n",
-                                               strerror(r));
-                       }
-                       break;
-#ifdef CONFIG_LINUX_FALLOCATE
-               case FIO_FALLOCATE_KEEP_SIZE:
-                       dprint(FD_FILE,
-                               "fallocate(FALLOC_FL_KEEP_SIZE) "
-                               "file %s size %llu\n", f->file_name,
-                               (unsigned long long) f->real_file_size);
-
-                       r = fallocate(f->fd, FALLOC_FL_KEEP_SIZE, 0,
-                                       f->real_file_size);
-                       if (r != 0)
-                               td_verror(td, errno, "fallocate");
-
-                       break;
-#endif /* CONFIG_LINUX_FALLOCATE */
-               default:
-                       log_err("fio: unknown fallocate mode: %d\n",
-                               td->o.fallocate_mode);
-                       assert(0);
-               }
-       }
-#endif /* CONFIG_POSIX_FALLOCATE */
+       fallocate_file(td, f);
 
+       /*
+        * If our jobs don't require regular files initially, we're done.
+        */
        if (!new_layout)
                goto done;
 
@@ -144,11 +188,20 @@ static int extend_file(struct thread_data *td, struct fio_file *f)
                }
        }
 
-       b = malloc(td->o.max_bs[DDIR_WRITE]);
-
        left = f->real_file_size;
+       bs = td->o.max_bs[DDIR_WRITE];
+       if (bs > left)
+               bs = left;
+
+       b = malloc(bs);
+       if (!b) {
+               td_verror(td, errno, "malloc");
+               goto err;
+       }
+
        while (left && !td->terminate) {
-               bs = td->o.max_bs[DDIR_WRITE];
+               ssize_t r;
+
                if (bs > left)
                        bs = left;
 
@@ -213,7 +266,11 @@ static int pre_read_file(struct thread_data *td, struct fio_file *f)
        unsigned int bs;
        char *b;
 
-       if (td->io_ops->flags & FIO_PIPEIO)
+       if (td_ioengine_flagged(td, FIO_PIPEIO) ||
+           td_ioengine_flagged(td, FIO_NOIO))
+               return 0;
+
+       if (f->filetype == FIO_TYPE_CHAR)
                return 0;
 
        if (!fio_file_open(f)) {
@@ -226,8 +283,17 @@ static int pre_read_file(struct thread_data *td, struct fio_file *f)
 
        old_runstate = td_bump_runstate(td, TD_PRE_READING);
 
+       left = f->io_size;
        bs = td->o.max_bs[DDIR_READ];
+       if (bs > left)
+               bs = left;
+
        b = malloc(bs);
+       if (!b) {
+               td_verror(td, errno, "malloc");
+               ret = 1;
+               goto error;
+       }
        memset(b, 0, bs);
 
        if (lseek(f->fd, f->file_offset, SEEK_SET) < 0) {
@@ -237,8 +303,6 @@ static int pre_read_file(struct thread_data *td, struct fio_file *f)
                goto error;
        }
 
-       left = f->io_size;
-
        while (left && !td->terminate) {
                if (bs > left)
                        bs = left;
@@ -264,7 +328,7 @@ error:
        return ret;
 }
 
-static unsigned long long get_rand_file_size(struct thread_data *td)
+unsigned long long get_rand_file_size(struct thread_data *td)
 {
        unsigned long long ret, sized;
        uint64_t frand_max;
@@ -329,7 +393,7 @@ static int char_size(struct thread_data *td, struct fio_file *f)
        int r;
 
        if (td->io_ops->open_file(td, f)) {
-               log_err("fio: failed opening blockdev %s for size check\n",
+               log_err("fio: failed opening chardev %s for size check\n",
                        f->file_name);
                return 1;
        }
@@ -366,16 +430,38 @@ static int get_file_size(struct thread_data *td, struct fio_file *f)
 
        if (f->filetype == FIO_TYPE_FILE)
                ret = file_size(td, f);
-       else if (f->filetype == FIO_TYPE_BD)
+       else if (f->filetype == FIO_TYPE_BLOCK)
                ret = bdev_size(td, f);
        else if (f->filetype == FIO_TYPE_CHAR)
                ret = char_size(td, f);
        else
-               f->real_file_size = -1;
+               f->real_file_size = -1ULL;
 
+       /*
+        * Leave ->real_file_size with 0 since it could be expectation
+        * of initial setup for regular files.
+        */
        if (ret)
                return ret;
 
+       /*
+        * If ->real_file_size is -1, a conditional for the message
+        * "offset extends end" is always true, but it makes no sense,
+        * so just return the same value here.
+        */
+       if (f->real_file_size == -1ULL) {
+               log_info("%s: failed to get file size of %s\n", td->o.name,
+                                       f->file_name);
+               return 1;
+       }
+
+       if (td->o.start_offset && f->file_offset == 0)
+               dprint(FD_FILE, "offset of file %s not initialized yet\n",
+                                       f->file_name);
+       /*
+        * ->file_offset normally hasn't been initialized yet, so this
+        * is basically always false.
+        */
        if (f->file_offset > f->real_file_size) {
                log_err("%s: offset extends end (%llu > %llu)\n", td->o.name,
                                        (unsigned long long) f->file_offset,
@@ -391,7 +477,7 @@ static int __file_invalidate_cache(struct thread_data *td, struct fio_file *f,
                                   unsigned long long off,
                                   unsigned long long len)
 {
-       int ret = 0;
+       int errval = 0, ret = 0;
 
 #ifdef CONFIG_ESX
        return 0;
@@ -405,15 +491,33 @@ static int __file_invalidate_cache(struct thread_data *td, struct fio_file *f,
        if (len == -1ULL || off == -1ULL)
                return 0;
 
-       dprint(FD_IO, "invalidate cache %s: %llu/%llu\n", f->file_name, off,
-                                                               len);
-
-       if (td->io_ops->invalidate)
+       if (td->io_ops->invalidate) {
+               dprint(FD_IO, "invalidate %s cache %s\n", td->io_ops->name,
+                       f->file_name);
                ret = td->io_ops->invalidate(td, f);
-       else if (f->filetype == FIO_TYPE_FILE)
+               if (ret < 0)
+                       errval = -ret;
+       } else if (f->filetype == FIO_TYPE_FILE) {
+               dprint(FD_IO, "declare unneeded cache %s: %llu/%llu\n",
+                       f->file_name, off, len);
                ret = posix_fadvise(f->fd, off, len, POSIX_FADV_DONTNEED);
-       else if (f->filetype == FIO_TYPE_BD) {
+               if (ret)
+                       errval = ret;
+       } else if (f->filetype == FIO_TYPE_BLOCK) {
+               int retry_count = 0;
+
+               dprint(FD_IO, "drop page cache %s\n", f->file_name);
                ret = blockdev_invalidate_cache(f);
+               while (ret < 0 && errno == EAGAIN && retry_count++ < 25) {
+                       /*
+                        * Linux multipath devices reject ioctl while
+                        * the maps are being updated. That window can
+                        * last tens of milliseconds; we'll try up to
+                        * a quarter of a second.
+                        */
+                       usleep(10000);
+                       ret = blockdev_invalidate_cache(f);
+               }
                if (ret < 0 && errno == EACCES && geteuid()) {
                        if (!root_warn) {
                                log_err("fio: only root may flush block "
@@ -422,8 +526,15 @@ static int __file_invalidate_cache(struct thread_data *td, struct fio_file *f,
                        }
                        ret = 0;
                }
-       } else if (f->filetype == FIO_TYPE_CHAR || f->filetype == FIO_TYPE_PIPE)
+               if (ret < 0)
+                       errval = errno;
+               else if (ret) /* probably not supported */
+                       errval = ret;
+       } else if (f->filetype == FIO_TYPE_CHAR ||
+                  f->filetype == FIO_TYPE_PIPE) {
+               dprint(FD_IO, "invalidate not supported %s\n", f->file_name);
                ret = 0;
+       }
 
        /*
         * Cache flushing isn't a fatal condition, and we know it will
@@ -431,10 +542,9 @@ static int __file_invalidate_cache(struct thread_data *td, struct fio_file *f,
         * function to flush eg block device caches. So just warn and
         * continue on our way.
         */
-       if (ret) {
-               log_info("fio: cache invalidation of %s failed: %s\n", f->file_name, strerror(errno));
-               ret = 0;
-       }
+       if (errval)
+               log_info("fio: cache invalidation of %s failed: %s\n",
+                        f->file_name, strerror(errval));
 
        return 0;
 
@@ -466,7 +576,7 @@ int generic_close_file(struct thread_data fio_unused *td, struct fio_file *f)
                f->shadow_fd = -1;
        }
 
-       f->engine_data = 0;
+       f->engine_pos = 0;
        return ret;
 }
 
@@ -478,9 +588,6 @@ int file_lookup_open(struct fio_file *f, int flags)
        __f = lookup_file_hash(f->file_name);
        if (__f) {
                dprint(FD_FILE, "found file in hash %s\n", f->file_name);
-               /*
-                * racy, need the __f->lock locked
-                */
                f->lock = __f->lock;
                from_hash = 1;
        } else {
@@ -577,7 +684,8 @@ open_again:
                        f->fd = dup(STDIN_FILENO);
                else
                        from_hash = file_lookup_open(f, flags);
-       } else { //td trim
+       } else if (td_trim(td)) {
+               assert(!td_rw(td)); /* should have matched above */
                flags |= O_RDWR;
                from_hash = file_lookup_open(f, flags);
        }
@@ -632,6 +740,10 @@ open_again:
        return 0;
 }
 
+/*
+ * This function i.e. get_file_size() is the default .get_file_size
+ * implementation of majority of I/O engines.
+ */
 int generic_get_file_size(struct thread_data *td, struct fio_file *f)
 {
        return get_file_size(td, f);
@@ -647,7 +759,7 @@ static int get_file_sizes(struct thread_data *td)
        int err = 0;
 
        for_each_file(td, f, i) {
-               dprint(FD_FILE, "get file size for %p/%d/%p\n", f, i,
+               dprint(FD_FILE, "get file size for %p/%d/%s\n", f, i,
                                                                f->file_name);
 
                if (td_io_get_file_size(td, f)) {
@@ -659,6 +771,13 @@ static int get_file_sizes(struct thread_data *td)
                        clear_error(td);
                }
 
+               /*
+                * There are corner cases where we end up with -1 for
+                * ->real_file_size due to unsupported file type, etc.
+                * We then just set to size option value divided by number
+                * of files, similar to the way file ->io_size is set.
+                * stat(2) failure doesn't set ->real_file_size to -1.
+                */
                if (f->real_file_size == -1ULL && td->o.size)
                        f->real_file_size = td->o.size / td->o.nr_files;
        }
@@ -689,7 +808,7 @@ static unsigned long long get_fs_free_counts(struct thread_data *td)
                struct stat sb;
                char buf[256];
 
-               if (f->filetype == FIO_TYPE_BD || f->filetype == FIO_TYPE_CHAR) {
+               if (f->filetype == FIO_TYPE_BLOCK || f->filetype == FIO_TYPE_CHAR) {
                        if (f->real_file_size != -1ULL)
                                ret += f->real_file_size;
                        continue;
@@ -745,12 +864,42 @@ static unsigned long long get_fs_free_counts(struct thread_data *td)
 uint64_t get_start_offset(struct thread_data *td, struct fio_file *f)
 {
        struct thread_options *o = &td->o;
+       unsigned long long align_bs;
+       unsigned long long offset;
 
        if (o->file_append && f->filetype == FIO_TYPE_FILE)
                return f->real_file_size;
 
-       return td->o.start_offset +
-               td->subjob_number * td->o.offset_increment;
+       if (o->start_offset_percent > 0) {
+               /*
+                * if blockalign is provided, find the min across read, write,
+                * and trim
+                */
+               if (fio_option_is_set(o, ba)) {
+                       align_bs = (unsigned long long) min(o->ba[DDIR_READ], o->ba[DDIR_WRITE]);
+                       align_bs = min((unsigned long long) o->ba[DDIR_TRIM], align_bs);
+               } else {
+                       /* else take the minimum block size */
+                       align_bs = td_min_bs(td);
+               }
+
+               /* calculate the raw offset */
+               offset = (f->real_file_size * o->start_offset_percent / 100) +
+                       (td->subjob_number * o->offset_increment);
+
+               /*
+                * block align the offset at the next available boundary at
+                * ceiling(offset / align_bs) * align_bs
+                */
+               offset = (offset / align_bs + (offset % align_bs != 0)) * align_bs;
+
+       } else {
+               /* start_offset_percent not set */
+               offset = o->start_offset +
+                               td->subjob_number * o->offset_increment;
+       }
+
+       return offset;
 }
 
 /*
@@ -775,7 +924,9 @@ int setup_files(struct thread_data *td)
                goto done;
 
        /*
-        * if ioengine defines a setup() method, it's responsible for
+        * Find out physical size of files or devices for this thread,
+        * before we determine I/O size and range of our targets.
+        * If ioengine defines a setup() method, it's responsible for
         * opening the files and setting f->real_file_size to indicate
         * the valid range for that file.
         */
@@ -793,6 +944,7 @@ int setup_files(struct thread_data *td)
         */
        total_size = 0;
        for_each_file(td, f, i) {
+               f->fileno = i;
                if (f->real_file_size == -1ULL)
                        total_size = -1ULL;
                else
@@ -806,7 +958,7 @@ int setup_files(struct thread_data *td)
         * device/file sizes are zero and no size given, punt
         */
        if ((!total_size || total_size == -1ULL) && !o->size &&
-           !(td->io_ops->flags & FIO_NOIO) && !o->fill_device &&
+           !td_ioengine_flagged(td, FIO_NOIO) && !o->fill_device &&
            !(o->nr_files && (o->file_size_low || o->file_size_high))) {
                log_err("%s: you need to specify size=\n", o->name);
                td_verror(td, EINVAL, "total_file_size");
@@ -815,7 +967,7 @@ int setup_files(struct thread_data *td)
 
        /*
         * Calculate per-file size and potential extra size for the
-        * first files, if needed.
+        * first files, if needed (i.e. if we don't have a fixed size).
         */
        if (!o->file_size_low && o->nr_files) {
                uint64_t all_fs;
@@ -837,11 +989,18 @@ int setup_files(struct thread_data *td)
        for_each_file(td, f, i) {
                f->file_offset = get_start_offset(td, f);
 
+               /*
+                * Update ->io_size depending on options specified.
+                * ->file_size_low being 0 means filesize option isn't set.
+                * Non zero ->file_size_low equals ->file_size_high means
+                * filesize option is set in a fixed size format.
+                * Non zero ->file_size_low not equals ->file_size_high means
+                * filesize option is set in a range format.
+                */
                if (!o->file_size_low) {
                        /*
-                        * no file size range given, file size is equal to
-                        * total size divided by number of files. If that is
-                        * zero, set it to the real file size. If the size
+                        * no file size or range given, file size is equal to
+                        * total size divided by number of files. If the size
                         * doesn't divide nicely with the min blocksize,
                         * make the first files bigger.
                         */
@@ -851,8 +1010,22 @@ int setup_files(struct thread_data *td)
                                f->io_size += bs;
                        }
 
-                       if (!f->io_size)
+                       /*
+                        * We normally don't come here for regular files, but
+                        * if the result is 0 for a regular file, set it to the
+                        * real file size. This could be size of the existing
+                        * one if it already exists, but otherwise will be set
+                        * to 0. A new file won't be created because
+                        * ->io_size + ->file_offset equals ->real_file_size.
+                        */
+                       if (!f->io_size) {
+                               if (f->file_offset > f->real_file_size)
+                                       goto err_offset;
                                f->io_size = f->real_file_size - f->file_offset;
+                               if (!f->io_size)
+                                       log_info("fio: file %s may be ignored\n",
+                                               f->file_name);
+                       }
                } else if (f->real_file_size < o->file_size_low ||
                           f->real_file_size > o->file_size_high) {
                        if (f->file_offset > o->file_size_low)
@@ -873,20 +1046,29 @@ int setup_files(struct thread_data *td)
                if (f->io_size == -1ULL)
                        total_size = -1ULL;
                else {
-                        if (o->size_percent)
-                                f->io_size = (f->io_size * o->size_percent) / 100;
+                        if (o->size_percent) {
+                               uint64_t file_size;
+
+                               file_size = f->io_size + f->file_offset;
+                               f->io_size = (file_size *
+                                             o->size_percent) / 100;
+                               if (f->io_size > (file_size - f->file_offset))
+                                       f->io_size = file_size - f->file_offset;
+
+                               f->io_size -= (f->io_size % td_min_bs(td));
+                       }
                        total_size += f->io_size;
                }
 
                if (f->filetype == FIO_TYPE_FILE &&
                    (f->io_size + f->file_offset) > f->real_file_size &&
-                   !(td->io_ops->flags & FIO_DISKLESSIO)) {
+                   !td_ioengine_flagged(td, FIO_DISKLESSIO)) {
                        if (!o->create_on_open) {
                                need_extend++;
                                extend_size += (f->io_size + f->file_offset);
+                               fio_file_set_extend(f);
                        } else
                                f->real_file_size = f->io_size + f->file_offset;
-                       fio_file_set_extend(f);
                }
        }
 
@@ -905,7 +1087,7 @@ int setup_files(struct thread_data *td)
                }
 
                td->ts.nr_block_infos = len;
-               for (int i = 0; i < len; i++)
+               for (i = 0; i < len; i++)
                        td->ts.block_infos[i] =
                                BLOCK_INFO(0, BLOCK_STATE_UNINIT);
        } else
@@ -920,14 +1102,21 @@ int setup_files(struct thread_data *td)
        }
 
        /*
-        * See if we need to extend some files
+        * See if we need to extend some files, typically needed when our
+        * target regular files don't exist yet, but our jobs require them
+        * initially due to read I/Os.
         */
        if (need_extend) {
                temp_stall_ts = 1;
-               if (output_format == FIO_OUTPUT_NORMAL)
-                       log_info("%s: Laying out IO file(s) (%u file(s) /"
-                                " %lluMB)\n", o->name, need_extend,
-                                       extend_size >> 20);
+               if (output_format & FIO_OUTPUT_NORMAL) {
+                       log_info("%s: Laying out IO file%s (%u file%s / %s%lluMiB)\n",
+                                o->name,
+                                need_extend > 1 ? "s" : "",
+                                need_extend,
+                                need_extend > 1 ? "s" : "",
+                                need_extend > 1 ? "total " : "",
+                                extend_size >> 20);
+               }
 
                for_each_file(td, f, i) {
                        unsigned long long old_len = -1ULL, extend_len = -1ULL;
@@ -974,8 +1163,8 @@ int setup_files(struct thread_data *td)
         * stored entries.
         */
        if (!o->read_iolog_file) {
-               if (o->io_limit)
-                       td->total_io_size = o->io_limit * o->loops;
+               if (o->io_size)
+                       td->total_io_size = o->io_size * o->loops;
                else
                        td->total_io_size = o->size * o->loops;
        }
@@ -1001,10 +1190,11 @@ int pre_read_files(struct thread_data *td)
        dprint(FD_FILE, "pre_read files\n");
 
        for_each_file(td, f, i) {
-               pre_read_file(td, f);
+               if (pre_read_file(td, f))
+                       return -1;
        }
 
-       return 1;
+       return 0;
 }
 
 static int __init_rand_distribution(struct thread_data *td, struct fio_file *f)
@@ -1075,7 +1265,7 @@ static int check_rand_gen_limits(struct thread_data *td, struct fio_file *f,
        if (!fio_option_is_set(&td->o, random_generator)) {
                log_info("fio: Switching to tausworthe64. Use the "
                         "random_generator= option to get rid of this "
-                        " warning.\n");
+                        "warning.\n");
                td->o.random_generator = FIO_RAND_GEN_TAUSWORTHE64;
                return 0;
        }
@@ -1202,14 +1392,16 @@ static void get_file_type(struct fio_file *f)
        else
                f->filetype = FIO_TYPE_FILE;
 
+#ifdef WIN32
        /* \\.\ is the device namespace in Windows, where every file is
         * a block device */
        if (strncmp(f->file_name, "\\\\.\\", 4) == 0)
-               f->filetype = FIO_TYPE_BD;
+               f->filetype = FIO_TYPE_BLOCK;
+#endif
 
        if (!stat(f->file_name, &sb)) {
                if (S_ISBLK(sb.st_mode))
-                       f->filetype = FIO_TYPE_BD;
+                       f->filetype = FIO_TYPE_BLOCK;
                else if (S_ISCHR(sb.st_mode))
                        f->filetype = FIO_TYPE_CHAR;
                else if (S_ISFIFO(sb.st_mode))
@@ -1217,31 +1409,35 @@ static void get_file_type(struct fio_file *f)
        }
 }
 
-static int __is_already_allocated(const char *fname)
+static bool __is_already_allocated(const char *fname, bool set)
 {
        struct flist_head *entry;
-       char *filename;
+       bool ret;
 
-       if (flist_empty(&filename_list))
-               return 0;
+       ret = file_bloom_exists(fname, set);
+       if (!ret)
+               return ret;
 
        flist_for_each(entry, &filename_list) {
-               filename = flist_entry(entry, struct file_name, list)->filename;
+               struct file_name *fn;
 
-               if (strcmp(filename, fname) == 0)
-                       return 1;
+               fn = flist_entry(entry, struct file_name, list);
+
+               if (!strcmp(fn->filename, fname))
+                       return true;
        }
 
-       return 0;
+       return false;
 }
 
-static int is_already_allocated(const char *fname)
+static bool is_already_allocated(const char *fname)
 {
-       int ret;
+       bool ret;
 
        fio_file_hash_lock();
-       ret = __is_already_allocated(fname);
+       ret = __is_already_allocated(fname, false);
        fio_file_hash_unlock();
+
        return ret;
 }
 
@@ -1253,7 +1449,7 @@ static void set_already_allocated(const char *fname)
        fn->filename = strdup(fname);
 
        fio_file_hash_lock();
-       if (!__is_already_allocated(fname)) {
+       if (!__is_already_allocated(fname, true)) {
                flist_add_tail(&fn->list, &filename_list);
                fn = NULL;
        }
@@ -1265,7 +1461,6 @@ static void set_already_allocated(const char *fname)
        }
 }
 
-
 static void free_already_allocated(void)
 {
        struct flist_head *entry, *tmp;
@@ -1291,7 +1486,6 @@ static struct fio_file *alloc_new_file(struct thread_data *td)
 
        f = smalloc(sizeof(*f));
        if (!f) {
-               log_err("fio: smalloc OOM\n");
                assert(0);
                return NULL;
        }
@@ -1302,6 +1496,26 @@ static struct fio_file *alloc_new_file(struct thread_data *td)
        return f;
 }
 
+bool exists_and_not_regfile(const char *filename)
+{
+       struct stat sb;
+
+       if (lstat(filename, &sb) == -1)
+               return false;
+
+#ifndef WIN32 /* NOT Windows */
+       if (S_ISREG(sb.st_mode))
+               return false;
+#else
+       /* \\.\ is the device namespace in Windows, where every file
+        * is a device node */
+       if (S_ISREG(sb.st_mode) && strncmp(filename, "\\\\.\\", 4) != 0)
+               return false;
+#endif
+
+       return true;
+}
+
 int add_file(struct thread_data *td, const char *fname, int numjob, int inc)
 {
        int cur_files = td->files_index;
@@ -1312,12 +1526,14 @@ int add_file(struct thread_data *td, const char *fname, int numjob, int inc)
        dprint(FD_FILE, "add file %s\n", fname);
 
        if (td->o.directory)
-               len = set_name_idx(file_name, PATH_MAX, td->o.directory, numjob);
+               len = set_name_idx(file_name, PATH_MAX, td->o.directory, numjob,
+                                       td->o.unique_filename);
 
        sprintf(file_name + len, "%s", fname);
 
        /* clean cloned siblings using existing files */
-       if (numjob && is_already_allocated(file_name))
+       if (numjob && is_already_allocated(file_name) &&
+           !exists_and_not_regfile(fname))
                return 0;
 
        f = alloc_new_file(td);
@@ -1348,14 +1564,12 @@ int add_file(struct thread_data *td, const char *fname, int numjob, int inc)
        /*
         * init function, io engine may not be loaded yet
         */
-       if (td->io_ops && (td->io_ops->flags & FIO_DISKLESSIO))
+       if (td->io_ops && td_ioengine_flagged(td, FIO_DISKLESSIO))
                f->real_file_size = -1ULL;
 
        f->file_name = smalloc_strdup(file_name);
-       if (!f->file_name) {
-               log_err("fio: smalloc OOM\n");
+       if (!f->file_name)
                assert(0);
-       }
 
        get_file_type(f);
 
@@ -1558,10 +1772,8 @@ void dup_files(struct thread_data *td, struct thread_data *org)
 
                if (f->file_name) {
                        __f->file_name = smalloc_strdup(f->file_name);
-                       if (!__f->file_name) {
-                               log_err("fio: smalloc OOM\n");
+                       if (!__f->file_name)
                                assert(0);
-                       }
 
                        __f->filetype = f->filetype;
                }
@@ -1617,16 +1829,16 @@ void fio_file_reset(struct thread_data *td, struct fio_file *f)
                lfsr_reset(&f->lfsr, td->rand_seeds[FIO_RAND_BLOCK_OFF]);
 }
 
-int fio_files_done(struct thread_data *td)
+bool fio_files_done(struct thread_data *td)
 {
        struct fio_file *f;
        unsigned int i;
 
        for_each_file(td, f, i)
                if (!fio_file_done(f))
-                       return 0;
+                       return false;
 
-       return 1;
+       return true;
 }
 
 /* free memory used in initialization phase only */