io_uring: refactor tctx task_work list splicing
[linux-2.6-microblaze.git] / fs / io_uring.c
index 42380ed..51db0d8 100644 (file)
@@ -11,7 +11,7 @@
  * before writing the tail (using smp_load_acquire to read the tail will
  * do). It also needs a smp_mb() before updating CQ head (ordering the
  * entry load(s) with the head store), pairing with an implicit barrier
- * through a control-dependency in io_get_cqring (smp_store_release to
+ * through a control-dependency in io_get_cqe (smp_store_release to
  * store head will do). Failure to do so could lead to reading invalid
  * CQ entries.
  *
 #define IORING_MAX_RESTRICTIONS        (IORING_RESTRICTION_LAST + \
                                 IORING_REGISTER_LAST + IORING_OP_LAST)
 
+#define IO_RSRC_TAG_TABLE_SHIFT        9
+#define IO_RSRC_TAG_TABLE_MAX  (1U << IO_RSRC_TAG_TABLE_SHIFT)
+#define IO_RSRC_TAG_TABLE_MASK (IO_RSRC_TAG_TABLE_MAX - 1)
+
 #define IORING_MAX_REG_BUFFERS (1U << 14)
 
 #define SQE_VALID_FLAGS        (IOSQE_FIXED_FILE|IOSQE_IO_DRAIN|IOSQE_IO_LINK| \
                                IOSQE_IO_HARDLINK | IOSQE_ASYNC | \
                                IOSQE_BUFFER_SELECT)
+#define IO_REQ_CLEAN_FLAGS (REQ_F_BUFFER_SELECTED | REQ_F_NEED_CLEANUP | \
+                               REQ_F_POLLED | REQ_F_INFLIGHT | REQ_F_CREDS)
+
+#define IO_TCTX_REFS_CACHE_NR  (1U << 10)
 
 struct io_uring {
        u32 head ____cacheline_aligned_in_smp;
@@ -243,7 +251,8 @@ typedef void (rsrc_put_fn)(struct io_ring_ctx *ctx, struct io_rsrc_put *prsrc);
 struct io_rsrc_data {
        struct io_ring_ctx              *ctx;
 
-       u64                             *tags;
+       u64                             **tags;
+       unsigned int                    nr;
        rsrc_put_fn                     *do_put;
        atomic_t                        refs;
        struct completion               done;
@@ -288,7 +297,6 @@ struct io_sq_data {
 
        unsigned long           state;
        struct completion       exited;
-       struct callback_head    *park_task_work;
 };
 
 #define IO_IOPOLL_BATCH                        8
@@ -299,11 +307,8 @@ struct io_sq_data {
 struct io_comp_state {
        struct io_kiocb         *reqs[IO_COMPL_BATCH];
        unsigned int            nr;
-       unsigned int            locked_free_nr;
        /* inline/task_work completion list, under ->uring_lock */
        struct list_head        free_list;
-       /* IRQ completion list, under ->completion_lock */
-       struct list_head        locked_free_list;
 };
 
 struct io_submit_link {
@@ -338,16 +343,23 @@ struct io_submit_state {
 };
 
 struct io_ring_ctx {
+       /* const or read-mostly hot data */
        struct {
                struct percpu_ref       refs;
-       } ____cacheline_aligned_in_smp;
 
-       struct {
+               struct io_rings         *rings;
                unsigned int            flags;
                unsigned int            compat: 1;
                unsigned int            drain_next: 1;
                unsigned int            eventfd_async: 1;
                unsigned int            restricted: 1;
+               unsigned int            off_timeout_used: 1;
+               unsigned int            drain_active: 1;
+       } ____cacheline_aligned_in_smp;
+
+       /* submission data */
+       struct {
+               struct mutex            uring_lock;
 
                /*
                 * Ring buffer of indices into array of io_uring_sqe, which is
@@ -361,35 +373,33 @@ struct io_ring_ctx {
                 * array.
                 */
                u32                     *sq_array;
+               struct io_uring_sqe     *sq_sqes;
                unsigned                cached_sq_head;
                unsigned                sq_entries;
-               unsigned                sq_mask;
-               unsigned                sq_thread_idle;
-               unsigned                cached_sq_dropped;
-               unsigned                cached_cq_overflow;
-               unsigned long           sq_check_overflow;
+               struct list_head        defer_list;
 
-               /* hashed buffered write serialization */
-               struct io_wq_hash       *hash_map;
+               /*
+                * Fixed resources fast path, should be accessed only under
+                * uring_lock, and updated through io_uring_register(2)
+                */
+               struct io_rsrc_node     *rsrc_node;
+               struct io_file_table    file_table;
+               unsigned                nr_user_files;
+               unsigned                nr_user_bufs;
+               struct io_mapped_ubuf   **user_bufs;
 
-               struct list_head        defer_list;
+               struct io_submit_state  submit_state;
                struct list_head        timeout_list;
                struct list_head        cq_overflow_list;
-
-               struct io_uring_sqe     *sq_sqes;
-       } ____cacheline_aligned_in_smp;
-
-       struct {
-               struct mutex            uring_lock;
-               wait_queue_head_t       wait;
+               struct xarray           io_buffers;
+               struct xarray           personalities;
+               u32                     pers_next;
+               unsigned                sq_thread_idle;
        } ____cacheline_aligned_in_smp;
 
-       struct io_submit_state          submit_state;
-
-       struct io_rings *rings;
-
-       /* Only used for accounting purposes */
-       struct mm_struct        *mm_account;
+       /* IRQ completion list, under ->completion_lock */
+       struct list_head        locked_free_list;
+       unsigned int            locked_free_nr;
 
        const struct cred       *sq_creds;      /* cred used for __io_sq_thread() */
        struct io_sq_data       *sq_data;       /* if using sq thread polling */
@@ -397,44 +407,18 @@ struct io_ring_ctx {
        struct wait_queue_head  sqo_sq_wait;
        struct list_head        sqd_list;
 
-       /*
-        * If used, fixed file set. Writers must ensure that ->refs is dead,
-        * readers must ensure that ->refs is alive as long as the file* is
-        * used. Only updated through io_uring_register(2).
-        */
-       struct io_rsrc_data     *file_data;
-       struct io_file_table    file_table;
-       unsigned                nr_user_files;
-
-       /* if used, fixed mapped user buffers */
-       struct io_rsrc_data     *buf_data;
-       unsigned                nr_user_bufs;
-       struct io_mapped_ubuf   **user_bufs;
-
-       struct user_struct      *user;
-
-       struct completion       ref_comp;
-
-#if defined(CONFIG_UNIX)
-       struct socket           *ring_sock;
-#endif
-
-       struct xarray           io_buffers;
-
-       struct xarray           personalities;
-       u32                     pers_next;
+       unsigned long           check_cq_overflow;
 
        struct {
                unsigned                cached_cq_tail;
                unsigned                cq_entries;
-               unsigned                cq_mask;
-               atomic_t                cq_timeouts;
-               unsigned                cq_last_tm_flush;
-               unsigned                cq_extra;
-               unsigned long           cq_check_overflow;
+               struct eventfd_ctx      *cq_ev_fd;
+               struct wait_queue_head  poll_wait;
                struct wait_queue_head  cq_wait;
+               unsigned                cq_extra;
+               atomic_t                cq_timeouts;
                struct fasync_struct    *cq_fasync;
-               struct eventfd_ctx      *cq_ev_fd;
+               unsigned                cq_last_tm_flush;
        } ____cacheline_aligned_in_smp;
 
        struct {
@@ -452,26 +436,44 @@ struct io_ring_ctx {
                bool                    poll_multi_file;
        } ____cacheline_aligned_in_smp;
 
-       struct delayed_work             rsrc_put_work;
-       struct llist_head               rsrc_put_llist;
-       struct list_head                rsrc_ref_list;
-       spinlock_t                      rsrc_ref_lock;
-       struct io_rsrc_node             *rsrc_node;
-       struct io_rsrc_node             *rsrc_backup_node;
-       struct io_mapped_ubuf           *dummy_ubuf;
-
        struct io_restriction           restrictions;
 
-       /* exit task_work */
-       struct callback_head            *exit_task_work;
+       /* slow path rsrc auxilary data, used by update/register */
+       struct {
+               struct io_rsrc_node             *rsrc_backup_node;
+               struct io_mapped_ubuf           *dummy_ubuf;
+               struct io_rsrc_data             *file_data;
+               struct io_rsrc_data             *buf_data;
+
+               struct delayed_work             rsrc_put_work;
+               struct llist_head               rsrc_put_llist;
+               struct list_head                rsrc_ref_list;
+               spinlock_t                      rsrc_ref_lock;
+       };
 
        /* Keep this last, we don't need it for the fast path */
-       struct work_struct              exit_work;
-       struct list_head                tctx_list;
+       struct {
+               #if defined(CONFIG_UNIX)
+                       struct socket           *ring_sock;
+               #endif
+               /* hashed buffered write serialization */
+               struct io_wq_hash               *hash_map;
+
+               /* Only used for accounting purposes */
+               struct user_struct              *user;
+               struct mm_struct                *mm_account;
+
+               /* ctx exit and cancelation */
+               struct callback_head            *exit_task_work;
+               struct work_struct              exit_work;
+               struct list_head                tctx_list;
+               struct completion               ref_comp;
+       };
 };
 
 struct io_uring_task {
        /* submission side */
+       int                     cached_refs;
        struct xarray           xa;
        struct wait_queue_head  wait;
        const struct io_ring_ctx *last;
@@ -706,7 +708,7 @@ enum {
        REQ_F_BUFFER_SELECT_BIT = IOSQE_BUFFER_SELECT_BIT,
 
        /* first byte is taken by user flags, shift it to not overlap */
-       REQ_F_FAIL_LINK_BIT     = 8,
+       REQ_F_FAIL_BIT          = 8,
        REQ_F_INFLIGHT_BIT,
        REQ_F_CUR_POS_BIT,
        REQ_F_NOWAIT_BIT,
@@ -718,6 +720,7 @@ enum {
        REQ_F_COMPLETE_INLINE_BIT,
        REQ_F_REISSUE_BIT,
        REQ_F_DONT_REISSUE_BIT,
+       REQ_F_CREDS_BIT,
        /* keep async read/write and isreg together and in order */
        REQ_F_ASYNC_READ_BIT,
        REQ_F_ASYNC_WRITE_BIT,
@@ -742,7 +745,7 @@ enum {
        REQ_F_BUFFER_SELECT     = BIT(REQ_F_BUFFER_SELECT_BIT),
 
        /* fail rest of links */
-       REQ_F_FAIL_LINK         = BIT(REQ_F_FAIL_LINK_BIT),
+       REQ_F_FAIL              = BIT(REQ_F_FAIL_BIT),
        /* on inflight list, should be cancelled and waited on exit reliably */
        REQ_F_INFLIGHT          = BIT(REQ_F_INFLIGHT_BIT),
        /* read/write uses file position */
@@ -771,6 +774,8 @@ enum {
        REQ_F_ASYNC_WRITE       = BIT(REQ_F_ASYNC_WRITE_BIT),
        /* regular file */
        REQ_F_ISREG             = BIT(REQ_F_ISREG_BIT),
+       /* has creds assigned */
+       REQ_F_CREDS             = BIT(REQ_F_CREDS_BIT),
 };
 
 struct async_poll {
@@ -783,6 +788,11 @@ struct io_task_work {
        task_work_func_t        func;
 };
 
+enum {
+       IORING_RSRC_FILE                = 0,
+       IORING_RSRC_BUFFER              = 1,
+};
+
 /*
  * NOTE! Each of the iocb union members has the file pointer
  * as the first entry in their struct definition. So you can
@@ -846,6 +856,8 @@ struct io_kiocb {
        struct hlist_node               hash_node;
        struct async_poll               *apoll;
        struct io_wq_work               work;
+       const struct cred               *creds;
+
        /* store used ubuf, so we can prevent reloading */
        struct io_mapped_ubuf           *imu;
 };
@@ -1029,11 +1041,11 @@ static const struct io_op_def io_op_defs[] = {
 };
 
 static bool io_disarm_next(struct io_kiocb *req);
-static void io_uring_del_task_file(unsigned long index);
+static void io_uring_del_tctx_node(unsigned long index);
 static void io_uring_try_cancel_requests(struct io_ring_ctx *ctx,
                                         struct task_struct *task,
-                                        struct files_struct *files);
-static void io_uring_cancel_sqpoll(struct io_sq_data *sqd);
+                                        bool cancel_all);
+static void io_uring_cancel_generic(bool cancel_all, struct io_sq_data *sqd);
 static struct io_rsrc_node *io_rsrc_node_alloc(struct io_ring_ctx *ctx);
 
 static bool io_cqring_fill_event(struct io_ring_ctx *ctx, u64 user_data,
@@ -1054,8 +1066,7 @@ static void __io_queue_sqe(struct io_kiocb *req);
 static void io_rsrc_put_work(struct work_struct *work);
 
 static void io_req_task_queue(struct io_kiocb *req);
-static void io_submit_flush_completions(struct io_comp_state *cs,
-                                       struct io_ring_ctx *ctx);
+static void io_submit_flush_completions(struct io_ring_ctx *ctx);
 static bool io_poll_remove_waitqs(struct io_kiocb *req);
 static int io_req_prep_async(struct io_kiocb *req);
 
@@ -1101,15 +1112,14 @@ static void io_refs_resurrect(struct percpu_ref *ref, struct completion *compl)
                percpu_ref_put(ref);
 }
 
-static bool io_match_task(struct io_kiocb *head,
-                         struct task_struct *task,
-                         struct files_struct *files)
+static bool io_match_task(struct io_kiocb *head, struct task_struct *task,
+                         bool cancel_all)
 {
        struct io_kiocb *req;
 
        if (task && head->task != task)
                return false;
-       if (!files)
+       if (cancel_all)
                return true;
 
        io_for_each_link(req, head) {
@@ -1119,10 +1129,9 @@ static bool io_match_task(struct io_kiocb *head,
        return false;
 }
 
-static inline void req_set_fail_links(struct io_kiocb *req)
+static inline void req_set_fail(struct io_kiocb *req)
 {
-       if (req->flags & REQ_F_LINK)
-               req->flags |= REQ_F_FAIL_LINK;
+       req->flags |= REQ_F_FAIL;
 }
 
 static void io_ring_ctx_ref_free(struct percpu_ref *ref)
@@ -1174,13 +1183,13 @@ static struct io_ring_ctx *io_ring_ctx_alloc(struct io_uring_params *p)
        ctx->flags = p->flags;
        init_waitqueue_head(&ctx->sqo_sq_wait);
        INIT_LIST_HEAD(&ctx->sqd_list);
-       init_waitqueue_head(&ctx->cq_wait);
+       init_waitqueue_head(&ctx->poll_wait);
        INIT_LIST_HEAD(&ctx->cq_overflow_list);
        init_completion(&ctx->ref_comp);
        xa_init_flags(&ctx->io_buffers, XA_FLAGS_ALLOC1);
        xa_init_flags(&ctx->personalities, XA_FLAGS_ALLOC1);
        mutex_init(&ctx->uring_lock);
-       init_waitqueue_head(&ctx->wait);
+       init_waitqueue_head(&ctx->cq_wait);
        spin_lock_init(&ctx->completion_lock);
        INIT_LIST_HEAD(&ctx->iopoll_list);
        INIT_LIST_HEAD(&ctx->defer_list);
@@ -1191,7 +1200,7 @@ static struct io_ring_ctx *io_ring_ctx_alloc(struct io_uring_params *p)
        init_llist_head(&ctx->rsrc_put_llist);
        INIT_LIST_HEAD(&ctx->tctx_list);
        INIT_LIST_HEAD(&ctx->submit_state.comp.free_list);
-       INIT_LIST_HEAD(&ctx->submit_state.comp.locked_free_list);
+       INIT_LIST_HEAD(&ctx->locked_free_list);
        return ctx;
 err:
        kfree(ctx->dummy_ubuf);
@@ -1200,13 +1209,20 @@ err:
        return NULL;
 }
 
+static void io_account_cq_overflow(struct io_ring_ctx *ctx)
+{
+       struct io_rings *r = ctx->rings;
+
+       WRITE_ONCE(r->cq_overflow, READ_ONCE(r->cq_overflow) + 1);
+       ctx->cq_extra--;
+}
+
 static bool req_need_defer(struct io_kiocb *req, u32 seq)
 {
        if (unlikely(req->flags & REQ_F_IO_DRAIN)) {
                struct io_ring_ctx *ctx = req->ctx;
 
-               return seq + ctx->cq_extra != ctx->cached_cq_tail
-                               + READ_ONCE(ctx->cached_cq_overflow);
+               return seq + READ_ONCE(ctx->cq_extra) != ctx->cached_cq_tail;
        }
 
        return false;
@@ -1225,8 +1241,10 @@ static void io_prep_async_work(struct io_kiocb *req)
        const struct io_op_def *def = &io_op_defs[req->opcode];
        struct io_ring_ctx *ctx = req->ctx;
 
-       if (!req->work.creds)
-               req->work.creds = get_current_cred();
+       if (!(req->flags & REQ_F_CREDS)) {
+               req->flags |= REQ_F_CREDS;
+               req->creds = get_current_cred();
+       }
 
        req->work.list.next = NULL;
        req->work.flags = 0;
@@ -1290,9 +1308,9 @@ static void io_kill_timeout(struct io_kiocb *req, int status)
        }
 }
 
-static void __io_queue_deferred(struct io_ring_ctx *ctx)
+static void io_queue_deferred(struct io_ring_ctx *ctx)
 {
-       do {
+       while (!list_empty(&ctx->defer_list)) {
                struct io_defer_entry *de = list_first_entry(&ctx->defer_list,
                                                struct io_defer_entry, list);
 
@@ -1301,19 +1319,14 @@ static void __io_queue_deferred(struct io_ring_ctx *ctx)
                list_del_init(&de->list);
                io_req_task_queue(de->req);
                kfree(de);
-       } while (!list_empty(&ctx->defer_list));
+       }
 }
 
 static void io_flush_timeouts(struct io_ring_ctx *ctx)
 {
-       u32 seq;
-
-       if (list_empty(&ctx->timeout_list))
-               return;
+       u32 seq = ctx->cached_cq_tail - atomic_read(&ctx->cq_timeouts);
 
-       seq = ctx->cached_cq_tail - atomic_read(&ctx->cq_timeouts);
-
-       do {
+       while (!list_empty(&ctx->timeout_list)) {
                u32 events_needed, events_got;
                struct io_kiocb *req = list_first_entry(&ctx->timeout_list,
                                                struct io_kiocb, timeout.list);
@@ -1335,27 +1348,31 @@ static void io_flush_timeouts(struct io_ring_ctx *ctx)
 
                list_del_init(&req->timeout.list);
                io_kill_timeout(req, 0);
-       } while (!list_empty(&ctx->timeout_list));
-
+       }
        ctx->cq_last_tm_flush = seq;
 }
 
-static void io_commit_cqring(struct io_ring_ctx *ctx)
+static void __io_commit_cqring_flush(struct io_ring_ctx *ctx)
 {
-       io_flush_timeouts(ctx);
+       if (ctx->off_timeout_used)
+               io_flush_timeouts(ctx);
+       if (ctx->drain_active)
+               io_queue_deferred(ctx);
+}
 
+static inline void io_commit_cqring(struct io_ring_ctx *ctx)
+{
+       if (unlikely(ctx->off_timeout_used || ctx->drain_active))
+               __io_commit_cqring_flush(ctx);
        /* order cqe stores with ring update */
        smp_store_release(&ctx->rings->cq.tail, ctx->cached_cq_tail);
-
-       if (unlikely(!list_empty(&ctx->defer_list)))
-               __io_queue_deferred(ctx);
 }
 
 static inline bool io_sqring_full(struct io_ring_ctx *ctx)
 {
        struct io_rings *r = ctx->rings;
 
-       return READ_ONCE(r->sq.tail) - ctx->cached_sq_head == r->sq_ring_entries;
+       return READ_ONCE(r->sq.tail) - ctx->cached_sq_head == ctx->sq_entries;
 }
 
 static inline unsigned int __io_cqring_events(struct io_ring_ctx *ctx)
@@ -1363,21 +1380,21 @@ static inline unsigned int __io_cqring_events(struct io_ring_ctx *ctx)
        return ctx->cached_cq_tail - READ_ONCE(ctx->rings->cq.head);
 }
 
-static inline struct io_uring_cqe *io_get_cqring(struct io_ring_ctx *ctx)
+static inline struct io_uring_cqe *io_get_cqe(struct io_ring_ctx *ctx)
 {
        struct io_rings *rings = ctx->rings;
-       unsigned tail;
+       unsigned tail, mask = ctx->cq_entries - 1;
 
        /*
         * writes to the cq entry need to come after reading head; the
         * control dependency is enough as we're using WRITE_ONCE to
         * fill the cq entry
         */
-       if (__io_cqring_events(ctx) == rings->cq_ring_entries)
+       if (__io_cqring_events(ctx) == ctx->cq_entries)
                return NULL;
 
        tail = ctx->cached_cq_tail++;
-       return &rings->cqes[tail & ctx->cq_mask];
+       return &rings->cqes[tail & mask];
 }
 
 static inline bool io_should_trigger_evfd(struct io_ring_ctx *ctx)
@@ -1394,14 +1411,14 @@ static void io_cqring_ev_posted(struct io_ring_ctx *ctx)
        /* see waitqueue_active() comment */
        smp_mb();
 
-       if (waitqueue_active(&ctx->wait))
-               wake_up(&ctx->wait);
+       if (waitqueue_active(&ctx->cq_wait))
+               wake_up(&ctx->cq_wait);
        if (ctx->sq_data && waitqueue_active(&ctx->sq_data->wait))
                wake_up(&ctx->sq_data->wait);
        if (io_should_trigger_evfd(ctx))
                eventfd_signal(ctx->cq_ev_fd, 1);
-       if (waitqueue_active(&ctx->cq_wait)) {
-               wake_up_interruptible(&ctx->cq_wait);
+       if (waitqueue_active(&ctx->poll_wait)) {
+               wake_up_interruptible(&ctx->poll_wait);
                kill_fasync(&ctx->cq_fasync, SIGIO, POLL_IN);
        }
 }
@@ -1412,13 +1429,13 @@ static void io_cqring_ev_posted_iopoll(struct io_ring_ctx *ctx)
        smp_mb();
 
        if (ctx->flags & IORING_SETUP_SQPOLL) {
-               if (waitqueue_active(&ctx->wait))
-                       wake_up(&ctx->wait);
+               if (waitqueue_active(&ctx->cq_wait))
+                       wake_up(&ctx->cq_wait);
        }
        if (io_should_trigger_evfd(ctx))
                eventfd_signal(ctx->cq_ev_fd, 1);
-       if (waitqueue_active(&ctx->cq_wait)) {
-               wake_up_interruptible(&ctx->cq_wait);
+       if (waitqueue_active(&ctx->poll_wait)) {
+               wake_up_interruptible(&ctx->poll_wait);
                kill_fasync(&ctx->cq_fasync, SIGIO, POLL_IN);
        }
 }
@@ -1426,17 +1443,16 @@ static void io_cqring_ev_posted_iopoll(struct io_ring_ctx *ctx)
 /* Returns true if there are no backlogged entries after the flush */
 static bool __io_cqring_overflow_flush(struct io_ring_ctx *ctx, bool force)
 {
-       struct io_rings *rings = ctx->rings;
        unsigned long flags;
        bool all_flushed, posted;
 
-       if (!force && __io_cqring_events(ctx) == rings->cq_ring_entries)
+       if (!force && __io_cqring_events(ctx) == ctx->cq_entries)
                return false;
 
        posted = false;
        spin_lock_irqsave(&ctx->completion_lock, flags);
        while (!list_empty(&ctx->cq_overflow_list)) {
-               struct io_uring_cqe *cqe = io_get_cqring(ctx);
+               struct io_uring_cqe *cqe = io_get_cqe(ctx);
                struct io_overflow_cqe *ocqe;
 
                if (!cqe && !force)
@@ -1446,8 +1462,8 @@ static bool __io_cqring_overflow_flush(struct io_ring_ctx *ctx, bool force)
                if (cqe)
                        memcpy(cqe, &ocqe->cqe, sizeof(*cqe));
                else
-                       WRITE_ONCE(ctx->rings->cq_overflow,
-                                  ++ctx->cached_cq_overflow);
+                       io_account_cq_overflow(ctx);
+
                posted = true;
                list_del(&ocqe->list);
                kfree(ocqe);
@@ -1455,8 +1471,7 @@ static bool __io_cqring_overflow_flush(struct io_ring_ctx *ctx, bool force)
 
        all_flushed = list_empty(&ctx->cq_overflow_list);
        if (all_flushed) {
-               clear_bit(0, &ctx->sq_check_overflow);
-               clear_bit(0, &ctx->cq_check_overflow);
+               clear_bit(0, &ctx->check_cq_overflow);
                ctx->rings->sq_flags &= ~IORING_SQ_CQ_OVERFLOW;
        }
 
@@ -1472,7 +1487,7 @@ static bool io_cqring_overflow_flush(struct io_ring_ctx *ctx, bool force)
 {
        bool ret = true;
 
-       if (test_bit(0, &ctx->cq_check_overflow)) {
+       if (test_bit(0, &ctx->check_cq_overflow)) {
                /* iopoll syncs against uring_lock, not completion_lock */
                if (ctx->flags & IORING_SETUP_IOPOLL)
                        mutex_lock(&ctx->uring_lock);
@@ -1531,12 +1546,11 @@ static bool io_cqring_event_overflow(struct io_ring_ctx *ctx, u64 user_data,
                 * or cannot allocate an overflow entry, then we need to drop it
                 * on the floor.
                 */
-               WRITE_ONCE(ctx->rings->cq_overflow, ++ctx->cached_cq_overflow);
+               io_account_cq_overflow(ctx);
                return false;
        }
        if (list_empty(&ctx->cq_overflow_list)) {
-               set_bit(0, &ctx->sq_check_overflow);
-               set_bit(0, &ctx->cq_check_overflow);
+               set_bit(0, &ctx->check_cq_overflow);
                ctx->rings->sq_flags |= IORING_SQ_CQ_OVERFLOW;
        }
        ocqe->cqe.user_data = user_data;
@@ -1558,7 +1572,7 @@ static inline bool __io_cqring_fill_event(struct io_ring_ctx *ctx, u64 user_data
         * submission (by quite a lot). Increment the overflow count in
         * the ring.
         */
-       cqe = io_get_cqring(ctx);
+       cqe = io_get_cqe(ctx);
        if (likely(cqe)) {
                WRITE_ONCE(cqe->user_data, user_data);
                WRITE_ONCE(cqe->res, res);
@@ -1588,10 +1602,8 @@ static void io_req_complete_post(struct io_kiocb *req, long res,
         * free_list cache.
         */
        if (req_ref_put_and_test(req)) {
-               struct io_comp_state *cs = &ctx->submit_state.comp;
-
                if (req->flags & (REQ_F_LINK | REQ_F_HARDLINK)) {
-                       if (req->flags & (REQ_F_LINK_TIMEOUT | REQ_F_FAIL_LINK))
+                       if (req->flags & (REQ_F_LINK_TIMEOUT | REQ_F_FAIL))
                                io_disarm_next(req);
                        if (req->link) {
                                io_req_task_queue(req->link);
@@ -1600,8 +1612,8 @@ static void io_req_complete_post(struct io_kiocb *req, long res,
                }
                io_dismantle_req(req);
                io_put_task(req->task, 1);
-               list_add(&req->compl.list, &cs->locked_free_list);
-               cs->locked_free_nr++;
+               list_add(&req->compl.list, &ctx->locked_free_list);
+               ctx->locked_free_nr++;
        } else {
                if (!percpu_ref_tryget(&ctx->refs))
                        req = NULL;
@@ -1617,8 +1629,7 @@ static void io_req_complete_post(struct io_kiocb *req, long res,
 
 static inline bool io_req_needs_clean(struct io_kiocb *req)
 {
-       return req->flags & (REQ_F_BUFFER_SELECTED | REQ_F_NEED_CLEANUP |
-                               REQ_F_POLLED | REQ_F_INFLIGHT);
+       return req->flags & IO_REQ_CLEAN_FLAGS;
 }
 
 static void io_req_complete_state(struct io_kiocb *req, long res,
@@ -1647,7 +1658,7 @@ static inline void io_req_complete(struct io_kiocb *req, long res)
 
 static void io_req_complete_failed(struct io_kiocb *req, long res)
 {
-       req_set_fail_links(req);
+       req_set_fail(req);
        io_put_req(req);
        io_req_complete_post(req, res, 0);
 }
@@ -1656,8 +1667,8 @@ static void io_flush_cached_locked_reqs(struct io_ring_ctx *ctx,
                                        struct io_comp_state *cs)
 {
        spin_lock_irq(&ctx->completion_lock);
-       list_splice_init(&cs->locked_free_list, &cs->free_list);
-       cs->locked_free_nr = 0;
+       list_splice_init(&ctx->locked_free_list, &cs->free_list);
+       ctx->locked_free_nr = 0;
        spin_unlock_irq(&ctx->completion_lock);
 }
 
@@ -1673,7 +1684,7 @@ static bool io_flush_cached_reqs(struct io_ring_ctx *ctx)
         * locked cache, grab the lock and move them over to our submission
         * side cache.
         */
-       if (READ_ONCE(cs->locked_free_nr) > IO_COMPL_BATCH)
+       if (READ_ONCE(ctx->locked_free_nr) > IO_COMPL_BATCH)
                io_flush_cached_locked_reqs(ctx, cs);
 
        nr = state->free_reqs;
@@ -1742,10 +1753,6 @@ static void io_dismantle_req(struct io_kiocb *req)
                percpu_ref_put(req->fixed_rsrc_refs);
        if (req->async_data)
                kfree(req->async_data);
-       if (req->work.creds) {
-               put_cred(req->work.creds);
-               req->work.creds = NULL;
-       }
 }
 
 /* must to be called somewhat shortly after putting a request */
@@ -1826,7 +1833,7 @@ static bool io_disarm_next(struct io_kiocb *req)
 
        if (likely(req->flags & REQ_F_LINK_TIMEOUT))
                posted = io_kill_linked_timeout(req);
-       if (unlikely((req->flags & REQ_F_FAIL_LINK) &&
+       if (unlikely((req->flags & REQ_F_FAIL) &&
                     !(req->flags & REQ_F_HARDLINK))) {
                posted |= (req->link != NULL);
                io_fail_links(req);
@@ -1844,7 +1851,7 @@ static struct io_kiocb *__io_req_find_next(struct io_kiocb *req)
         * dependencies to the next request. In case of failure, fail the rest
         * of the chain.
         */
-       if (req->flags & (REQ_F_LINK_TIMEOUT | REQ_F_FAIL_LINK)) {
+       if (req->flags & (REQ_F_LINK_TIMEOUT | REQ_F_FAIL)) {
                struct io_ring_ctx *ctx = req->ctx;
                unsigned long flags;
                bool posted;
@@ -1875,54 +1882,45 @@ static void ctx_flush_and_put(struct io_ring_ctx *ctx)
                return;
        if (ctx->submit_state.comp.nr) {
                mutex_lock(&ctx->uring_lock);
-               io_submit_flush_completions(&ctx->submit_state.comp, ctx);
+               io_submit_flush_completions(ctx);
                mutex_unlock(&ctx->uring_lock);
        }
        percpu_ref_put(&ctx->refs);
 }
 
-static bool __tctx_task_work(struct io_uring_task *tctx)
+static void tctx_task_work(struct callback_head *cb)
 {
        struct io_ring_ctx *ctx = NULL;
-       struct io_wq_work_list list;
-       struct io_wq_work_node *node;
+       struct io_uring_task *tctx = container_of(cb, struct io_uring_task,
+                                                 task_work);
 
-       if (wq_list_empty(&tctx->task_list))
-               return false;
+       clear_bit(0, &tctx->task_state);
 
-       spin_lock_irq(&tctx->task_lock);
-       list = tctx->task_list;
-       INIT_WQ_LIST(&tctx->task_list);
-       spin_unlock_irq(&tctx->task_lock);
+       while (!wq_list_empty(&tctx->task_list)) {
+               struct io_wq_work_node *node;
 
-       node = list.first;
-       while (node) {
-               struct io_wq_work_node *next = node->next;
-               struct io_kiocb *req;
+               spin_lock_irq(&tctx->task_lock);
+               node = tctx->task_list.first;
+               INIT_WQ_LIST(&tctx->task_list);
+               spin_unlock_irq(&tctx->task_lock);
 
-               req = container_of(node, struct io_kiocb, io_task_work.node);
-               if (req->ctx != ctx) {
-                       ctx_flush_and_put(ctx);
-                       ctx = req->ctx;
-                       percpu_ref_get(&ctx->refs);
-               }
+               while (node) {
+                       struct io_wq_work_node *next = node->next;
+                       struct io_kiocb *req = container_of(node, struct io_kiocb,
+                                                           io_task_work.node);
 
-               req->task_work.func(&req->task_work);
-               node = next;
+                       if (req->ctx != ctx) {
+                               ctx_flush_and_put(ctx);
+                               ctx = req->ctx;
+                               percpu_ref_get(&ctx->refs);
+                       }
+                       req->task_work.func(&req->task_work);
+                       node = next;
+               }
+               cond_resched();
        }
 
        ctx_flush_and_put(ctx);
-       return list.first != NULL;
-}
-
-static void tctx_task_work(struct callback_head *cb)
-{
-       struct io_uring_task *tctx = container_of(cb, struct io_uring_task, task_work);
-
-       clear_bit(0, &tctx->task_state);
-
-       while (__tctx_task_work(tctx))
-               cond_resched();
 }
 
 static int io_req_task_work_add(struct io_kiocb *req)
@@ -2123,9 +2121,9 @@ static void io_req_free_batch(struct req_batch *rb, struct io_kiocb *req,
                list_add(&req->compl.list, &state->comp.free_list);
 }
 
-static void io_submit_flush_completions(struct io_comp_state *cs,
-                                       struct io_ring_ctx *ctx)
+static void io_submit_flush_completions(struct io_ring_ctx *ctx)
 {
+       struct io_comp_state *cs = &ctx->submit_state.comp;
        int i, nr = cs->nr;
        struct io_kiocb *req;
        struct req_batch rb;
@@ -2384,7 +2382,7 @@ static int io_iopoll_check(struct io_ring_ctx *ctx, long min)
         * If we do, we can potentially be spinning for commands that
         * already triggered a CQE (eg in error).
         */
-       if (test_bit(0, &ctx->cq_check_overflow))
+       if (test_bit(0, &ctx->check_cq_overflow))
                __io_cqring_overflow_flush(ctx, false);
        if (io_cqring_events(ctx))
                goto out;
@@ -2483,7 +2481,7 @@ static void __io_complete_rw(struct io_kiocb *req, long res, long res2,
                        req->flags |= REQ_F_REISSUE;
                        return;
                }
-               req_set_fail_links(req);
+               req_set_fail(req);
        }
        if (req->flags & REQ_F_BUFFER_SELECTED)
                cflags = io_put_rw_kbuf(req);
@@ -2506,7 +2504,7 @@ static void io_complete_rw_iopoll(struct kiocb *kiocb, long res, long res2)
        if (unlikely(res != req->result)) {
                if (!(res == -EAGAIN && io_rw_should_reissue(req) &&
                    io_resubmit_prep(req))) {
-                       req_set_fail_links(req);
+                       req_set_fail(req);
                        req->flags |= REQ_F_DONT_REISSUE;
                }
        }
@@ -2523,9 +2521,14 @@ static void io_complete_rw_iopoll(struct kiocb *kiocb, long res, long res2)
  * find it from a io_do_iopoll() thread before the issuer is done
  * accessing the kiocb cookie.
  */
-static void io_iopoll_req_issued(struct io_kiocb *req, bool in_async)
+static void io_iopoll_req_issued(struct io_kiocb *req)
 {
        struct io_ring_ctx *ctx = req->ctx;
+       const bool in_async = io_wq_current_is_worker();
+
+       /* workqueue context doesn't hold uring_lock, grab it now */
+       if (unlikely(in_async))
+               mutex_lock(&ctx->uring_lock);
 
        /*
         * Track whether we have multiple files in our lists. This will impact
@@ -2552,14 +2555,19 @@ static void io_iopoll_req_issued(struct io_kiocb *req, bool in_async)
        else
                list_add_tail(&req->inflight_entry, &ctx->iopoll_list);
 
-       /*
-        * If IORING_SETUP_SQPOLL is enabled, sqes are either handled in sq thread
-        * task context or in io worker task context. If current task context is
-        * sq thread, we don't need to check whether should wake up sq thread.
-        */
-       if (in_async && (ctx->flags & IORING_SETUP_SQPOLL) &&
-           wq_has_sleeper(&ctx->sq_data->wait))
-               wake_up(&ctx->sq_data->wait);
+       if (unlikely(in_async)) {
+               /*
+                * If IORING_SETUP_SQPOLL is enabled, sqes are either handle
+                * in sq thread task context or in io worker task context. If
+                * current task context is sq thread, we don't need to check
+                * whether should wake up sq thread.
+                */
+               if ((ctx->flags & IORING_SETUP_SQPOLL) &&
+                   wq_has_sleeper(&ctx->sq_data->wait))
+                       wake_up(&ctx->sq_data->wait);
+
+               mutex_unlock(&ctx->uring_lock);
+       }
 }
 
 static inline void io_state_file_put(struct io_submit_state *state)
@@ -2616,7 +2624,7 @@ static bool __io_file_supports_async(struct file *file, int rw)
                        return true;
                return false;
        }
-       if (S_ISCHR(mode) || S_ISSOCK(mode))
+       if (S_ISSOCK(mode))
                return true;
        if (S_ISREG(mode)) {
                if (IS_ENABLED(CONFIG_BLOCK) &&
@@ -2762,7 +2770,7 @@ static void kiocb_done(struct kiocb *kiocb, ssize_t ret,
                } else {
                        int cflags = 0;
 
-                       req_set_fail_links(req);
+                       req_set_fail(req);
                        if (req->flags & REQ_F_BUFFER_SELECTED)
                                cflags = io_put_rw_kbuf(req);
                        __io_req_complete(req, issue_flags, ret, cflags);
@@ -3233,7 +3241,7 @@ static bool io_rw_should_retry(struct io_kiocb *req)
        return true;
 }
 
-static int io_iter_do_read(struct io_kiocb *req, struct iov_iter *iter)
+static inline int io_iter_do_read(struct io_kiocb *req, struct iov_iter *iter)
 {
        if (req->file->f_op->read_iter)
                return call_read_iter(req->file, &req->rw.kiocb, iter);
@@ -3484,7 +3492,7 @@ static int io_renameat(struct io_kiocb *req, unsigned int issue_flags)
 
        req->flags &= ~REQ_F_NEED_CLEANUP;
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        io_req_complete(req, ret);
        return 0;
 }
@@ -3528,7 +3536,7 @@ static int io_unlinkat(struct io_kiocb *req, unsigned int issue_flags)
 
        req->flags &= ~REQ_F_NEED_CLEANUP;
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        io_req_complete(req, ret);
        return 0;
 }
@@ -3565,7 +3573,7 @@ static int io_shutdown(struct io_kiocb *req, unsigned int issue_flags)
 
        ret = __sys_shutdown_sock(sock, req->shutdown.how);
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        io_req_complete(req, ret);
        return 0;
 #else
@@ -3623,7 +3631,7 @@ static int io_tee(struct io_kiocb *req, unsigned int issue_flags)
        req->flags &= ~REQ_F_NEED_CLEANUP;
 
        if (ret != sp->len)
-               req_set_fail_links(req);
+               req_set_fail(req);
        io_req_complete(req, ret);
        return 0;
 }
@@ -3660,7 +3668,7 @@ static int io_splice(struct io_kiocb *req, unsigned int issue_flags)
        req->flags &= ~REQ_F_NEED_CLEANUP;
 
        if (ret != sp->len)
-               req_set_fail_links(req);
+               req_set_fail(req);
        io_req_complete(req, ret);
        return 0;
 }
@@ -3713,7 +3721,7 @@ static int io_fsync(struct io_kiocb *req, unsigned int issue_flags)
                                end > 0 ? end : LLONG_MAX,
                                req->sync.flags & IORING_FSYNC_DATASYNC);
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        io_req_complete(req, ret);
        return 0;
 }
@@ -3742,7 +3750,7 @@ static int io_fallocate(struct io_kiocb *req, unsigned int issue_flags)
        ret = vfs_fallocate(req->file, req->sync.mode, req->sync.off,
                                req->sync.len);
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        io_req_complete(req, ret);
        return 0;
 }
@@ -3861,7 +3869,7 @@ err:
        putname(req->open.filename);
        req->flags &= ~REQ_F_NEED_CLEANUP;
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        __io_req_complete(req, issue_flags, ret, 0);
        return 0;
 }
@@ -3933,7 +3941,7 @@ static int io_remove_buffers(struct io_kiocb *req, unsigned int issue_flags)
        if (head)
                ret = __io_remove_buffers(ctx, head, p->bgid, p->nbufs);
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
 
        /* complete before unlock, IOPOLL may need the lock */
        __io_req_complete(req, issue_flags, ret, 0);
@@ -4024,7 +4032,7 @@ static int io_provide_buffers(struct io_kiocb *req, unsigned int issue_flags)
                        __io_remove_buffers(ctx, head, p->bgid, -1U);
        }
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        /* complete before unlock, IOPOLL may need the lock */
        __io_req_complete(req, issue_flags, ret, 0);
        io_ring_submit_unlock(ctx, !force_nonblock);
@@ -4070,7 +4078,7 @@ static int io_epoll_ctl(struct io_kiocb *req, unsigned int issue_flags)
                return -EAGAIN;
 
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        __io_req_complete(req, issue_flags, ret, 0);
        return 0;
 #else
@@ -4106,7 +4114,7 @@ static int io_madvise(struct io_kiocb *req, unsigned int issue_flags)
 
        ret = do_madvise(current->mm, ma->addr, ma->len, ma->advice);
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        io_req_complete(req, ret);
        return 0;
 #else
@@ -4145,7 +4153,7 @@ static int io_fadvise(struct io_kiocb *req, unsigned int issue_flags)
 
        ret = vfs_fadvise(req->file, fa->offset, fa->len, fa->advice);
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        __io_req_complete(req, issue_flags, ret, 0);
        return 0;
 }
@@ -4180,7 +4188,7 @@ static int io_statx(struct io_kiocb *req, unsigned int issue_flags)
                       ctx->buffer);
 
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        io_req_complete(req, ret);
        return 0;
 }
@@ -4238,7 +4246,7 @@ static int io_close(struct io_kiocb *req, unsigned int issue_flags)
        ret = filp_close(file, current->files);
 err:
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        if (file)
                fput(file);
        __io_req_complete(req, issue_flags, ret, 0);
@@ -4271,7 +4279,7 @@ static int io_sync_file_range(struct io_kiocb *req, unsigned int issue_flags)
        ret = sync_file_range(req->file, req->sync.off, req->sync.len,
                                req->sync.flags);
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        io_req_complete(req, ret);
        return 0;
 }
@@ -4375,7 +4383,7 @@ static int io_sendmsg(struct io_kiocb *req, unsigned int issue_flags)
                kfree(kmsg->free_iov);
        req->flags &= ~REQ_F_NEED_CLEANUP;
        if (ret < min_ret)
-               req_set_fail_links(req);
+               req_set_fail(req);
        __io_req_complete(req, issue_flags, ret, 0);
        return 0;
 }
@@ -4417,7 +4425,7 @@ static int io_send(struct io_kiocb *req, unsigned int issue_flags)
                ret = -EINTR;
 
        if (ret < min_ret)
-               req_set_fail_links(req);
+               req_set_fail(req);
        __io_req_complete(req, issue_flags, ret, 0);
        return 0;
 }
@@ -4612,7 +4620,7 @@ static int io_recvmsg(struct io_kiocb *req, unsigned int issue_flags)
                kfree(kmsg->free_iov);
        req->flags &= ~REQ_F_NEED_CLEANUP;
        if (ret < min_ret || ((flags & MSG_WAITALL) && (kmsg->msg.msg_flags & (MSG_TRUNC | MSG_CTRUNC))))
-               req_set_fail_links(req);
+               req_set_fail(req);
        __io_req_complete(req, issue_flags, ret, cflags);
        return 0;
 }
@@ -4667,7 +4675,7 @@ out_free:
        if (req->flags & REQ_F_BUFFER_SELECTED)
                cflags = io_put_recv_kbuf(req);
        if (ret < min_ret || ((flags & MSG_WAITALL) && (msg.msg_flags & (MSG_TRUNC | MSG_CTRUNC))))
-               req_set_fail_links(req);
+               req_set_fail(req);
        __io_req_complete(req, issue_flags, ret, cflags);
        return 0;
 }
@@ -4706,7 +4714,7 @@ static int io_accept(struct io_kiocb *req, unsigned int issue_flags)
        if (ret < 0) {
                if (ret == -ERESTARTSYS)
                        ret = -EINTR;
-               req_set_fail_links(req);
+               req_set_fail(req);
        }
        __io_req_complete(req, issue_flags, ret, 0);
        return 0;
@@ -4770,7 +4778,7 @@ static int io_connect(struct io_kiocb *req, unsigned int issue_flags)
                ret = -EINTR;
 out:
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        __io_req_complete(req, issue_flags, ret, 0);
        return 0;
 }
@@ -5059,7 +5067,7 @@ static void io_async_task_func(struct callback_head *cb)
        struct async_poll *apoll = req->apoll;
        struct io_ring_ctx *ctx = req->ctx;
 
-       trace_io_uring_task_run(req->ctx, req->opcode, req->user_data);
+       trace_io_uring_task_run(req->ctx, req, req->opcode, req->user_data);
 
        if (io_poll_rewait(req, &apoll->poll)) {
                spin_unlock_irq(&ctx->completion_lock);
@@ -5192,8 +5200,8 @@ static bool io_arm_poll_handler(struct io_kiocb *req)
                return false;
        }
        spin_unlock_irq(&ctx->completion_lock);
-       trace_io_uring_poll_arm(ctx, req->opcode, req->user_data, mask,
-                                       apoll->poll.events);
+       trace_io_uring_poll_arm(ctx, req, req->opcode, req->user_data,
+                               mask, apoll->poll.events);
        return true;
 }
 
@@ -5241,7 +5249,7 @@ static bool io_poll_remove_one(struct io_kiocb *req)
        if (do_complete) {
                io_cqring_fill_event(req->ctx, req->user_data, -ECANCELED, 0);
                io_commit_cqring(req->ctx);
-               req_set_fail_links(req);
+               req_set_fail(req);
                io_put_req_deferred(req, 1);
        }
 
@@ -5252,7 +5260,7 @@ static bool io_poll_remove_one(struct io_kiocb *req)
  * Returns true if we found and killed one or more poll requests
  */
 static bool io_poll_remove_all(struct io_ring_ctx *ctx, struct task_struct *tsk,
-                              struct files_struct *files)
+                              bool cancel_all)
 {
        struct hlist_node *tmp;
        struct io_kiocb *req;
@@ -5264,7 +5272,7 @@ static bool io_poll_remove_all(struct io_ring_ctx *ctx, struct task_struct *tsk,
 
                list = &ctx->cancel_hash[i];
                hlist_for_each_entry_safe(req, tmp, list, hash_node) {
-                       if (io_match_task(req, tsk, files))
+                       if (io_match_task(req, tsk, cancel_all))
                                posted += io_poll_remove_one(req);
                }
        }
@@ -5451,7 +5459,7 @@ static int io_poll_update(struct io_kiocb *req, unsigned int issue_flags)
 err:
        if (ret < 0) {
                spin_unlock_irq(&ctx->completion_lock);
-               req_set_fail_links(req);
+               req_set_fail(req);
                io_req_complete(req, ret);
                return 0;
        }
@@ -5471,7 +5479,7 @@ err:
        if (!completing) {
                ret = io_poll_add(preq, issue_flags);
                if (ret < 0) {
-                       req_set_fail_links(preq);
+                       req_set_fail(preq);
                        io_req_complete(preq, ret);
                }
        }
@@ -5496,7 +5504,7 @@ static enum hrtimer_restart io_timeout_fn(struct hrtimer *timer)
        spin_unlock_irqrestore(&ctx->completion_lock, flags);
 
        io_cqring_ev_posted(ctx);
-       req_set_fail_links(req);
+       req_set_fail(req);
        io_put_req(req);
        return HRTIMER_NORESTART;
 }
@@ -5532,7 +5540,7 @@ static int io_timeout_cancel(struct io_ring_ctx *ctx, __u64 user_data)
        if (IS_ERR(req))
                return PTR_ERR(req);
 
-       req_set_fail_links(req);
+       req_set_fail(req);
        io_cqring_fill_event(ctx, req->user_data, -ECANCELED, 0);
        io_put_req_deferred(req, 1);
        return 0;
@@ -5611,7 +5619,7 @@ static int io_timeout_remove(struct io_kiocb *req, unsigned int issue_flags)
        spin_unlock_irq(&ctx->completion_lock);
        io_cqring_ev_posted(ctx);
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        io_put_req(req);
        return 0;
 }
@@ -5634,6 +5642,8 @@ static int io_timeout_prep(struct io_kiocb *req, const struct io_uring_sqe *sqe,
                return -EINVAL;
 
        req->timeout.off = off;
+       if (unlikely(off && !req->ctx->off_timeout_used))
+               req->ctx->off_timeout_used = true;
 
        if (!req->async_data && io_alloc_async_data(req))
                return -ENOMEM;
@@ -5764,7 +5774,7 @@ done:
        io_cqring_ev_posted(ctx);
 
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
 }
 
 static int io_async_cancel_prep(struct io_kiocb *req,
@@ -5821,7 +5831,7 @@ done:
        io_cqring_ev_posted(ctx);
 
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        io_put_req(req);
        return 0;
 }
@@ -5863,7 +5873,7 @@ static int io_files_update(struct io_kiocb *req, unsigned int issue_flags)
        mutex_unlock(&ctx->uring_lock);
 
        if (ret < 0)
-               req_set_fail_links(req);
+               req_set_fail(req);
        __io_req_complete(req, issue_flags, ret, 0);
        return 0;
 }
@@ -5974,48 +5984,69 @@ static int io_req_prep_async(struct io_kiocb *req)
 
 static u32 io_get_sequence(struct io_kiocb *req)
 {
-       struct io_kiocb *pos;
-       struct io_ring_ctx *ctx = req->ctx;
-       u32 total_submitted, nr_reqs = 0;
-
-       io_for_each_link(pos, req)
-               nr_reqs++;
+       u32 seq = req->ctx->cached_sq_head;
 
-       total_submitted = ctx->cached_sq_head - ctx->cached_sq_dropped;
-       return total_submitted - nr_reqs;
+       /* need original cached_sq_head, but it was increased for each req */
+       io_for_each_link(req, req)
+               seq--;
+       return seq;
 }
 
-static int io_req_defer(struct io_kiocb *req)
+static bool io_drain_req(struct io_kiocb *req)
 {
+       struct io_kiocb *pos;
        struct io_ring_ctx *ctx = req->ctx;
        struct io_defer_entry *de;
        int ret;
        u32 seq;
 
+       /*
+        * If we need to drain a request in the middle of a link, drain the
+        * head request and the next request/link after the current link.
+        * Considering sequential execution of links, IOSQE_IO_DRAIN will be
+        * maintained for every request of our link.
+        */
+       if (ctx->drain_next) {
+               req->flags |= REQ_F_IO_DRAIN;
+               ctx->drain_next = false;
+       }
+       /* not interested in head, start from the first linked */
+       io_for_each_link(pos, req->link) {
+               if (pos->flags & REQ_F_IO_DRAIN) {
+                       ctx->drain_next = true;
+                       req->flags |= REQ_F_IO_DRAIN;
+                       break;
+               }
+       }
+
        /* Still need defer if there is pending req in defer list. */
        if (likely(list_empty_careful(&ctx->defer_list) &&
-               !(req->flags & REQ_F_IO_DRAIN)))
-               return 0;
+               !(req->flags & REQ_F_IO_DRAIN))) {
+               ctx->drain_active = false;
+               return false;
+       }
 
        seq = io_get_sequence(req);
        /* Still a chance to pass the sequence check */
        if (!req_need_defer(req, seq) && list_empty_careful(&ctx->defer_list))
-               return 0;
+               return false;
 
        ret = io_req_prep_async(req);
        if (ret)
                return ret;
        io_prep_async_link(req);
        de = kmalloc(sizeof(*de), GFP_KERNEL);
-       if (!de)
-               return -ENOMEM;
+       if (!de) {
+               io_req_complete_failed(req, ret);
+               return true;
+       }
 
        spin_lock_irq(&ctx->completion_lock);
        if (!req_need_defer(req, seq) && list_empty(&ctx->defer_list)) {
                spin_unlock_irq(&ctx->completion_lock);
                kfree(de);
                io_queue_async_work(req);
-               return -EIOCBQUEUED;
+               return true;
        }
 
        trace_io_uring_defer(ctx, req, req->user_data);
@@ -6023,7 +6054,7 @@ static int io_req_defer(struct io_kiocb *req)
        de->seq = seq;
        list_add_tail(&de->list, &ctx->defer_list);
        spin_unlock_irq(&ctx->completion_lock);
-       return -EIOCBQUEUED;
+       return true;
 }
 
 static void io_clean_op(struct io_kiocb *req)
@@ -6040,7 +6071,6 @@ static void io_clean_op(struct io_kiocb *req)
                        kfree(req->sr_msg.kbuf);
                        break;
                }
-               req->flags &= ~REQ_F_BUFFER_SELECTED;
        }
 
        if (req->flags & REQ_F_NEED_CLEANUP) {
@@ -6052,8 +6082,8 @@ static void io_clean_op(struct io_kiocb *req)
                case IORING_OP_WRITE_FIXED:
                case IORING_OP_WRITE: {
                        struct io_async_rw *io = req->async_data;
-                       if (io->free_iovec)
-                               kfree(io->free_iovec);
+
+                       kfree(io->free_iovec);
                        break;
                        }
                case IORING_OP_RECVMSG:
@@ -6081,7 +6111,6 @@ static void io_clean_op(struct io_kiocb *req)
                        putname(req->unlink.filename);
                        break;
                }
-               req->flags &= ~REQ_F_NEED_CLEANUP;
        }
        if ((req->flags & REQ_F_POLLED) && req->apoll) {
                kfree(req->apoll->double_poll);
@@ -6092,8 +6121,11 @@ static void io_clean_op(struct io_kiocb *req)
                struct io_uring_task *tctx = req->task->io_uring;
 
                atomic_dec(&tctx->inflight_tracked);
-               req->flags &= ~REQ_F_INFLIGHT;
        }
+       if (req->flags & REQ_F_CREDS)
+               put_cred(req->creds);
+
+       req->flags &= ~IO_REQ_CLEAN_FLAGS;
 }
 
 static int io_issue_sqe(struct io_kiocb *req, unsigned int issue_flags)
@@ -6102,8 +6134,8 @@ static int io_issue_sqe(struct io_kiocb *req, unsigned int issue_flags)
        const struct cred *creds = NULL;
        int ret;
 
-       if (req->work.creds && req->work.creds != current_cred())
-               creds = override_creds(req->work.creds);
+       if ((req->flags & REQ_F_CREDS) && req->creds != current_cred())
+               creds = override_creds(req->creds);
 
        switch (req->opcode) {
        case IORING_OP_NOP:
@@ -6213,23 +6245,11 @@ static int io_issue_sqe(struct io_kiocb *req, unsigned int issue_flags)
 
        if (creds)
                revert_creds(creds);
-
        if (ret)
                return ret;
-
        /* If the op doesn't have a file, we're not polling for it */
-       if ((ctx->flags & IORING_SETUP_IOPOLL) && req->file) {
-               const bool in_async = io_wq_current_is_worker();
-
-               /* workqueue context doesn't hold uring_lock, grab it now */
-               if (in_async)
-                       mutex_lock(&ctx->uring_lock);
-
-               io_iopoll_req_issued(req, in_async);
-
-               if (in_async)
-                       mutex_unlock(&ctx->uring_lock);
-       }
+       if ((ctx->flags & IORING_SETUP_IOPOLL) && req->file)
+               io_iopoll_req_issued(req);
 
        return 0;
 }
@@ -6425,7 +6445,7 @@ static void __io_queue_sqe(struct io_kiocb *req)
 
                        cs->reqs[cs->nr++] = req;
                        if (cs->nr == ARRAY_SIZE(cs->reqs))
-                               io_submit_flush_completions(cs, ctx);
+                               io_submit_flush_completions(ctx);
                } else {
                        io_put_req(req);
                }
@@ -6444,23 +6464,20 @@ static void __io_queue_sqe(struct io_kiocb *req)
                io_queue_linked_timeout(linked_timeout);
 }
 
-static void io_queue_sqe(struct io_kiocb *req)
+static inline void io_queue_sqe(struct io_kiocb *req)
 {
-       int ret;
+       if (unlikely(req->ctx->drain_active) && io_drain_req(req))
+               return;
 
-       ret = io_req_defer(req);
-       if (ret) {
-               if (ret != -EIOCBQUEUED) {
-fail_req:
-                       io_req_complete_failed(req, ret);
-               }
-       } else if (req->flags & REQ_F_FORCE_ASYNC) {
-               ret = io_req_prep_async(req);
-               if (unlikely(ret))
-                       goto fail_req;
-               io_queue_async_work(req);
-       } else {
+       if (likely(!(req->flags & REQ_F_FORCE_ASYNC))) {
                __io_queue_sqe(req);
+       } else {
+               int ret = io_req_prep_async(req);
+
+               if (unlikely(ret))
+                       io_req_complete_failed(req, ret);
+               else
+                       io_queue_async_work(req);
        }
 }
 
@@ -6510,7 +6527,6 @@ static int io_init_req(struct io_ring_ctx *ctx, struct io_kiocb *req,
        atomic_set(&req->refs, 2);
        req->task = current;
        req->result = 0;
-       req->work.creds = NULL;
 
        /* enforce forwards compatibility on users */
        if (unlikely(sqe_flags & ~SQE_VALID_FLAGS))
@@ -6523,13 +6539,16 @@ static int io_init_req(struct io_ring_ctx *ctx, struct io_kiocb *req,
        if ((sqe_flags & IOSQE_BUFFER_SELECT) &&
            !io_op_defs[req->opcode].buffer_select)
                return -EOPNOTSUPP;
+       if (unlikely(sqe_flags & IOSQE_IO_DRAIN))
+               ctx->drain_active = true;
 
        personality = READ_ONCE(sqe->personality);
        if (personality) {
-               req->work.creds = xa_load(&ctx->personalities, personality);
-               if (!req->work.creds)
+               req->creds = xa_load(&ctx->personalities, personality);
+               if (!req->creds)
                        return -EINVAL;
-               get_cred(req->work.creds);
+               get_cred(req->creds);
+               req->flags |= REQ_F_CREDS;
        }
        state = &ctx->submit_state;
 
@@ -6566,20 +6585,22 @@ static int io_submit_sqe(struct io_ring_ctx *ctx, struct io_kiocb *req,
 fail_req:
                if (link->head) {
                        /* fail even hard links since we don't submit */
-                       link->head->flags |= REQ_F_FAIL_LINK;
+                       req_set_fail(link->head);
                        io_req_complete_failed(link->head, -ECANCELED);
                        link->head = NULL;
                }
                io_req_complete_failed(req, ret);
                return ret;
        }
+
        ret = io_req_prep(req, sqe);
        if (unlikely(ret))
                goto fail_req;
 
        /* don't need @sqe from now on */
-       trace_io_uring_submit_sqe(ctx, req->opcode, req->user_data,
-                               true, ctx->flags & IORING_SETUP_SQPOLL);
+       trace_io_uring_submit_sqe(ctx, req, req->opcode, req->user_data,
+                                 req->flags, true,
+                                 ctx->flags & IORING_SETUP_SQPOLL);
 
        /*
         * If we already have a head request, queue this one for async
@@ -6591,17 +6612,6 @@ fail_req:
        if (link->head) {
                struct io_kiocb *head = link->head;
 
-               /*
-                * Taking sequential execution of a link, draining both sides
-                * of the link also fullfils IOSQE_IO_DRAIN semantics for all
-                * requests in the link. So, it drains the head and the
-                * next after the link request. The last one is done via
-                * drain_next flag to persist the effect across calls.
-                */
-               if (req->flags & REQ_F_IO_DRAIN) {
-                       head->flags |= REQ_F_IO_DRAIN;
-                       ctx->drain_next = 1;
-               }
                ret = io_req_prep_async(req);
                if (unlikely(ret))
                        goto fail_req;
@@ -6611,14 +6621,10 @@ fail_req:
 
                /* last request of a link, enqueue the link */
                if (!(req->flags & (REQ_F_LINK | REQ_F_HARDLINK))) {
-                       io_queue_sqe(head);
                        link->head = NULL;
+                       io_queue_sqe(head);
                }
        } else {
-               if (unlikely(ctx->drain_next)) {
-                       req->flags |= REQ_F_IO_DRAIN;
-                       ctx->drain_next = 0;
-               }
                if (req->flags & (REQ_F_LINK | REQ_F_HARDLINK)) {
                        link->head = req;
                        link->last = req;
@@ -6639,7 +6645,7 @@ static void io_submit_state_end(struct io_submit_state *state,
        if (state->link.head)
                io_queue_sqe(state->link.head);
        if (state->comp.nr)
-               io_submit_flush_completions(&state->comp, ctx);
+               io_submit_flush_completions(ctx);
        if (state->plug_started)
                blk_finish_plug(&state->plug);
        io_state_file_put(state);
@@ -6670,7 +6676,7 @@ static void io_commit_sqring(struct io_ring_ctx *ctx)
 }
 
 /*
- * Fetch an sqe, if one is available. Note that sqe_ptr will point to memory
+ * Fetch an sqe, if one is available. Note this returns a pointer to memory
  * that is mapped by userspace. This means that care needs to be taken to
  * ensure that reads are stable, as we cannot rely on userspace always
  * being a good citizen. If members of the sqe are validated and then later
@@ -6679,8 +6685,8 @@ static void io_commit_sqring(struct io_ring_ctx *ctx)
  */
 static const struct io_uring_sqe *io_get_sqe(struct io_ring_ctx *ctx)
 {
-       u32 *sq_array = ctx->sq_array;
-       unsigned head;
+       unsigned head, mask = ctx->sq_entries - 1;
+       unsigned sq_idx = ctx->cached_sq_head++ & mask;
 
        /*
         * The cached sq head (or cq tail) serves two purposes:
@@ -6690,28 +6696,36 @@ static const struct io_uring_sqe *io_get_sqe(struct io_ring_ctx *ctx)
         * 2) allows the kernel side to track the head on its own, even
         *    though the application is the one updating it.
         */
-       head = READ_ONCE(sq_array[ctx->cached_sq_head++ & ctx->sq_mask]);
+       head = READ_ONCE(ctx->sq_array[sq_idx]);
        if (likely(head < ctx->sq_entries))
                return &ctx->sq_sqes[head];
 
        /* drop invalid entries */
-       ctx->cached_sq_dropped++;
-       WRITE_ONCE(ctx->rings->sq_dropped, ctx->cached_sq_dropped);
+       ctx->cq_extra--;
+       WRITE_ONCE(ctx->rings->sq_dropped,
+                  READ_ONCE(ctx->rings->sq_dropped) + 1);
        return NULL;
 }
 
 static int io_submit_sqes(struct io_ring_ctx *ctx, unsigned int nr)
 {
+       struct io_uring_task *tctx;
        int submitted = 0;
 
        /* make sure SQ entry isn't read before tail */
        nr = min3(nr, ctx->sq_entries, io_sqring_entries(ctx));
-
        if (!percpu_ref_tryget_many(&ctx->refs, nr))
                return -EAGAIN;
 
-       percpu_counter_add(&current->io_uring->inflight, nr);
-       refcount_add(nr, &current->usage);
+       tctx = current->io_uring;
+       tctx->cached_refs -= nr;
+       if (unlikely(tctx->cached_refs < 0)) {
+               unsigned int refill = -tctx->cached_refs + IO_TCTX_REFS_CACHE_NR;
+
+               percpu_counter_add(&tctx->inflight, refill);
+               refcount_add(refill, &current->usage);
+               tctx->cached_refs += refill;
+       }
        io_submit_state_start(&ctx->submit_state, nr);
 
        while (submitted < nr) {
@@ -6737,12 +6751,10 @@ static int io_submit_sqes(struct io_ring_ctx *ctx, unsigned int nr)
 
        if (unlikely(submitted != nr)) {
                int ref_used = (submitted == -EAGAIN) ? 0 : submitted;
-               struct io_uring_task *tctx = current->io_uring;
                int unused = nr - ref_used;
 
+               current->io_uring->cached_refs += unused;
                percpu_ref_put_many(&ctx->refs, unused);
-               percpu_counter_sub(&tctx->inflight, unused);
-               put_task_struct_many(current, unused);
        }
 
        io_submit_state_end(&ctx->submit_state, ctx);
@@ -6752,6 +6764,11 @@ static int io_submit_sqes(struct io_ring_ctx *ctx, unsigned int nr)
        return submitted;
 }
 
+static inline bool io_sqd_events_pending(struct io_sq_data *sqd)
+{
+       return READ_ONCE(sqd->state);
+}
+
 static inline void io_ring_set_wakeup_flag(struct io_ring_ctx *ctx)
 {
        /* Tell userspace we may need a wakeup call */
@@ -6792,10 +6809,10 @@ static int __io_sq_thread(struct io_ring_ctx *ctx, bool cap_entries)
                    !(ctx->flags & IORING_SETUP_R_DISABLED))
                        ret = io_submit_sqes(ctx, to_submit);
                mutex_unlock(&ctx->uring_lock);
-       }
 
-       if (!io_sqring_full(ctx) && wq_has_sleeper(&ctx->sqo_sq_wait))
-               wake_up(&ctx->sqo_sq_wait);
+               if (to_submit && wq_has_sleeper(&ctx->sqo_sq_wait))
+                       wake_up(&ctx->sqo_sq_wait);
+       }
 
        return ret;
 }
@@ -6810,6 +6827,23 @@ static void io_sqd_update_thread_idle(struct io_sq_data *sqd)
        sqd->sq_thread_idle = sq_thread_idle;
 }
 
+static bool io_sqd_handle_event(struct io_sq_data *sqd)
+{
+       bool did_sig = false;
+       struct ksignal ksig;
+
+       if (test_bit(IO_SQ_THREAD_SHOULD_PARK, &sqd->state) ||
+           signal_pending(current)) {
+               mutex_unlock(&sqd->lock);
+               if (signal_pending(current))
+                       did_sig = get_signal(&ksig);
+               cond_resched();
+               mutex_lock(&sqd->lock);
+       }
+       io_run_task_work();
+       return did_sig || test_bit(IO_SQ_THREAD_SHOULD_STOP, &sqd->state);
+}
+
 static int io_sq_thread(void *data)
 {
        struct io_sq_data *sqd = data;
@@ -6828,32 +6862,17 @@ static int io_sq_thread(void *data)
        current->flags |= PF_NO_SETAFFINITY;
 
        mutex_lock(&sqd->lock);
-       /* a user may had exited before the thread started */
-       io_run_task_work_head(&sqd->park_task_work);
-
-       while (!test_bit(IO_SQ_THREAD_SHOULD_STOP, &sqd->state)) {
+       while (1) {
                int ret;
                bool cap_entries, sqt_spin, needs_sched;
 
-               if (test_bit(IO_SQ_THREAD_SHOULD_PARK, &sqd->state) ||
-                   signal_pending(current)) {
-                       bool did_sig = false;
-
-                       mutex_unlock(&sqd->lock);
-                       if (signal_pending(current)) {
-                               struct ksignal ksig;
-
-                               did_sig = get_signal(&ksig);
-                       }
-                       cond_resched();
-                       mutex_lock(&sqd->lock);
-                       io_run_task_work();
-                       io_run_task_work_head(&sqd->park_task_work);
-                       if (did_sig)
+               if (io_sqd_events_pending(sqd) || signal_pending(current)) {
+                       if (io_sqd_handle_event(sqd))
                                break;
                        timeout = jiffies + sqd->sq_thread_idle;
                        continue;
                }
+
                sqt_spin = false;
                cap_entries = !list_is_singular(&sqd->ctx_list);
                list_for_each_entry(ctx, &sqd->ctx_list, sqd_list) {
@@ -6877,12 +6896,11 @@ static int io_sq_thread(void *data)
                }
 
                prepare_to_wait(&sqd->wait, &wait, TASK_INTERRUPTIBLE);
-               if (!test_bit(IO_SQ_THREAD_SHOULD_PARK, &sqd->state)) {
-                       list_for_each_entry(ctx, &sqd->ctx_list, sqd_list)
-                               io_ring_set_wakeup_flag(ctx);
-
+               if (!io_sqd_events_pending(sqd)) {
                        needs_sched = true;
                        list_for_each_entry(ctx, &sqd->ctx_list, sqd_list) {
+                               io_ring_set_wakeup_flag(ctx);
+
                                if ((ctx->flags & IORING_SETUP_IOPOLL) &&
                                    !list_empty_careful(&ctx->iopoll_list)) {
                                        needs_sched = false;
@@ -6904,16 +6922,14 @@ static int io_sq_thread(void *data)
                }
 
                finish_wait(&sqd->wait, &wait);
-               io_run_task_work_head(&sqd->park_task_work);
                timeout = jiffies + sqd->sq_thread_idle;
        }
 
-       io_uring_cancel_sqpoll(sqd);
+       io_uring_cancel_generic(true, sqd);
        sqd->thread = NULL;
        list_for_each_entry(ctx, &sqd->ctx_list, sqd_list)
                io_ring_set_wakeup_flag(ctx);
        io_run_task_work();
-       io_run_task_work_head(&sqd->park_task_work);
        mutex_unlock(&sqd->lock);
 
        complete(&sqd->exited);
@@ -6950,7 +6966,7 @@ static int io_wake_function(struct wait_queue_entry *curr, unsigned int mode,
         * Cannot safely flush overflowed CQEs from here, ensure we wake up
         * the task, and the next invocation will do it.
         */
-       if (io_should_wake(iowq) || test_bit(0, &iowq->ctx->cq_check_overflow))
+       if (io_should_wake(iowq) || test_bit(0, &iowq->ctx->check_cq_overflow))
                return autoremove_wake_function(curr, mode, wake_flags, key);
        return -1;
 }
@@ -6978,7 +6994,7 @@ static inline int io_cqring_wait_schedule(struct io_ring_ctx *ctx,
        if (ret || io_should_wake(iowq))
                return ret;
        /* let the caller flush overflows, retry */
-       if (test_bit(0, &ctx->cq_check_overflow))
+       if (test_bit(0, &ctx->check_cq_overflow))
                return 1;
 
        *timeout = schedule_timeout(*timeout);
@@ -7043,10 +7059,10 @@ static int io_cqring_wait(struct io_ring_ctx *ctx, int min_events,
                        ret = -EBUSY;
                        break;
                }
-               prepare_to_wait_exclusive(&ctx->wait, &iowq.wq,
+               prepare_to_wait_exclusive(&ctx->cq_wait, &iowq.wq,
                                                TASK_INTERRUPTIBLE);
                ret = io_cqring_wait_schedule(ctx, &iowq, &timeout);
-               finish_wait(&ctx->wait, &iowq.wq);
+               finish_wait(&ctx->cq_wait, &iowq.wq);
                cond_resched();
        } while (ret > 0);
 
@@ -7055,14 +7071,36 @@ static int io_cqring_wait(struct io_ring_ctx *ctx, int min_events,
        return READ_ONCE(rings->cq.head) == READ_ONCE(rings->cq.tail) ? ret : 0;
 }
 
-static void io_free_file_tables(struct io_file_table *table, unsigned nr_files)
+static void io_free_page_table(void **table, size_t size)
 {
-       unsigned i, nr_tables = DIV_ROUND_UP(nr_files, IORING_MAX_FILES_TABLE);
+       unsigned i, nr_tables = DIV_ROUND_UP(size, PAGE_SIZE);
 
        for (i = 0; i < nr_tables; i++)
-               kfree(table->files[i]);
-       kfree(table->files);
-       table->files = NULL;
+               kfree(table[i]);
+       kfree(table);
+}
+
+static void **io_alloc_page_table(size_t size)
+{
+       unsigned i, nr_tables = DIV_ROUND_UP(size, PAGE_SIZE);
+       size_t init_size = size;
+       void **table;
+
+       table = kcalloc(nr_tables, sizeof(*table), GFP_KERNEL);
+       if (!table)
+               return NULL;
+
+       for (i = 0; i < nr_tables; i++) {
+               unsigned int this_size = min_t(size_t, size, PAGE_SIZE);
+
+               table[i] = kzalloc(this_size, GFP_KERNEL);
+               if (!table[i]) {
+                       io_free_page_table(table, init_size);
+                       return NULL;
+               }
+               size -= this_size;
+       }
+       return table;
 }
 
 static inline void io_rsrc_ref_lock(struct io_ring_ctx *ctx)
@@ -7151,33 +7189,77 @@ static int io_rsrc_ref_quiesce(struct io_rsrc_data *data, struct io_ring_ctx *ct
        return ret;
 }
 
+static u64 *io_get_tag_slot(struct io_rsrc_data *data, unsigned int idx)
+{
+       unsigned int off = idx & IO_RSRC_TAG_TABLE_MASK;
+       unsigned int table_idx = idx >> IO_RSRC_TAG_TABLE_SHIFT;
+
+       return &data->tags[table_idx][off];
+}
+
 static void io_rsrc_data_free(struct io_rsrc_data *data)
 {
-       kvfree(data->tags);
+       size_t size = data->nr * sizeof(data->tags[0][0]);
+
+       if (data->tags)
+               io_free_page_table((void **)data->tags, size);
        kfree(data);
 }
 
-static struct io_rsrc_data *io_rsrc_data_alloc(struct io_ring_ctx *ctx,
-                                              rsrc_put_fn *do_put,
-                                              unsigned nr)
+static int io_rsrc_data_alloc(struct io_ring_ctx *ctx, rsrc_put_fn *do_put,
+                             u64 __user *utags, unsigned nr,
+                             struct io_rsrc_data **pdata)
 {
        struct io_rsrc_data *data;
+       int ret = -ENOMEM;
+       unsigned i;
 
        data = kzalloc(sizeof(*data), GFP_KERNEL);
        if (!data)
-               return NULL;
-
-       data->tags = kvcalloc(nr, sizeof(*data->tags), GFP_KERNEL);
+               return -ENOMEM;
+       data->tags = (u64 **)io_alloc_page_table(nr * sizeof(data->tags[0][0]));
        if (!data->tags) {
                kfree(data);
-               return NULL;
+               return -ENOMEM;
        }
 
-       atomic_set(&data->refs, 1);
+       data->nr = nr;
        data->ctx = ctx;
        data->do_put = do_put;
+       if (utags) {
+               ret = -EFAULT;
+               for (i = 0; i < nr; i++) {
+                       u64 *tag_slot = io_get_tag_slot(data, i);
+
+                       if (copy_from_user(tag_slot, &utags[i],
+                                          sizeof(*tag_slot)))
+                               goto fail;
+               }
+       }
+
+       atomic_set(&data->refs, 1);
        init_completion(&data->done);
-       return data;
+       *pdata = data;
+       return 0;
+fail:
+       io_rsrc_data_free(data);
+       return ret;
+}
+
+static bool io_alloc_file_tables(struct io_file_table *table, unsigned nr_files)
+{
+       size_t size = nr_files * sizeof(struct io_fixed_file);
+
+       table->files = (struct io_fixed_file **)io_alloc_page_table(size);
+       return !!table->files;
+}
+
+static void io_free_file_tables(struct io_file_table *table, unsigned nr_files)
+{
+       size_t size = nr_files * sizeof(struct io_fixed_file);
+
+       io_free_page_table((void **)table->files, size);
+       table->files = NULL;
 }
 
 static void __io_sqe_files_unregister(struct io_ring_ctx *ctx)
@@ -7441,31 +7523,6 @@ static int io_sqe_files_scm(struct io_ring_ctx *ctx)
 }
 #endif
 
-static bool io_alloc_file_tables(struct io_file_table *table, unsigned nr_files)
-{
-       unsigned i, nr_tables = DIV_ROUND_UP(nr_files, IORING_MAX_FILES_TABLE);
-
-       table->files = kcalloc(nr_tables, sizeof(*table->files), GFP_KERNEL);
-       if (!table->files)
-               return false;
-
-       for (i = 0; i < nr_tables; i++) {
-               unsigned int this_files = min(nr_files, IORING_MAX_FILES_TABLE);
-
-               table->files[i] = kcalloc(this_files, sizeof(*table->files[i]),
-                                       GFP_KERNEL);
-               if (!table->files[i])
-                       break;
-               nr_files -= this_files;
-       }
-
-       if (i == nr_tables)
-               return true;
-
-       io_free_file_tables(table, nr_tables * IORING_MAX_FILES_TABLE);
-       return false;
-}
-
 static void io_rsrc_file_put(struct io_ring_ctx *ctx, struct io_rsrc_put *prsrc)
 {
        struct file *file = prsrc->file;
@@ -7540,14 +7597,13 @@ static void __io_rsrc_put_work(struct io_rsrc_node *ref_node)
 
                if (prsrc->tag) {
                        bool lock_ring = ctx->flags & IORING_SETUP_IOPOLL;
-                       unsigned long flags;
 
                        io_ring_submit_lock(ctx, lock_ring);
-                       spin_lock_irqsave(&ctx->completion_lock, flags);
+                       spin_lock_irq(&ctx->completion_lock);
                        io_cqring_fill_event(ctx, prsrc->tag, 0, 0);
                        ctx->cq_extra++;
                        io_commit_cqring(ctx);
-                       spin_unlock_irqrestore(&ctx->completion_lock, flags);
+                       spin_unlock_irq(&ctx->completion_lock);
                        io_cqring_ev_posted(ctx);
                        io_ring_submit_unlock(ctx, lock_ring);
                }
@@ -7629,7 +7685,6 @@ static int io_sqe_files_register(struct io_ring_ctx *ctx, void __user *arg,
        struct file *file;
        int fd, ret;
        unsigned i;
-       struct io_rsrc_data *file_data;
 
        if (ctx->file_data)
                return -EBUSY;
@@ -7640,27 +7695,24 @@ static int io_sqe_files_register(struct io_ring_ctx *ctx, void __user *arg,
        ret = io_rsrc_node_switch_start(ctx);
        if (ret)
                return ret;
+       ret = io_rsrc_data_alloc(ctx, io_rsrc_file_put, tags, nr_args,
+                                &ctx->file_data);
+       if (ret)
+               return ret;
 
-       file_data = io_rsrc_data_alloc(ctx, io_rsrc_file_put, nr_args);
-       if (!file_data)
-               return -ENOMEM;
-       ctx->file_data = file_data;
        ret = -ENOMEM;
        if (!io_alloc_file_tables(&ctx->file_table, nr_args))
                goto out_free;
 
        for (i = 0; i < nr_args; i++, ctx->nr_user_files++) {
-               u64 tag = 0;
-
-               if ((tags && copy_from_user(&tag, &tags[i], sizeof(tag))) ||
-                   copy_from_user(&fd, &fds[i], sizeof(fd))) {
+               if (copy_from_user(&fd, &fds[i], sizeof(fd))) {
                        ret = -EFAULT;
                        goto out_fput;
                }
                /* allow sparse sets */
                if (fd == -1) {
                        ret = -EINVAL;
-                       if (unlikely(tag))
+                       if (unlikely(*io_get_tag_slot(ctx->file_data, i)))
                                goto out_fput;
                        continue;
                }
@@ -7681,7 +7733,6 @@ static int io_sqe_files_register(struct io_ring_ctx *ctx, void __user *arg,
                        fput(file);
                        goto out_fput;
                }
-               ctx->file_data->tags[i] = tag;
                io_fixed_file_set(io_fixed_file_slot(&ctx->file_table, i), file);
        }
 
@@ -7759,7 +7810,7 @@ static int io_queue_rsrc_removal(struct io_rsrc_data *data, unsigned idx,
        if (!prsrc)
                return -ENOMEM;
 
-       prsrc->tag = data->tags[idx];
+       prsrc->tag = *io_get_tag_slot(data, idx);
        prsrc->rsrc = rsrc;
        list_add(&prsrc->list, &node->rsrc_list);
        return 0;
@@ -7829,7 +7880,7 @@ static int __io_sqe_files_update(struct io_ring_ctx *ctx,
                                err = -EBADF;
                                break;
                        }
-                       data->tags[up->offset + done] = tag;
+                       *io_get_tag_slot(data, up->offset + done) = tag;
                        io_fixed_file_set(file_slot, file);
                        err = io_sqe_file_register(ctx, file, i);
                        if (err) {
@@ -7887,7 +7938,7 @@ static int io_uring_alloc_task_context(struct task_struct *task,
        struct io_uring_task *tctx;
        int ret;
 
-       tctx = kmalloc(sizeof(*tctx), GFP_KERNEL);
+       tctx = kzalloc(sizeof(*tctx), GFP_KERNEL);
        if (unlikely(!tctx))
                return -ENOMEM;
 
@@ -7907,13 +7958,11 @@ static int io_uring_alloc_task_context(struct task_struct *task,
 
        xa_init(&tctx->xa);
        init_waitqueue_head(&tctx->wait);
-       tctx->last = NULL;
        atomic_set(&tctx->in_idle, 0);
        atomic_set(&tctx->inflight_tracked, 0);
        task->io_uring = tctx;
        spin_lock_init(&tctx->task_lock);
        INIT_WQ_LIST(&tctx->task_list);
-       tctx->task_state = 0;
        init_task_work(&tctx->task_work, tctx_task_work);
        return 0;
 }
@@ -7924,6 +7973,7 @@ void __io_uring_free(struct task_struct *tsk)
 
        WARN_ON_ONCE(!xa_empty(&tctx->xa));
        WARN_ON_ONCE(tctx->io_wq);
+       WARN_ON_ONCE(tctx->cached_refs);
 
        percpu_counter_destroy(&tctx->inflight);
        kfree(tctx);
@@ -8300,6 +8350,8 @@ static int io_sqe_buffer_register(struct io_ring_ctx *ctx, struct iovec *iov,
                for (i = 0; i < nr_pages; i++) {
                        struct vm_area_struct *vma = vmas[i];
 
+                       if (vma_is_shmem(vma))
+                               continue;
                        if (vma->vm_file &&
                            !is_file_hugepages(vma->vm_file)) {
                                ret = -EOPNOTSUPP;
@@ -8397,9 +8449,9 @@ static int io_sqe_buffers_register(struct io_ring_ctx *ctx, void __user *arg,
        ret = io_rsrc_node_switch_start(ctx);
        if (ret)
                return ret;
-       data = io_rsrc_data_alloc(ctx, io_rsrc_buf_put, nr_args);
-       if (!data)
-               return -ENOMEM;
+       ret = io_rsrc_data_alloc(ctx, io_rsrc_buf_put, tags, nr_args, &data);
+       if (ret)
+               return ret;
        ret = io_buffers_map_alloc(ctx, nr_args);
        if (ret) {
                io_rsrc_data_free(data);
@@ -8407,19 +8459,13 @@ static int io_sqe_buffers_register(struct io_ring_ctx *ctx, void __user *arg,
        }
 
        for (i = 0; i < nr_args; i++, ctx->nr_user_bufs++) {
-               u64 tag = 0;
-
-               if (tags && copy_from_user(&tag, &tags[i], sizeof(tag))) {
-                       ret = -EFAULT;
-                       break;
-               }
                ret = io_copy_iov(ctx, &iov, arg, i);
                if (ret)
                        break;
                ret = io_buffer_validate(&iov);
                if (ret)
                        break;
-               if (!iov.iov_base && tag) {
+               if (!iov.iov_base && *io_get_tag_slot(data, i)) {
                        ret = -EINVAL;
                        break;
                }
@@ -8428,7 +8474,6 @@ static int io_sqe_buffers_register(struct io_ring_ctx *ctx, void __user *arg,
                                             &last_hpage);
                if (ret)
                        break;
-               data->tags[i] = tag;
        }
 
        WARN_ON_ONCE(ctx->buf_data);
@@ -8493,7 +8538,7 @@ static int __io_sqe_buffers_update(struct io_ring_ctx *ctx,
                }
 
                ctx->user_bufs[i] = imu;
-               ctx->buf_data->tags[offset] = tag;
+               *io_get_tag_slot(ctx->buf_data, offset) = tag;
        }
 
        if (needs_switch)
@@ -8638,7 +8683,7 @@ static __poll_t io_uring_poll(struct file *file, poll_table *wait)
        struct io_ring_ctx *ctx = file->private_data;
        __poll_t mask = 0;
 
-       poll_wait(file, &ctx->cq_wait, wait);
+       poll_wait(file, &ctx->poll_wait, wait);
        /*
         * synchronizes with barrier from wq_has_sleeper call in
         * io_commit_cqring
@@ -8660,7 +8705,7 @@ static __poll_t io_uring_poll(struct file *file, poll_table *wait)
         * Users may get EPOLLIN meanwhile seeing nothing in cqring, this
         * pushs them to do the flush.
         */
-       if (io_cqring_events(ctx) || test_bit(0, &ctx->cq_check_overflow))
+       if (io_cqring_events(ctx) || test_bit(0, &ctx->check_cq_overflow))
                mask |= EPOLLIN | EPOLLRDNORM;
 
        return mask;
@@ -8708,7 +8753,7 @@ static void io_tctx_exit_cb(struct callback_head *cb)
         * node. It'll be removed by the end of cancellation, just ignore it.
         */
        if (!atomic_read(&tctx->in_idle))
-               io_uring_del_task_file((unsigned long)work->ctx);
+               io_uring_del_tctx_node((unsigned long)work->ctx);
        complete(&work->completion);
 }
 
@@ -8734,7 +8779,7 @@ static void io_ring_exit_work(struct work_struct *work)
         * as nobody else will be looking for them.
         */
        do {
-               io_uring_try_cancel_requests(ctx, NULL, NULL);
+               io_uring_try_cancel_requests(ctx, NULL, true);
                if (ctx->sq_data) {
                        struct io_sq_data *sqd = ctx->sq_data;
                        struct task_struct *tsk;
@@ -8785,14 +8830,14 @@ static void io_ring_exit_work(struct work_struct *work)
 
 /* Returns true if we found and killed one or more timeouts */
 static bool io_kill_timeouts(struct io_ring_ctx *ctx, struct task_struct *tsk,
-                            struct files_struct *files)
+                            bool cancel_all)
 {
        struct io_kiocb *req, *tmp;
        int canceled = 0;
 
        spin_lock_irq(&ctx->completion_lock);
        list_for_each_entry_safe(req, tmp, &ctx->timeout_list, timeout.list) {
-               if (io_match_task(req, tsk, files)) {
+               if (io_match_task(req, tsk, cancel_all)) {
                        io_kill_timeout(req, -ECANCELED);
                        canceled++;
                }
@@ -8818,8 +8863,8 @@ static void io_ring_ctx_wait_and_kill(struct io_ring_ctx *ctx)
                io_unregister_personality(ctx, index);
        mutex_unlock(&ctx->uring_lock);
 
-       io_kill_timeouts(ctx, NULL, NULL);
-       io_poll_remove_all(ctx, NULL, NULL);
+       io_kill_timeouts(ctx, NULL, true);
+       io_poll_remove_all(ctx, NULL, true);
 
        /* if we failed setting up the ctx, we might not have any rings */
        io_iopoll_try_reap_events(ctx);
@@ -8845,7 +8890,7 @@ static int io_uring_release(struct inode *inode, struct file *file)
 
 struct io_task_cancel {
        struct task_struct *task;
-       struct files_struct *files;
+       bool all;
 };
 
 static bool io_cancel_task_cb(struct io_wq_work *work, void *data)
@@ -8854,30 +8899,29 @@ static bool io_cancel_task_cb(struct io_wq_work *work, void *data)
        struct io_task_cancel *cancel = data;
        bool ret;
 
-       if (cancel->files && (req->flags & REQ_F_LINK_TIMEOUT)) {
+       if (!cancel->all && (req->flags & REQ_F_LINK_TIMEOUT)) {
                unsigned long flags;
                struct io_ring_ctx *ctx = req->ctx;
 
                /* protect against races with linked timeouts */
                spin_lock_irqsave(&ctx->completion_lock, flags);
-               ret = io_match_task(req, cancel->task, cancel->files);
+               ret = io_match_task(req, cancel->task, cancel->all);
                spin_unlock_irqrestore(&ctx->completion_lock, flags);
        } else {
-               ret = io_match_task(req, cancel->task, cancel->files);
+               ret = io_match_task(req, cancel->task, cancel->all);
        }
        return ret;
 }
 
 static bool io_cancel_defer_files(struct io_ring_ctx *ctx,
-                                 struct task_struct *task,
-                                 struct files_struct *files)
+                                 struct task_struct *task, bool cancel_all)
 {
        struct io_defer_entry *de;
        LIST_HEAD(list);
 
        spin_lock_irq(&ctx->completion_lock);
        list_for_each_entry_reverse(de, &ctx->defer_list, list) {
-               if (io_match_task(de->req, task, files)) {
+               if (io_match_task(de->req, task, cancel_all)) {
                        list_cut_position(&list, &ctx->defer_list, &de->list);
                        break;
                }
@@ -8921,9 +8965,9 @@ static bool io_uring_try_cancel_iowq(struct io_ring_ctx *ctx)
 
 static void io_uring_try_cancel_requests(struct io_ring_ctx *ctx,
                                         struct task_struct *task,
-                                        struct files_struct *files)
+                                        bool cancel_all)
 {
-       struct io_task_cancel cancel = { .task = task, .files = files, };
+       struct io_task_cancel cancel = { .task = task, .all = cancel_all, };
        struct io_uring_task *tctx = task ? task->io_uring : NULL;
 
        while (1) {
@@ -8943,7 +8987,7 @@ static void io_uring_try_cancel_requests(struct io_ring_ctx *ctx,
                }
 
                /* SQPOLL thread does its own polling */
-               if ((!(ctx->flags & IORING_SETUP_SQPOLL) && !files) ||
+               if ((!(ctx->flags & IORING_SETUP_SQPOLL) && cancel_all) ||
                    (ctx->sq_data && ctx->sq_data->thread == current)) {
                        while (!list_empty_careful(&ctx->iopoll_list)) {
                                io_iopoll_try_reap_events(ctx);
@@ -8951,9 +8995,9 @@ static void io_uring_try_cancel_requests(struct io_ring_ctx *ctx,
                        }
                }
 
-               ret |= io_cancel_defer_files(ctx, task, files);
-               ret |= io_poll_remove_all(ctx, task, files);
-               ret |= io_kill_timeouts(ctx, task, files);
+               ret |= io_cancel_defer_files(ctx, task, cancel_all);
+               ret |= io_poll_remove_all(ctx, task, cancel_all);
+               ret |= io_kill_timeouts(ctx, task, cancel_all);
                ret |= io_run_task_work();
                ret |= io_run_ctx_fallback(ctx);
                if (!ret)
@@ -8962,7 +9006,7 @@ static void io_uring_try_cancel_requests(struct io_ring_ctx *ctx,
        }
 }
 
-static int __io_uring_add_task_file(struct io_ring_ctx *ctx)
+static int __io_uring_add_tctx_node(struct io_ring_ctx *ctx)
 {
        struct io_uring_task *tctx = current->io_uring;
        struct io_tctx_node *node;
@@ -8999,19 +9043,19 @@ static int __io_uring_add_task_file(struct io_ring_ctx *ctx)
 /*
  * Note that this task has used io_uring. We use it for cancelation purposes.
  */
-static inline int io_uring_add_task_file(struct io_ring_ctx *ctx)
+static inline int io_uring_add_tctx_node(struct io_ring_ctx *ctx)
 {
        struct io_uring_task *tctx = current->io_uring;
 
        if (likely(tctx && tctx->last == ctx))
                return 0;
-       return __io_uring_add_task_file(ctx);
+       return __io_uring_add_tctx_node(ctx);
 }
 
 /*
  * Remove this io_uring_file -> task mapping.
  */
-static void io_uring_del_task_file(unsigned long index)
+static void io_uring_del_tctx_node(unsigned long index)
 {
        struct io_uring_task *tctx = current->io_uring;
        struct io_tctx_node *node;
@@ -9041,7 +9085,7 @@ static void io_uring_clean_tctx(struct io_uring_task *tctx)
        unsigned long index;
 
        xa_for_each(&tctx->xa, index, node)
-               io_uring_del_task_file(index);
+               io_uring_del_tctx_node(index);
        if (wq) {
                /*
                 * Must be after io_uring_del_task_file() (removes nodes under
@@ -9059,99 +9103,83 @@ static s64 tctx_inflight(struct io_uring_task *tctx, bool tracked)
        return percpu_counter_sum(&tctx->inflight);
 }
 
-static void io_uring_try_cancel(struct files_struct *files)
+static void io_uring_drop_tctx_refs(struct task_struct *task)
 {
-       struct io_uring_task *tctx = current->io_uring;
-       struct io_tctx_node *node;
-       unsigned long index;
-
-       xa_for_each(&tctx->xa, index, node) {
-               struct io_ring_ctx *ctx = node->ctx;
+       struct io_uring_task *tctx = task->io_uring;
+       unsigned int refs = tctx->cached_refs;
 
-               /* sqpoll task will cancel all its requests */
-               if (!ctx->sq_data)
-                       io_uring_try_cancel_requests(ctx, current, files);
-       }
+       tctx->cached_refs = 0;
+       percpu_counter_sub(&tctx->inflight, refs);
+       put_task_struct_many(task, refs);
 }
 
-/* should only be called by SQPOLL task */
-static void io_uring_cancel_sqpoll(struct io_sq_data *sqd)
+/*
+ * Find any io_uring ctx that this task has registered or done IO on, and cancel
+ * requests. @sqd should be not-null IIF it's an SQPOLL thread cancellation.
+ */
+static void io_uring_cancel_generic(bool cancel_all, struct io_sq_data *sqd)
 {
        struct io_uring_task *tctx = current->io_uring;
        struct io_ring_ctx *ctx;
        s64 inflight;
        DEFINE_WAIT(wait);
 
+       WARN_ON_ONCE(sqd && sqd->thread != current);
+
        if (!current->io_uring)
                return;
        if (tctx->io_wq)
                io_wq_exit_start(tctx->io_wq);
 
-       WARN_ON_ONCE(!sqd || sqd->thread != current);
-
+       io_uring_drop_tctx_refs(current);
        atomic_inc(&tctx->in_idle);
        do {
                /* read completions before cancelations */
-               inflight = tctx_inflight(tctx, false);
+               inflight = tctx_inflight(tctx, !cancel_all);
                if (!inflight)
                        break;
-               list_for_each_entry(ctx, &sqd->ctx_list, sqd_list)
-                       io_uring_try_cancel_requests(ctx, current, NULL);
 
-               prepare_to_wait(&tctx->wait, &wait, TASK_UNINTERRUPTIBLE);
-               /*
-                * If we've seen completions, retry without waiting. This
-                * avoids a race where a completion comes in before we did
-                * prepare_to_wait().
-                */
-               if (inflight == tctx_inflight(tctx, false))
-                       schedule();
-               finish_wait(&tctx->wait, &wait);
-       } while (1);
-       atomic_dec(&tctx->in_idle);
-}
-
-/*
- * Find any io_uring fd that this task has registered or done IO on, and cancel
- * requests.
- */
-void __io_uring_cancel(struct files_struct *files)
-{
-       struct io_uring_task *tctx = current->io_uring;
-       DEFINE_WAIT(wait);
-       s64 inflight;
+               if (!sqd) {
+                       struct io_tctx_node *node;
+                       unsigned long index;
 
-       if (tctx->io_wq)
-               io_wq_exit_start(tctx->io_wq);
+                       xa_for_each(&tctx->xa, index, node) {
+                               /* sqpoll task will cancel all its requests */
+                               if (node->ctx->sq_data)
+                                       continue;
+                               io_uring_try_cancel_requests(node->ctx, current,
+                                                            cancel_all);
+                       }
+               } else {
+                       list_for_each_entry(ctx, &sqd->ctx_list, sqd_list)
+                               io_uring_try_cancel_requests(ctx, current,
+                                                            cancel_all);
+               }
 
-       /* make sure overflow events are dropped */
-       atomic_inc(&tctx->in_idle);
-       do {
-               /* read completions before cancelations */
-               inflight = tctx_inflight(tctx, !!files);
-               if (!inflight)
-                       break;
-               io_uring_try_cancel(files);
                prepare_to_wait(&tctx->wait, &wait, TASK_UNINTERRUPTIBLE);
-
                /*
                 * If we've seen completions, retry without waiting. This
                 * avoids a race where a completion comes in before we did
                 * prepare_to_wait().
                 */
-               if (inflight == tctx_inflight(tctx, !!files))
+               if (inflight == tctx_inflight(tctx, !cancel_all))
                        schedule();
                finish_wait(&tctx->wait, &wait);
        } while (1);
        atomic_dec(&tctx->in_idle);
 
        io_uring_clean_tctx(tctx);
-       if (!files) {
+       if (cancel_all) {
                /* for exec all current's requests should be gone, kill tctx */
                __io_uring_free(current);
        }
 }
 
+void __io_uring_cancel(struct files_struct *files)
+{
+       io_uring_cancel_generic(!files, NULL);
+}
+
 static void *io_uring_validate_mmap_request(struct file *file,
                                            loff_t pgoff, size_t sz)
 {
@@ -9324,7 +9352,7 @@ SYSCALL_DEFINE6(io_uring_enter, unsigned int, fd, u32, to_submit,
                }
                submitted = to_submit;
        } else if (to_submit) {
-               ret = io_uring_add_task_file(ctx);
+               ret = io_uring_add_tctx_node(ctx);
                if (unlikely(ret))
                        goto out;
                mutex_lock(&ctx->uring_lock);
@@ -9508,8 +9536,6 @@ static int io_allocate_scq_urings(struct io_ring_ctx *ctx,
        rings->cq_ring_mask = p->cq_entries - 1;
        rings->sq_ring_entries = p->sq_entries;
        rings->cq_ring_entries = p->cq_entries;
-       ctx->sq_mask = rings->sq_ring_mask;
-       ctx->cq_mask = rings->cq_ring_mask;
 
        size = array_size(sizeof(struct io_uring_sqe), p->sq_entries);
        if (size == SIZE_MAX) {
@@ -9536,7 +9562,7 @@ static int io_uring_install_fd(struct io_ring_ctx *ctx, struct file *file)
        if (fd < 0)
                return fd;
 
-       ret = io_uring_add_task_file(ctx);
+       ret = io_uring_add_tctx_node(ctx);
        if (ret) {
                put_unused_fd(fd);
                return ret;
@@ -9671,7 +9697,8 @@ static int io_uring_create(unsigned entries, struct io_uring_params *p,
                        IORING_FEAT_SUBMIT_STABLE | IORING_FEAT_RW_CUR_POS |
                        IORING_FEAT_CUR_PERSONALITY | IORING_FEAT_FAST_POLL |
                        IORING_FEAT_POLL_32BITS | IORING_FEAT_SQPOLL_NONFIXED |
-                       IORING_FEAT_EXT_ARG | IORING_FEAT_NATIVE_WORKERS;
+                       IORING_FEAT_EXT_ARG | IORING_FEAT_NATIVE_WORKERS |
+                       IORING_FEAT_RSRC_TAGS;
 
        if (copy_to_user(params, p, sizeof(*p))) {
                ret = -EFAULT;
@@ -9911,7 +9938,7 @@ static int io_register_files_update(struct io_ring_ctx *ctx, void __user *arg,
 }
 
 static int io_register_rsrc_update(struct io_ring_ctx *ctx, void __user *arg,
-                                  unsigned size)
+                                  unsigned size, unsigned type)
 {
        struct io_uring_rsrc_update2 up;
 
@@ -9919,13 +9946,13 @@ static int io_register_rsrc_update(struct io_ring_ctx *ctx, void __user *arg,
                return -EINVAL;
        if (copy_from_user(&up, arg, sizeof(up)))
                return -EFAULT;
-       if (!up.nr)
+       if (!up.nr || up.resv)
                return -EINVAL;
-       return __io_register_rsrc_update(ctx, up.type, &up, up.nr);
+       return __io_register_rsrc_update(ctx, type, &up, up.nr);
 }
 
 static int io_register_rsrc(struct io_ring_ctx *ctx, void __user *arg,
-                           unsigned int size)
+                           unsigned int size, unsigned int type)
 {
        struct io_uring_rsrc_register rr;
 
@@ -9936,10 +9963,10 @@ static int io_register_rsrc(struct io_ring_ctx *ctx, void __user *arg,
        memset(&rr, 0, sizeof(rr));
        if (copy_from_user(&rr, arg, size))
                return -EFAULT;
-       if (!rr.nr)
+       if (!rr.nr || rr.resv || rr.resv2)
                return -EINVAL;
 
-       switch (rr.type) {
+       switch (type) {
        case IORING_RSRC_FILE:
                return io_sqe_files_register(ctx, u64_to_user_ptr(rr.data),
                                             rr.nr, u64_to_user_ptr(rr.tags));
@@ -9950,6 +9977,43 @@ static int io_register_rsrc(struct io_ring_ctx *ctx, void __user *arg,
        return -EINVAL;
 }
 
+static int io_register_iowq_aff(struct io_ring_ctx *ctx, void __user *arg,
+                               unsigned len)
+{
+       struct io_uring_task *tctx = current->io_uring;
+       cpumask_var_t new_mask;
+       int ret;
+
+       if (!tctx || !tctx->io_wq)
+               return -EINVAL;
+
+       if (!alloc_cpumask_var(&new_mask, GFP_KERNEL))
+               return -ENOMEM;
+
+       cpumask_clear(new_mask);
+       if (len > cpumask_size())
+               len = cpumask_size();
+
+       if (copy_from_user(new_mask, arg, len)) {
+               free_cpumask_var(new_mask);
+               return -EFAULT;
+       }
+
+       ret = io_wq_cpu_affinity(tctx->io_wq, new_mask);
+       free_cpumask_var(new_mask);
+       return ret;
+}
+
+static int io_unregister_iowq_aff(struct io_ring_ctx *ctx)
+{
+       struct io_uring_task *tctx = current->io_uring;
+
+       if (!tctx || !tctx->io_wq)
+               return -EINVAL;
+
+       return io_wq_cpu_affinity(tctx->io_wq, NULL);
+}
+
 static bool io_register_op_must_quiesce(int op)
 {
        switch (op) {
@@ -9961,8 +10025,12 @@ static bool io_register_op_must_quiesce(int op)
        case IORING_REGISTER_PROBE:
        case IORING_REGISTER_PERSONALITY:
        case IORING_UNREGISTER_PERSONALITY:
-       case IORING_REGISTER_RSRC:
-       case IORING_REGISTER_RSRC_UPDATE:
+       case IORING_REGISTER_FILES2:
+       case IORING_REGISTER_FILES_UPDATE2:
+       case IORING_REGISTER_BUFFERS2:
+       case IORING_REGISTER_BUFFERS_UPDATE:
+       case IORING_REGISTER_IOWQ_AFF:
+       case IORING_UNREGISTER_IOWQ_AFF:
                return false;
        default:
                return true;
@@ -10088,11 +10156,31 @@ static int __io_uring_register(struct io_ring_ctx *ctx, unsigned opcode,
        case IORING_REGISTER_RESTRICTIONS:
                ret = io_register_restrictions(ctx, arg, nr_args);
                break;
-       case IORING_REGISTER_RSRC:
-               ret = io_register_rsrc(ctx, arg, nr_args);
+       case IORING_REGISTER_FILES2:
+               ret = io_register_rsrc(ctx, arg, nr_args, IORING_RSRC_FILE);
+               break;
+       case IORING_REGISTER_FILES_UPDATE2:
+               ret = io_register_rsrc_update(ctx, arg, nr_args,
+                                             IORING_RSRC_FILE);
                break;
-       case IORING_REGISTER_RSRC_UPDATE:
-               ret = io_register_rsrc_update(ctx, arg, nr_args);
+       case IORING_REGISTER_BUFFERS2:
+               ret = io_register_rsrc(ctx, arg, nr_args, IORING_RSRC_BUFFER);
+               break;
+       case IORING_REGISTER_BUFFERS_UPDATE:
+               ret = io_register_rsrc_update(ctx, arg, nr_args,
+                                             IORING_RSRC_BUFFER);
+               break;
+       case IORING_REGISTER_IOWQ_AFF:
+               ret = -EINVAL;
+               if (!arg || !nr_args)
+                       break;
+               ret = io_register_iowq_aff(ctx, arg, nr_args);
+               break;
+       case IORING_UNREGISTER_IOWQ_AFF:
+               ret = -EINVAL;
+               if (arg || nr_args)
+                       break;
+               ret = io_unregister_iowq_aff(ctx);
                break;
        default:
                ret = -EINVAL;