ccflags-y += -I$(src)          # needed for trace events
 obj-$(CONFIG_CIFS) += cifs.o
 
-cifs-y := trace.o cifsfs.o cifssmb.o cifs_debug.o connect.o dir.o file.o \
+cifs-y := trace.o cifsfs.o cifs_debug.o connect.o dir.o file.o \
          inode.o link.o misc.o netmisc.o smbencrypt.o transport.o \
          cifs_unicode.o nterr.o cifsencrypt.o \
          readdir.o ioctl.o sess.o export.o unc.o winucase.o \
 
 cifs-$(CONFIG_CIFS_ROOT) += cifsroot.o
 
-cifs-$(CONFIG_CIFS_ALLOW_INSECURE_LEGACY) += smb1ops.o
+cifs-$(CONFIG_CIFS_ALLOW_INSECURE_LEGACY) += smb1ops.o cifssmb.o
 
        return rc;
 }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 struct cifs_ntsd *get_cifs_acl_by_fid(struct cifs_sb_info *cifs_sb,
                                      const struct cifs_fid *cifsfid, u32 *pacllen,
                                      u32 __maybe_unused unused)
        cifs_put_tlink(tlink);
        return rc;
 }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 /* Translate the CIFS ACL (similar to NTFS ACL) for a file into mode bits */
 int
 
 extern int generate_smb311signingkey(struct cifs_ses *ses,
                                     struct TCP_Server_Info *server);
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 extern int CIFSSMBCopy(unsigned int xid,
                        struct cifs_tcon *source_tcon,
                        const char *fromName,
                const struct nls_table *nls_codepage, int remap_special_chars);
 extern int CIFSGetExtAttr(const unsigned int xid, struct cifs_tcon *tcon,
                        const int netfid, __u64 *pExtAttrBits, __u64 *pMask);
+#endif /* CIFS_ALLOW_INSECURE_LEGACY */
 extern void cifs_autodisable_serverino(struct cifs_sb_info *cifs_sb);
 extern bool couldbe_mf_symlink(const struct cifs_fattr *fattr);
 extern int check_mf_symlink(unsigned int xid, struct cifs_tcon *tcon,
 
 #include "cifsproto.h"
 #include "cifs_unicode.h"
 #include "cifs_debug.h"
-#include "smb2proto.h"
 #include "fscache.h"
 #include "smbdirect.h"
 #ifdef CONFIG_CIFS_DFS_UPCALL
 #define CIFS_NUM_PROT 1
 #endif /* CIFS_POSIX */
 
-/*
- * Mark as invalid, all open files on tree connections since they
- * were closed when session to server was lost.
- */
-void
-cifs_mark_open_files_invalid(struct cifs_tcon *tcon)
-{
-       struct cifsFileInfo *open_file = NULL;
-       struct list_head *tmp;
-       struct list_head *tmp1;
-
-       /* only send once per connect */
-       spin_lock(&tcon->ses->ses_lock);
-       if ((tcon->ses->ses_status != SES_GOOD) || (tcon->status != TID_NEED_RECON)) {
-               spin_unlock(&tcon->ses->ses_lock);
-               return;
-       }
-       tcon->status = TID_IN_FILES_INVALIDATE;
-       spin_unlock(&tcon->ses->ses_lock);
-
-       /* list all files open on tree connection and mark them invalid */
-       spin_lock(&tcon->open_file_lock);
-       list_for_each_safe(tmp, tmp1, &tcon->openFileList) {
-               open_file = list_entry(tmp, struct cifsFileInfo, tlist);
-               open_file->invalidHandle = true;
-               open_file->oplock_break_cancelled = true;
-       }
-       spin_unlock(&tcon->open_file_lock);
-
-       mutex_lock(&tcon->crfid.fid_mutex);
-       tcon->crfid.is_valid = false;
-       /* cached handle is not valid, so SMB2_CLOSE won't be sent below */
-       close_cached_dir_lease_locked(&tcon->crfid);
-       memset(tcon->crfid.fid, 0, sizeof(struct cifs_fid));
-       mutex_unlock(&tcon->crfid.fid_mutex);
-
-       spin_lock(&tcon->tc_lock);
-       if (tcon->status == TID_IN_FILES_INVALIDATE)
-               tcon->status = TID_NEED_TCON;
-       spin_unlock(&tcon->tc_lock);
-
-       /*
-        * BB Add call to invalidate_inodes(sb) for all superblocks mounted
-        * to this tcon.
-        */
-}
 
 /* reconnect the socket, tcon, and smb session if needed */
 static int
        return 0;
 }
 
-int
-cifs_enable_signing(struct TCP_Server_Info *server, bool mnt_sign_required)
-{
-       bool srv_sign_required = server->sec_mode & server->vals->signing_required;
-       bool srv_sign_enabled = server->sec_mode & server->vals->signing_enabled;
-       bool mnt_sign_enabled;
-
-       /*
-        * Is signing required by mnt options? If not then check
-        * global_secflags to see if it is there.
-        */
-       if (!mnt_sign_required)
-               mnt_sign_required = ((global_secflags & CIFSSEC_MUST_SIGN) ==
-                                               CIFSSEC_MUST_SIGN);
-
-       /*
-        * If signing is required then it's automatically enabled too,
-        * otherwise, check to see if the secflags allow it.
-        */
-       mnt_sign_enabled = mnt_sign_required ? mnt_sign_required :
-                               (global_secflags & CIFSSEC_MAY_SIGN);
-
-       /* If server requires signing, does client allow it? */
-       if (srv_sign_required) {
-               if (!mnt_sign_enabled) {
-                       cifs_dbg(VFS, "Server requires signing, but it's disabled in SecurityFlags!\n");
-                       return -ENOTSUPP;
-               }
-               server->sign = true;
-       }
-
-       /* If client requires signing, does server allow it? */
-       if (mnt_sign_required) {
-               if (!srv_sign_enabled) {
-                       cifs_dbg(VFS, "Server does not support signing!\n");
-                       return -ENOTSUPP;
-               }
-               server->sign = true;
-       }
-
-       if (cifs_rdma_enabled(server) && server->sign)
-               cifs_dbg(VFS, "Signing is enabled, and RDMA read/write will be disabled\n");
-
-       return 0;
-}
-
 static bool
 should_set_ext_sec_flag(enum securityEnum sectype)
 {
        return rc;
 }
 
-/*
- * Discard any remaining data in the current SMB. To do this, we borrow the
- * current bigbuf.
- */
-int
-cifs_discard_remaining_data(struct TCP_Server_Info *server)
-{
-       unsigned int rfclen = server->pdu_size;
-       int remaining = rfclen + server->vals->header_preamble_size -
-               server->total_read;
-
-       while (remaining > 0) {
-               int length;
-
-               length = cifs_discard_from_socket(server,
-                               min_t(size_t, remaining,
-                                     CIFSMaxBufSize + MAX_HEADER_SIZE(server)));
-               if (length < 0)
-                       return length;
-               server->total_read += length;
-               remaining -= length;
-       }
-
-       return 0;
-}
-
-static int
-__cifs_readv_discard(struct TCP_Server_Info *server, struct mid_q_entry *mid,
-                    bool malformed)
-{
-       int length;
-
-       length = cifs_discard_remaining_data(server);
-       dequeue_mid(mid, malformed);
-       mid->resp_buf = server->smallbuf;
-       server->smallbuf = NULL;
-       return length;
-}
-
-static int
-cifs_readv_discard(struct TCP_Server_Info *server, struct mid_q_entry *mid)
-{
-       struct cifs_readdata *rdata = mid->callback_data;
-
-       return  __cifs_readv_discard(server, mid, rdata->result);
-}
-
-int
-cifs_readv_receive(struct TCP_Server_Info *server, struct mid_q_entry *mid)
-{
-       int length, len;
-       unsigned int data_offset, data_len;
-       struct cifs_readdata *rdata = mid->callback_data;
-       char *buf = server->smallbuf;
-       unsigned int buflen = server->pdu_size +
-               server->vals->header_preamble_size;
-       bool use_rdma_mr = false;
-
-       cifs_dbg(FYI, "%s: mid=%llu offset=%llu bytes=%u\n",
-                __func__, mid->mid, rdata->offset, rdata->bytes);
-
-       /*
-        * read the rest of READ_RSP header (sans Data array), or whatever we
-        * can if there's not enough data. At this point, we've read down to
-        * the Mid.
-        */
-       len = min_t(unsigned int, buflen, server->vals->read_rsp_size) -
-                                                       HEADER_SIZE(server) + 1;
-
-       length = cifs_read_from_socket(server,
-                                      buf + HEADER_SIZE(server) - 1, len);
-       if (length < 0)
-               return length;
-       server->total_read += length;
-
-       if (server->ops->is_session_expired &&
-           server->ops->is_session_expired(buf)) {
-               cifs_reconnect(server, true);
-               return -1;
-       }
-
-       if (server->ops->is_status_pending &&
-           server->ops->is_status_pending(buf, server)) {
-               cifs_discard_remaining_data(server);
-               return -1;
-       }
-
-       /* set up first two iov for signature check and to get credits */
-       rdata->iov[0].iov_base = buf;
-       rdata->iov[0].iov_len = server->vals->header_preamble_size;
-       rdata->iov[1].iov_base = buf + server->vals->header_preamble_size;
-       rdata->iov[1].iov_len =
-               server->total_read - server->vals->header_preamble_size;
-       cifs_dbg(FYI, "0: iov_base=%p iov_len=%zu\n",
-                rdata->iov[0].iov_base, rdata->iov[0].iov_len);
-       cifs_dbg(FYI, "1: iov_base=%p iov_len=%zu\n",
-                rdata->iov[1].iov_base, rdata->iov[1].iov_len);
-
-       /* Was the SMB read successful? */
-       rdata->result = server->ops->map_error(buf, false);
-       if (rdata->result != 0) {
-               cifs_dbg(FYI, "%s: server returned error %d\n",
-                        __func__, rdata->result);
-               /* normal error on read response */
-               return __cifs_readv_discard(server, mid, false);
-       }
-
-       /* Is there enough to get to the rest of the READ_RSP header? */
-       if (server->total_read < server->vals->read_rsp_size) {
-               cifs_dbg(FYI, "%s: server returned short header. got=%u expected=%zu\n",
-                        __func__, server->total_read,
-                        server->vals->read_rsp_size);
-               rdata->result = -EIO;
-               return cifs_readv_discard(server, mid);
-       }
-
-       data_offset = server->ops->read_data_offset(buf) +
-               server->vals->header_preamble_size;
-       if (data_offset < server->total_read) {
-               /*
-                * win2k8 sometimes sends an offset of 0 when the read
-                * is beyond the EOF. Treat it as if the data starts just after
-                * the header.
-                */
-               cifs_dbg(FYI, "%s: data offset (%u) inside read response header\n",
-                        __func__, data_offset);
-               data_offset = server->total_read;
-       } else if (data_offset > MAX_CIFS_SMALL_BUFFER_SIZE) {
-               /* data_offset is beyond the end of smallbuf */
-               cifs_dbg(FYI, "%s: data offset (%u) beyond end of smallbuf\n",
-                        __func__, data_offset);
-               rdata->result = -EIO;
-               return cifs_readv_discard(server, mid);
-       }
-
-       cifs_dbg(FYI, "%s: total_read=%u data_offset=%u\n",
-                __func__, server->total_read, data_offset);
-
-       len = data_offset - server->total_read;
-       if (len > 0) {
-               /* read any junk before data into the rest of smallbuf */
-               length = cifs_read_from_socket(server,
-                                              buf + server->total_read, len);
-               if (length < 0)
-                       return length;
-               server->total_read += length;
-       }
-
-       /* how much data is in the response? */
-#ifdef CONFIG_CIFS_SMB_DIRECT
-       use_rdma_mr = rdata->mr;
-#endif
-       data_len = server->ops->read_data_length(buf, use_rdma_mr);
-       if (!use_rdma_mr && (data_offset + data_len > buflen)) {
-               /* data_len is corrupt -- discard frame */
-               rdata->result = -EIO;
-               return cifs_readv_discard(server, mid);
-       }
-
-       length = rdata->read_into_pages(server, rdata, data_len);
-       if (length < 0)
-               return length;
-
-       server->total_read += length;
-
-       cifs_dbg(FYI, "total_read=%u buflen=%u remaining=%u\n",
-                server->total_read, buflen, data_len);
-
-       /* discard anything left over */
-       if (server->total_read < buflen)
-               return cifs_readv_discard(server, mid);
-
-       dequeue_mid(mid, false);
-       mid->resp_buf = server->smallbuf;
-       server->smallbuf = NULL;
-       return length;
-}
-
 static void
 cifs_readv_callback(struct mid_q_entry *mid)
 {
        return rc;
 }
 
-void
-cifs_writedata_release(struct kref *refcount)
-{
-       struct cifs_writedata *wdata = container_of(refcount,
-                                       struct cifs_writedata, refcount);
-#ifdef CONFIG_CIFS_SMB_DIRECT
-       if (wdata->mr) {
-               smbd_deregister_mr(wdata->mr);
-               wdata->mr = NULL;
-       }
-#endif
-
-       if (wdata->cfile)
-               cifsFileInfo_put(wdata->cfile);
-
-       kvfree(wdata->pages);
-       kfree(wdata);
-}
-
-/*
- * Write failed with a retryable error. Resend the write request. It's also
- * possible that the page was redirtied so re-clean the page.
- */
-static void
-cifs_writev_requeue(struct cifs_writedata *wdata)
-{
-       int i, rc = 0;
-       struct inode *inode = d_inode(wdata->cfile->dentry);
-       struct TCP_Server_Info *server;
-       unsigned int rest_len;
-
-       server = tlink_tcon(wdata->cfile->tlink)->ses->server;
-       i = 0;
-       rest_len = wdata->bytes;
-       do {
-               struct cifs_writedata *wdata2;
-               unsigned int j, nr_pages, wsize, tailsz, cur_len;
-
-               wsize = server->ops->wp_retry_size(inode);
-               if (wsize < rest_len) {
-                       nr_pages = wsize / PAGE_SIZE;
-                       if (!nr_pages) {
-                               rc = -ENOTSUPP;
-                               break;
-                       }
-                       cur_len = nr_pages * PAGE_SIZE;
-                       tailsz = PAGE_SIZE;
-               } else {
-                       nr_pages = DIV_ROUND_UP(rest_len, PAGE_SIZE);
-                       cur_len = rest_len;
-                       tailsz = rest_len - (nr_pages - 1) * PAGE_SIZE;
-               }
-
-               wdata2 = cifs_writedata_alloc(nr_pages, cifs_writev_complete);
-               if (!wdata2) {
-                       rc = -ENOMEM;
-                       break;
-               }
-
-               for (j = 0; j < nr_pages; j++) {
-                       wdata2->pages[j] = wdata->pages[i + j];
-                       lock_page(wdata2->pages[j]);
-                       clear_page_dirty_for_io(wdata2->pages[j]);
-               }
-
-               wdata2->sync_mode = wdata->sync_mode;
-               wdata2->nr_pages = nr_pages;
-               wdata2->offset = page_offset(wdata2->pages[0]);
-               wdata2->pagesz = PAGE_SIZE;
-               wdata2->tailsz = tailsz;
-               wdata2->bytes = cur_len;
-
-               rc = cifs_get_writable_file(CIFS_I(inode), FIND_WR_ANY,
-                                           &wdata2->cfile);
-               if (!wdata2->cfile) {
-                       cifs_dbg(VFS, "No writable handle to retry writepages rc=%d\n",
-                                rc);
-                       if (!is_retryable_error(rc))
-                               rc = -EBADF;
-               } else {
-                       wdata2->pid = wdata2->cfile->pid;
-                       rc = server->ops->async_writev(wdata2,
-                                                      cifs_writedata_release);
-               }
-
-               for (j = 0; j < nr_pages; j++) {
-                       unlock_page(wdata2->pages[j]);
-                       if (rc != 0 && !is_retryable_error(rc)) {
-                               SetPageError(wdata2->pages[j]);
-                               end_page_writeback(wdata2->pages[j]);
-                               put_page(wdata2->pages[j]);
-                       }
-               }
-
-               kref_put(&wdata2->refcount, cifs_writedata_release);
-               if (rc) {
-                       if (is_retryable_error(rc))
-                               continue;
-                       i += nr_pages;
-                       break;
-               }
-
-               rest_len -= cur_len;
-               i += nr_pages;
-       } while (i < wdata->nr_pages);
-
-       /* cleanup remaining pages from the original wdata */
-       for (; i < wdata->nr_pages; i++) {
-               SetPageError(wdata->pages[i]);
-               end_page_writeback(wdata->pages[i]);
-               put_page(wdata->pages[i]);
-       }
-
-       if (rc != 0 && !is_retryable_error(rc))
-               mapping_set_error(inode->i_mapping, rc);
-       kref_put(&wdata->refcount, cifs_writedata_release);
-}
-
-void
-cifs_writev_complete(struct work_struct *work)
-{
-       struct cifs_writedata *wdata = container_of(work,
-                                               struct cifs_writedata, work);
-       struct inode *inode = d_inode(wdata->cfile->dentry);
-       int i = 0;
-
-       if (wdata->result == 0) {
-               spin_lock(&inode->i_lock);
-               cifs_update_eof(CIFS_I(inode), wdata->offset, wdata->bytes);
-               spin_unlock(&inode->i_lock);
-               cifs_stats_bytes_written(tlink_tcon(wdata->cfile->tlink),
-                                        wdata->bytes);
-       } else if (wdata->sync_mode == WB_SYNC_ALL && wdata->result == -EAGAIN)
-               return cifs_writev_requeue(wdata);
-
-       for (i = 0; i < wdata->nr_pages; i++) {
-               struct page *page = wdata->pages[i];
-               if (wdata->result == -EAGAIN)
-                       __set_page_dirty_nobuffers(page);
-               else if (wdata->result < 0)
-                       SetPageError(page);
-               end_page_writeback(page);
-               cifs_readpage_to_fscache(inode, page);
-               put_page(page);
-       }
-       if (wdata->result != -EAGAIN)
-               mapping_set_error(inode->i_mapping, wdata->result);
-       kref_put(&wdata->refcount, cifs_writedata_release);
-}
-
-struct cifs_writedata *
-cifs_writedata_alloc(unsigned int nr_pages, work_func_t complete)
-{
-       struct page **pages =
-               kcalloc(nr_pages, sizeof(struct page *), GFP_NOFS);
-       if (pages)
-               return cifs_writedata_direct_alloc(pages, complete);
-
-       return NULL;
-}
-
-struct cifs_writedata *
-cifs_writedata_direct_alloc(struct page **pages, work_func_t complete)
-{
-       struct cifs_writedata *wdata;
-
-       wdata = kzalloc(sizeof(*wdata), GFP_NOFS);
-       if (wdata != NULL) {
-               wdata->pages = pages;
-               kref_init(&wdata->refcount);
-               INIT_LIST_HEAD(&wdata->list);
-               init_completion(&wdata->done);
-               INIT_WORK(&wdata->work, complete);
-       }
-       return wdata;
-}
-
 /*
  * Check the mid_state and signature on received buffer (if any), and queue the
  * workqueue completion task.
        return rc;
 }
 
-/* BB fix tabs in this function FIXME BB */
 int
 CIFSGetExtAttr(const unsigned int xid, struct cifs_tcon *tcon,
               const int netfid, __u64 *pExtAttrBits, __u64 *pMask)
 
 GetExtAttrRetry:
        rc = smb_init(SMB_COM_TRANSACTION2, 15, tcon, (void **) &pSMB,
-                       (void **) &pSMBr);
+                     (void **) &pSMBr);
        if (rc)
                return rc;
 
                        __u16 data_offset = le16_to_cpu(pSMBr->t2.DataOffset);
                        __u16 count = le16_to_cpu(pSMBr->t2.DataCount);
                        struct file_chattr_info *pfinfo;
-                       /* BB Do we need a cast or hash here ? */
+
                        if (count != 16) {
                                cifs_dbg(FYI, "Invalid size ret in GetExtAttr\n");
                                rc = -EIO;
 
        dequeue_mid(mid, malformed);
 }
 
+int
+cifs_enable_signing(struct TCP_Server_Info *server, bool mnt_sign_required)
+{
+       bool srv_sign_required = server->sec_mode & server->vals->signing_required;
+       bool srv_sign_enabled = server->sec_mode & server->vals->signing_enabled;
+       bool mnt_sign_enabled;
+
+       /*
+        * Is signing required by mnt options? If not then check
+        * global_secflags to see if it is there.
+        */
+       if (!mnt_sign_required)
+               mnt_sign_required = ((global_secflags & CIFSSEC_MUST_SIGN) ==
+                                               CIFSSEC_MUST_SIGN);
+
+       /*
+        * If signing is required then it's automatically enabled too,
+        * otherwise, check to see if the secflags allow it.
+        */
+       mnt_sign_enabled = mnt_sign_required ? mnt_sign_required :
+                               (global_secflags & CIFSSEC_MAY_SIGN);
+
+       /* If server requires signing, does client allow it? */
+       if (srv_sign_required) {
+               if (!mnt_sign_enabled) {
+                       cifs_dbg(VFS, "Server requires signing, but it's disabled in SecurityFlags!\n");
+                       return -EOPNOTSUPP;
+               }
+               server->sign = true;
+       }
+
+       /* If client requires signing, does server allow it? */
+       if (mnt_sign_required) {
+               if (!srv_sign_enabled) {
+                       cifs_dbg(VFS, "Server does not support signing!\n");
+                       return -EOPNOTSUPP;
+               }
+               server->sign = true;
+       }
+
+       if (cifs_rdma_enabled(server) && server->sign)
+               cifs_dbg(VFS, "Signing is enabled, and RDMA read/write will be disabled\n");
+
+       return 0;
+}
+
+
 static void clean_demultiplex_info(struct TCP_Server_Info *server)
 {
        int length;
        return generic_ip_connect(server);
 }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 void reset_cifs_unix_caps(unsigned int xid, struct cifs_tcon *tcon,
                          struct cifs_sb_info *cifs_sb, struct smb3_fs_context *ctx)
 {
                }
        }
 }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 int cifs_setup_cifs_sb(struct cifs_sb_info *cifs_sb)
 {
        if (tcon->posix_extensions)
                cifs_sb->mnt_cifs_flags |= CIFS_MOUNT_POSIX_PATHS;
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        /* tell server which Unix caps we support */
        if (cap_unix(tcon->ses)) {
                /*
                }
                spin_unlock(&tcon->ses->server->srv_lock);
        } else
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
                tcon->unix_ext = 0; /* server does not support them */
 
        /* do not care if a following call succeed - informational */
                goto out;
        }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        if (cap_unix(ses))
                reset_cifs_unix_caps(0, tcon, NULL, ctx);
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 out:
        kfree(ctx->username);
 
                return PTR_ERR(full_path);
        }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        if (tcon->unix_ext && cap_unix(tcon->ses) && !tcon->broken_posix_open &&
            (CIFS_UNIX_POSIX_PATH_OPS_CAP &
                        le64_to_cpu(tcon->fsUnixInfo.Capability))) {
                 * rare for path not covered on files)
                 */
        }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
        desired_access = 0;
        if (OPEN_FMODE(oflags) & FMODE_READ)
                goto out;
        }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        /*
         * If Open reported that we actually created a file then we now have to
         * set the mode if possible.
                rc = cifs_get_inode_info_unix(&newinode, full_path, inode->i_sb,
                                              xid);
        else {
+#else
+       {
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
                /* TODO: Add support for calling POSIX query info here, but passing in fid */
                rc = cifs_get_inode_info(&newinode, full_path, buf, inode->i_sb,
                                         xid, fid);
                }
        }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 cifs_create_set_dentry:
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
        if (rc != 0) {
                cifs_dbg(FYI, "Create worked, get_inode_info failed rc = %d\n",
                         rc);
 
 #include "cifspdu.h"
 #include "cifsglob.h"
 #include "cifsproto.h"
+#include "smb2proto.h"
 #include "cifs_unicode.h"
 #include "cifs_debug.h"
 #include "cifs_fs_sb.h"
 #include "fs_context.h"
 #include "cifs_ioctl.h"
 
+/*
+ * Mark as invalid, all open files on tree connections since they
+ * were closed when session to server was lost.
+ */
+void
+cifs_mark_open_files_invalid(struct cifs_tcon *tcon)
+{
+       struct cifsFileInfo *open_file = NULL;
+       struct list_head *tmp;
+       struct list_head *tmp1;
+
+       /* only send once per connect */
+       spin_lock(&tcon->ses->ses_lock);
+       if ((tcon->ses->ses_status != SES_GOOD) || (tcon->status != TID_NEED_RECON)) {
+               spin_unlock(&tcon->ses->ses_lock);
+               return;
+       }
+       tcon->status = TID_IN_FILES_INVALIDATE;
+       spin_unlock(&tcon->ses->ses_lock);
+
+       /* list all files open on tree connection and mark them invalid */
+       spin_lock(&tcon->open_file_lock);
+       list_for_each_safe(tmp, tmp1, &tcon->openFileList) {
+               open_file = list_entry(tmp, struct cifsFileInfo, tlist);
+               open_file->invalidHandle = true;
+               open_file->oplock_break_cancelled = true;
+       }
+       spin_unlock(&tcon->open_file_lock);
+
+       mutex_lock(&tcon->crfid.fid_mutex);
+       tcon->crfid.is_valid = false;
+       /* cached handle is not valid, so SMB2_CLOSE won't be sent below */
+       close_cached_dir_lease_locked(&tcon->crfid);
+       memset(tcon->crfid.fid, 0, sizeof(struct cifs_fid));
+       mutex_unlock(&tcon->crfid.fid_mutex);
+
+       spin_lock(&tcon->tc_lock);
+       if (tcon->status == TID_IN_FILES_INVALIDATE)
+               tcon->status = TID_NEED_TCON;
+       spin_unlock(&tcon->tc_lock);
+
+       /*
+        * BB Add call to invalidate_inodes(sb) for all superblocks mounted
+        * to this tcon.
+        */
+}
+
 static inline int cifs_convert_flags(unsigned int flags)
 {
        if ((flags & O_ACCMODE) == O_RDONLY)
                FILE_READ_DATA);
 }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 static u32 cifs_posix_convert_flags(unsigned int flags)
 {
        u32 posix_flags = 0;
 
        return posix_flags;
 }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 static inline int cifs_get_disposition(unsigned int flags)
 {
                return FILE_OPEN;
 }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 int cifs_posix_open(const char *full_path, struct inode **pinode,
                        struct super_block *sb, int mode, unsigned int f_flags,
                        __u32 *poplock, __u16 *pnetfid, unsigned int xid)
        kfree(presp_data);
        return rc;
 }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 static int
 cifs_nt_open(const char *full_path, struct inode *inode, struct cifs_sb_info *cifs_sb,
        else
                oplock = 0;
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        if (!tcon->broken_posix_open && tcon->unix_ext &&
            cap_unix(tcon->ses) && (CIFS_UNIX_POSIX_PATH_OPS_CAP &
                                le64_to_cpu(tcon->fsUnixInfo.Capability))) {
                 * or DFS errors.
                 */
        }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
        if (server->ops->get_lease_key)
                server->ops->get_lease_key(inode, &fid);
                goto out;
        }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        if ((oplock & CIFS_CREATE_ACTION) && !posix_open_ok && tcon->unix_ext) {
                /*
                 * Time to set mode which we can not set earlier due to
                CIFSSMBUnixSetFileInfo(xid, tcon, &args, fid.netfid,
                                       cfile->pid);
        }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 use_cache:
        fscache_use_cookie(cifs_inode_cookie(file_inode(file)),
        return rc;
 }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 static int cifs_push_posix_locks(struct cifsFileInfo *cfile);
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 /*
  * Try to reacquire byte range locks that were released when session
 static int
 cifs_relock_file(struct cifsFileInfo *cfile)
 {
-       struct cifs_sb_info *cifs_sb = CIFS_SB(cfile->dentry->d_sb);
        struct cifsInodeInfo *cinode = CIFS_I(d_inode(cfile->dentry));
        struct cifs_tcon *tcon = tlink_tcon(cfile->tlink);
        int rc = 0;
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
+       struct cifs_sb_info *cifs_sb = CIFS_SB(cfile->dentry->d_sb);
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
        down_read_nested(&cinode->lock_sem, SINGLE_DEPTH_NESTING);
        if (cinode->can_cache_brlcks) {
                return rc;
        }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        if (cap_unix(tcon->ses) &&
            (CIFS_UNIX_FCNTL_CAP & le64_to_cpu(tcon->fsUnixInfo.Capability)) &&
            ((cifs_sb->mnt_cifs_flags & CIFS_MOUNT_NOPOSIXBRL) == 0))
                rc = cifs_push_posix_locks(cfile);
        else
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
                rc = tcon->ses->server->ops->push_mand_locks(cfile);
 
        up_read(&cinode->lock_sem);
        else
                oplock = 0;
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        if (tcon->unix_ext && cap_unix(tcon->ses) &&
            (CIFS_UNIX_POSIX_PATH_OPS_CAP &
                                le64_to_cpu(tcon->fsUnixInfo.Capability))) {
                 * in the reconnect path it is important to retry hard
                 */
        }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
        desired_access = cifs_convert_flags(cfile->f_flags);
 
                goto reopen_error_exit;
        }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 reopen_success:
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
        cfile->invalidHandle = false;
        mutex_unlock(&cfile->fh_mutex);
        cinode = CIFS_I(inode);
        return rc;
 }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 /*
  * Check if there is another lock that prevents us to set the lock (posix
  * style). If such a lock exists, update the flock structure with its
 {
        return cifs_lock_secret ^ hash32_ptr((const void *)owner);
 }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 struct lock_to_push {
        struct list_head llist;
        __u8 type;
 };
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 static int
 cifs_push_posix_locks(struct cifsFileInfo *cfile)
 {
        }
        goto out;
 }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 static int
 cifs_push_locks(struct cifsFileInfo *cfile)
 {
-       struct cifs_sb_info *cifs_sb = CIFS_SB(cfile->dentry->d_sb);
        struct cifsInodeInfo *cinode = CIFS_I(d_inode(cfile->dentry));
        struct cifs_tcon *tcon = tlink_tcon(cfile->tlink);
        int rc = 0;
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
+       struct cifs_sb_info *cifs_sb = CIFS_SB(cfile->dentry->d_sb);
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
        /* we are going to update can_cache_brlcks here - need a write access */
        cifs_down_write(&cinode->lock_sem);
                return rc;
        }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        if (cap_unix(tcon->ses) &&
            (CIFS_UNIX_FCNTL_CAP & le64_to_cpu(tcon->fsUnixInfo.Capability)) &&
            ((cifs_sb->mnt_cifs_flags & CIFS_MOUNT_NOPOSIXBRL) == 0))
                rc = cifs_push_posix_locks(cfile);
        else
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
                rc = tcon->ses->server->ops->push_mand_locks(cfile);
 
        cinode->can_cache_brlcks = false;
        struct cifsFileInfo *cfile = (struct cifsFileInfo *)file->private_data;
        struct cifs_tcon *tcon = tlink_tcon(cfile->tlink);
        struct TCP_Server_Info *server = tcon->ses->server;
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        __u16 netfid = cfile->fid.netfid;
 
        if (posix_lck) {
                                      posix_lock_type, wait_flag);
                return rc;
        }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
        rc = cifs_lock_test(cfile, flock->fl_start, length, type, flock);
        if (!rc)
        }
 }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 int
 cifs_unlock_range(struct cifsFileInfo *cfile, struct file_lock *flock,
                  unsigned int xid)
        kfree(buf);
        return rc;
 }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 static int
 cifs_setlk(struct file *file, struct file_lock *flock, __u32 type,
        struct TCP_Server_Info *server = tcon->ses->server;
        struct inode *inode = d_inode(cfile->dentry);
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        if (posix_lck) {
                int posix_lock_type;
 
                                      NULL, posix_lock_type, wait_flag);
                goto out;
        }
-
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
        if (lock) {
                struct cifsLockInfo *lock;
 
        return -ENOENT;
 }
 
+void
+cifs_writedata_release(struct kref *refcount)
+{
+       struct cifs_writedata *wdata = container_of(refcount,
+                                       struct cifs_writedata, refcount);
+#ifdef CONFIG_CIFS_SMB_DIRECT
+       if (wdata->mr) {
+               smbd_deregister_mr(wdata->mr);
+               wdata->mr = NULL;
+       }
+#endif
+
+       if (wdata->cfile)
+               cifsFileInfo_put(wdata->cfile);
+
+       kvfree(wdata->pages);
+       kfree(wdata);
+}
+
+/*
+ * Write failed with a retryable error. Resend the write request. It's also
+ * possible that the page was redirtied so re-clean the page.
+ */
+static void
+cifs_writev_requeue(struct cifs_writedata *wdata)
+{
+       int i, rc = 0;
+       struct inode *inode = d_inode(wdata->cfile->dentry);
+       struct TCP_Server_Info *server;
+       unsigned int rest_len;
+
+       server = tlink_tcon(wdata->cfile->tlink)->ses->server;
+       i = 0;
+       rest_len = wdata->bytes;
+       do {
+               struct cifs_writedata *wdata2;
+               unsigned int j, nr_pages, wsize, tailsz, cur_len;
+
+               wsize = server->ops->wp_retry_size(inode);
+               if (wsize < rest_len) {
+                       nr_pages = wsize / PAGE_SIZE;
+                       if (!nr_pages) {
+                               rc = -EOPNOTSUPP;
+                               break;
+                       }
+                       cur_len = nr_pages * PAGE_SIZE;
+                       tailsz = PAGE_SIZE;
+               } else {
+                       nr_pages = DIV_ROUND_UP(rest_len, PAGE_SIZE);
+                       cur_len = rest_len;
+                       tailsz = rest_len - (nr_pages - 1) * PAGE_SIZE;
+               }
+
+               wdata2 = cifs_writedata_alloc(nr_pages, cifs_writev_complete);
+               if (!wdata2) {
+                       rc = -ENOMEM;
+                       break;
+               }
+
+               for (j = 0; j < nr_pages; j++) {
+                       wdata2->pages[j] = wdata->pages[i + j];
+                       lock_page(wdata2->pages[j]);
+                       clear_page_dirty_for_io(wdata2->pages[j]);
+               }
+
+               wdata2->sync_mode = wdata->sync_mode;
+               wdata2->nr_pages = nr_pages;
+               wdata2->offset = page_offset(wdata2->pages[0]);
+               wdata2->pagesz = PAGE_SIZE;
+               wdata2->tailsz = tailsz;
+               wdata2->bytes = cur_len;
+
+               rc = cifs_get_writable_file(CIFS_I(inode), FIND_WR_ANY,
+                                           &wdata2->cfile);
+               if (!wdata2->cfile) {
+                       cifs_dbg(VFS, "No writable handle to retry writepages rc=%d\n",
+                                rc);
+                       if (!is_retryable_error(rc))
+                               rc = -EBADF;
+               } else {
+                       wdata2->pid = wdata2->cfile->pid;
+                       rc = server->ops->async_writev(wdata2,
+                                                      cifs_writedata_release);
+               }
+
+               for (j = 0; j < nr_pages; j++) {
+                       unlock_page(wdata2->pages[j]);
+                       if (rc != 0 && !is_retryable_error(rc)) {
+                               SetPageError(wdata2->pages[j]);
+                               end_page_writeback(wdata2->pages[j]);
+                               put_page(wdata2->pages[j]);
+                       }
+               }
+
+               kref_put(&wdata2->refcount, cifs_writedata_release);
+               if (rc) {
+                       if (is_retryable_error(rc))
+                               continue;
+                       i += nr_pages;
+                       break;
+               }
+
+               rest_len -= cur_len;
+               i += nr_pages;
+       } while (i < wdata->nr_pages);
+
+       /* cleanup remaining pages from the original wdata */
+       for (; i < wdata->nr_pages; i++) {
+               SetPageError(wdata->pages[i]);
+               end_page_writeback(wdata->pages[i]);
+               put_page(wdata->pages[i]);
+       }
+
+       if (rc != 0 && !is_retryable_error(rc))
+               mapping_set_error(inode->i_mapping, rc);
+       kref_put(&wdata->refcount, cifs_writedata_release);
+}
+
+void
+cifs_writev_complete(struct work_struct *work)
+{
+       struct cifs_writedata *wdata = container_of(work,
+                                               struct cifs_writedata, work);
+       struct inode *inode = d_inode(wdata->cfile->dentry);
+       int i = 0;
+
+       if (wdata->result == 0) {
+               spin_lock(&inode->i_lock);
+               cifs_update_eof(CIFS_I(inode), wdata->offset, wdata->bytes);
+               spin_unlock(&inode->i_lock);
+               cifs_stats_bytes_written(tlink_tcon(wdata->cfile->tlink),
+                                        wdata->bytes);
+       } else if (wdata->sync_mode == WB_SYNC_ALL && wdata->result == -EAGAIN)
+               return cifs_writev_requeue(wdata);
+
+       for (i = 0; i < wdata->nr_pages; i++) {
+               struct page *page = wdata->pages[i];
+
+               if (wdata->result == -EAGAIN)
+                       __set_page_dirty_nobuffers(page);
+               else if (wdata->result < 0)
+                       SetPageError(page);
+               end_page_writeback(page);
+               cifs_readpage_to_fscache(inode, page);
+               put_page(page);
+       }
+       if (wdata->result != -EAGAIN)
+               mapping_set_error(inode->i_mapping, wdata->result);
+       kref_put(&wdata->refcount, cifs_writedata_release);
+}
+
+struct cifs_writedata *
+cifs_writedata_alloc(unsigned int nr_pages, work_func_t complete)
+{
+       struct page **pages =
+               kcalloc(nr_pages, sizeof(struct page *), GFP_NOFS);
+       if (pages)
+               return cifs_writedata_direct_alloc(pages, complete);
+
+       return NULL;
+}
+
+struct cifs_writedata *
+cifs_writedata_direct_alloc(struct page **pages, work_func_t complete)
+{
+       struct cifs_writedata *wdata;
+
+       wdata = kzalloc(sizeof(*wdata), GFP_NOFS);
+       if (wdata != NULL) {
+               wdata->pages = pages;
+               kref_init(&wdata->refcount);
+               INIT_LIST_HEAD(&wdata->list);
+               init_completion(&wdata->done);
+               INIT_WORK(&wdata->work, complete);
+       }
+       return wdata;
+}
+
+
 static int cifs_partialpagewrite(struct page *page, unsigned from, unsigned to)
 {
        struct address_space *mapping = page->mapping;
 
        fattr->cf_flags = CIFS_FATTR_DFS_REFERRAL;
 }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 static int
 cifs_get_file_info_unix(struct file *filp)
 {
 cgiiu_exit:
        return rc;
 }
+#else
+int cifs_get_inode_info_unix(struct inode **pinode,
+                            const unsigned char *full_path,
+                            struct super_block *sb, unsigned int xid)
+{
+       return -EOPNOTSUPP;
+}
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 static int
 cifs_sfu_type(struct cifs_fattr *fattr, const char *path,
        return hash;
 }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 /**
  * cifs_backup_query_path_info - SMB1 fallback code to get ino
  *
        *data = (FILE_ALL_INFO *)info.srch_entries_start;
        return 0;
 }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 static void
 cifs_set_fattr_ino(int xid,
                rc = 0;
                break;
        case -EACCES:
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
                /*
                 * perm errors, try again with backup flags if possible
                 *
                        /* nothing we can do, bail out */
                        goto out;
                }
+#else
+               goto out;
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
                break;
        default:
                cifs_dbg(FYI, "%s: unhandled err rc %d\n", __func__, rc);
        /*
         * 4. Tweak fattr based on mount options
         */
-
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 handle_mnt_opt:
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
        /* query for SFU type info if supported and needed */
        if (fattr.cf_cifsattrs & ATTR_SYSTEM &&
            cifs_sb->mnt_cifs_flags & CIFS_MOUNT_UNX_EMUL) {
        return server->ops->set_file_info(inode, full_path, &info_buf, xid);
 }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 /*
  * Open the given file (if it isn't already), set the DELETE_ON_CLOSE bit
  * and rename it to a random name that hopefully won't conflict with
 
        goto out_close;
 }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 /* copied from fs/nfs/dir.c with small changes */
 static void
        }
 
        cifs_close_deferred_file_under_dentry(tcon, full_path);
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        if (cap_unix(tcon->ses) && (CIFS_UNIX_POSIX_PATH_OPS_CAP &
                                le64_to_cpu(tcon->fsUnixInfo.Capability))) {
                rc = CIFSPOSIXDelFile(xid, tcon, full_path,
                if ((rc == 0) || (rc == -ENOENT))
                        goto psx_del_no_retry;
        }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 retry_std_delete:
        if (!server->ops->unlink) {
 
        if (tcon->posix_extensions)
                rc = smb311_posix_get_inode_info(&inode, full_path, parent->i_sb, xid);
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        else if (tcon->unix_ext)
                rc = cifs_get_inode_info_unix(&inode, full_path, parent->i_sb,
                                              xid);
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
        else
                rc = cifs_get_inode_info(&inode, full_path, NULL, parent->i_sb,
                                         xid, NULL);
        if (parent->i_mode & S_ISGID)
                mode |= S_ISGID;
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        if (tcon->unix_ext) {
                struct cifs_unix_set_info_args args = {
                        .mode   = mode,
                                       cifs_sb->local_nls,
                                       cifs_remap(cifs_sb));
        } else {
+#else
+       {
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
                struct TCP_Server_Info *server = tcon->ses->server;
                if (!(cifs_sb->mnt_cifs_flags & CIFS_MOUNT_CIFS_ACL) &&
                    (mode & S_IWUGO) == 0 && server->ops->mkdir_setinfo)
        return 0;
 }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 static int
 cifs_posix_mkdir(struct inode *inode, struct dentry *dentry, umode_t mode,
                 const char *full_path, struct cifs_sb_info *cifs_sb,
                              xid);
        goto posix_mkdir_out;
 }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 int cifs_mkdir(struct user_namespace *mnt_userns, struct inode *inode,
               struct dentry *direntry, umode_t mode)
                goto mkdir_out;
        }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        if (cap_unix(tcon->ses) && (CIFS_UNIX_POSIX_PATH_OPS_CAP &
                                le64_to_cpu(tcon->fsUnixInfo.Capability))) {
                rc = cifs_posix_mkdir(inode, direntry, mode, full_path, cifs_sb,
                if (rc != -EOPNOTSUPP)
                        goto mkdir_out;
        }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
        if (!server->ops->mkdir) {
                rc = -ENOSYS;
        struct tcon_link *tlink;
        struct cifs_tcon *tcon;
        struct TCP_Server_Info *server;
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        struct cifs_fid fid;
        struct cifs_open_parms oparms;
-       int oplock, rc;
+       int oplock;
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
+       int rc;
 
        tlink = cifs_sb_tlink(cifs_sb);
        if (IS_ERR(tlink))
        if (server->vals->protocol_id != 0)
                goto do_rename_exit;
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        /* open-file renames don't work across directories */
        if (to_dentry->d_parent != from_dentry->d_parent)
                goto do_rename_exit;
                                cifs_sb->local_nls, cifs_remap(cifs_sb));
                CIFSSMBClose(xid, tcon, fid.netfid);
        }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 do_rename_exit:
        if (rc == 0)
                d_move(from_dentry, to_dentry);
        struct cifs_sb_info *cifs_sb;
        struct tcon_link *tlink;
        struct cifs_tcon *tcon;
-       FILE_UNIX_BASIC_INFO *info_buf_source = NULL;
-       FILE_UNIX_BASIC_INFO *info_buf_target;
        unsigned int xid;
        int rc, tmprc;
        int retry_count = 0;
+       FILE_UNIX_BASIC_INFO *info_buf_source = NULL;
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
+       FILE_UNIX_BASIC_INFO *info_buf_target;
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
        if (flags & ~RENAME_NOREPLACE)
                return -EINVAL;
        if (flags & RENAME_NOREPLACE)
                goto cifs_rename_exit;
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        if (rc == -EEXIST && tcon->unix_ext) {
                /*
                 * Are src and dst hardlinks of same inode? We can only tell
         */
 
 unlink_target:
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
+
        /* Try unlinking the target dentry if it's not negative */
        if (d_really_is_positive(target_dentry) && (rc == -EACCES || rc == -EEXIST)) {
                if (d_is_dir(target_dentry))
 {
        int rc = 0;
        struct dentry *dentry = file_dentry(filp);
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        struct cifsFileInfo *cfile = (struct cifsFileInfo *) filp->private_data;
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
        if (!cifs_dentry_needs_reval(dentry))
                return rc;
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        if (tlink_tcon(cfile->tlink)->unix_ext)
                rc = cifs_get_file_info_unix(filp);
        else
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
                rc = cifs_get_file_info(filp);
 
        return rc;
        return rc;
 }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 static int
 cifs_setattr_unix(struct dentry *direntry, struct iattr *attrs)
 {
        free_xid(xid);
        return rc;
 }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 static int
 cifs_setattr_nounix(struct dentry *direntry, struct iattr *attrs)
             struct iattr *attrs)
 {
        struct cifs_sb_info *cifs_sb = CIFS_SB(direntry->d_sb);
-       struct cifs_tcon *pTcon = cifs_sb_master_tcon(cifs_sb);
        int rc, retries = 0;
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
+       struct cifs_tcon *pTcon = cifs_sb_master_tcon(cifs_sb);
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
        if (unlikely(cifs_forced_shutdown(cifs_sb)))
                return -EIO;
 
        do {
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
                if (pTcon->unix_ext)
                        rc = cifs_setattr_unix(direntry, attrs);
                else
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
                        rc = cifs_setattr_nounix(direntry, attrs);
                retries++;
        } while (is_retryable_error(rc) && retries < 2);
 
                        tcon = tlink_tcon(pSMBFile->tlink);
                        caps = le64_to_cpu(tcon->fsUnixInfo.Capability);
 #ifdef CONFIG_CIFS_POSIX
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
                        if (CIFS_UNIX_EXTATTR_CAP & caps) {
                                __u64   ExtAttrMask = 0;
                                rc = CIFSGetExtAttr(xid, tcon,
                                if (rc != EOPNOTSUPP)
                                        break;
                        }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 #endif /* CONFIG_CIFS_POSIX */
                        rc = 0;
                        if (CIFS_I(inode)->cifsAttrs & ATTR_COMPRESSED) {
 
        return rc;
 }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 /*
  * SMB 1.0 Protocol specific functions
  */
        CIFSSMBClose(xid, tcon, fid.netfid);
        return rc;
 }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 /*
  * SMB 2.1/SMB3 Protocol specific functions
                goto cifs_hl_exit;
        }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        if (tcon->unix_ext)
                rc = CIFSUnixCreateHardLink(xid, tcon, from_name, to_name,
                                            cifs_sb->local_nls,
                                            cifs_remap(cifs_sb));
        else {
+#else
+       {
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
                server = tcon->ses->server;
                if (!server->ops->create_hardlink) {
                        rc = -ENOSYS;
        /* BB what if DFS and this volume is on different share? BB */
        if (cifs_sb->mnt_cifs_flags & CIFS_MOUNT_MF_SYMLINKS)
                rc = create_mf_symlink(xid, pTcon, cifs_sb, full_path, symname);
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        else if (pTcon->unix_ext)
                rc = CIFSUnixCreateSymLink(xid, pTcon, full_path, symname,
                                           cifs_sb->local_nls,
                                           cifs_remap(cifs_sb));
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
        /* else
           rc = CIFSCreateReparseSymLink(xid, pTcon, fromName, toName,
                                        cifs_sb_target->local_nls); */
 
        return rc;
 }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 static __u32 cifs_ssetup_hdr(struct cifs_ses *ses,
                             struct TCP_Server_Info *server,
                             SESSION_SETUP_ANDX *pSMB)
        *pbcc_area = bcc_ptr;
 }
 
-
 static void unicode_ssetup_strings(char **pbcc_area, struct cifs_ses *ses,
                                   const struct nls_table *nls_cp)
 {
           for it later, but it is not very important */
        cifs_dbg(FYI, "ascii: bytes left %d\n", bleft);
 }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 int decode_ntlmssp_challenge(char *bcc_ptr, int blob_len,
                                    struct cifs_ses *ses)
        struct kvec iov[3];
 };
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
 static int
 sess_alloc_buffer(struct sess_data *sess_data, int wct)
 {
        kfree(sess_data);
        return rc;
 }
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
 
 #include <asm/processor.h>
 #include <linux/mempool.h>
 #include <linux/sched/signal.h>
+#include <linux/task_io_accounting_ops.h>
 #include "cifspdu.h"
 #include "cifsglob.h"
 #include "cifsproto.h"
                return -ERESTARTSYS;
        return rc;
 }
+
+/*
+ * Discard any remaining data in the current SMB. To do this, we borrow the
+ * current bigbuf.
+ */
+int
+cifs_discard_remaining_data(struct TCP_Server_Info *server)
+{
+       unsigned int rfclen = server->pdu_size;
+       int remaining = rfclen + server->vals->header_preamble_size -
+               server->total_read;
+
+       while (remaining > 0) {
+               int length;
+
+               length = cifs_discard_from_socket(server,
+                               min_t(size_t, remaining,
+                                     CIFSMaxBufSize + MAX_HEADER_SIZE(server)));
+               if (length < 0)
+                       return length;
+               server->total_read += length;
+               remaining -= length;
+       }
+
+       return 0;
+}
+
+static int
+__cifs_readv_discard(struct TCP_Server_Info *server, struct mid_q_entry *mid,
+                    bool malformed)
+{
+       int length;
+
+       length = cifs_discard_remaining_data(server);
+       dequeue_mid(mid, malformed);
+       mid->resp_buf = server->smallbuf;
+       server->smallbuf = NULL;
+       return length;
+}
+
+static int
+cifs_readv_discard(struct TCP_Server_Info *server, struct mid_q_entry *mid)
+{
+       struct cifs_readdata *rdata = mid->callback_data;
+
+       return  __cifs_readv_discard(server, mid, rdata->result);
+}
+
+int
+cifs_readv_receive(struct TCP_Server_Info *server, struct mid_q_entry *mid)
+{
+       int length, len;
+       unsigned int data_offset, data_len;
+       struct cifs_readdata *rdata = mid->callback_data;
+       char *buf = server->smallbuf;
+       unsigned int buflen = server->pdu_size +
+               server->vals->header_preamble_size;
+       bool use_rdma_mr = false;
+
+       cifs_dbg(FYI, "%s: mid=%llu offset=%llu bytes=%u\n",
+                __func__, mid->mid, rdata->offset, rdata->bytes);
+
+       /*
+        * read the rest of READ_RSP header (sans Data array), or whatever we
+        * can if there's not enough data. At this point, we've read down to
+        * the Mid.
+        */
+       len = min_t(unsigned int, buflen, server->vals->read_rsp_size) -
+                                                       HEADER_SIZE(server) + 1;
+
+       length = cifs_read_from_socket(server,
+                                      buf + HEADER_SIZE(server) - 1, len);
+       if (length < 0)
+               return length;
+       server->total_read += length;
+
+       if (server->ops->is_session_expired &&
+           server->ops->is_session_expired(buf)) {
+               cifs_reconnect(server, true);
+               return -1;
+       }
+
+       if (server->ops->is_status_pending &&
+           server->ops->is_status_pending(buf, server)) {
+               cifs_discard_remaining_data(server);
+               return -1;
+       }
+
+       /* set up first two iov for signature check and to get credits */
+       rdata->iov[0].iov_base = buf;
+       rdata->iov[0].iov_len = server->vals->header_preamble_size;
+       rdata->iov[1].iov_base = buf + server->vals->header_preamble_size;
+       rdata->iov[1].iov_len =
+               server->total_read - server->vals->header_preamble_size;
+       cifs_dbg(FYI, "0: iov_base=%p iov_len=%zu\n",
+                rdata->iov[0].iov_base, rdata->iov[0].iov_len);
+       cifs_dbg(FYI, "1: iov_base=%p iov_len=%zu\n",
+                rdata->iov[1].iov_base, rdata->iov[1].iov_len);
+
+       /* Was the SMB read successful? */
+       rdata->result = server->ops->map_error(buf, false);
+       if (rdata->result != 0) {
+               cifs_dbg(FYI, "%s: server returned error %d\n",
+                        __func__, rdata->result);
+               /* normal error on read response */
+               return __cifs_readv_discard(server, mid, false);
+       }
+
+       /* Is there enough to get to the rest of the READ_RSP header? */
+       if (server->total_read < server->vals->read_rsp_size) {
+               cifs_dbg(FYI, "%s: server returned short header. got=%u expected=%zu\n",
+                        __func__, server->total_read,
+                        server->vals->read_rsp_size);
+               rdata->result = -EIO;
+               return cifs_readv_discard(server, mid);
+       }
+
+       data_offset = server->ops->read_data_offset(buf) +
+               server->vals->header_preamble_size;
+       if (data_offset < server->total_read) {
+               /*
+                * win2k8 sometimes sends an offset of 0 when the read
+                * is beyond the EOF. Treat it as if the data starts just after
+                * the header.
+                */
+               cifs_dbg(FYI, "%s: data offset (%u) inside read response header\n",
+                        __func__, data_offset);
+               data_offset = server->total_read;
+       } else if (data_offset > MAX_CIFS_SMALL_BUFFER_SIZE) {
+               /* data_offset is beyond the end of smallbuf */
+               cifs_dbg(FYI, "%s: data offset (%u) beyond end of smallbuf\n",
+                        __func__, data_offset);
+               rdata->result = -EIO;
+               return cifs_readv_discard(server, mid);
+       }
+
+       cifs_dbg(FYI, "%s: total_read=%u data_offset=%u\n",
+                __func__, server->total_read, data_offset);
+
+       len = data_offset - server->total_read;
+       if (len > 0) {
+               /* read any junk before data into the rest of smallbuf */
+               length = cifs_read_from_socket(server,
+                                              buf + server->total_read, len);
+               if (length < 0)
+                       return length;
+               server->total_read += length;
+       }
+
+       /* how much data is in the response? */
+#ifdef CONFIG_CIFS_SMB_DIRECT
+       use_rdma_mr = rdata->mr;
+#endif
+       data_len = server->ops->read_data_length(buf, use_rdma_mr);
+       if (!use_rdma_mr && (data_offset + data_len > buflen)) {
+               /* data_len is corrupt -- discard frame */
+               rdata->result = -EIO;
+               return cifs_readv_discard(server, mid);
+       }
+
+       length = rdata->read_into_pages(server, rdata, data_len);
+       if (length < 0)
+               return length;
+
+       server->total_read += length;
+
+       cifs_dbg(FYI, "total_read=%u buflen=%u remaining=%u\n",
+                server->total_read, buflen, data_len);
+
+       /* discard anything left over */
+       if (server->total_read < buflen)
+               return cifs_readv_discard(server, mid);
+
+       dequeue_mid(mid, false);
+       mid->resp_buf = server->smallbuf;
+       server->smallbuf = NULL;
+       return length;
+}
 
                break;
        }
 
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        case XATTR_ACL_ACCESS:
 #ifdef CONFIG_CIFS_POSIX
                if (!value)
                                cifs_remap(cifs_sb));
 #endif  /* CONFIG_CIFS_POSIX */
                break;
+#endif /* CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
        }
 
 out:
                }
                break;
        }
-
+#ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY
        case XATTR_ACL_ACCESS:
 #ifdef CONFIG_CIFS_POSIX
                if (sb->s_flags & SB_POSIXACL)
                                cifs_remap(cifs_sb));
 #endif  /* CONFIG_CIFS_POSIX */
                break;
+#endif /* ifdef CONFIG_CIFS_ALLOW_INSECURE_LEGACY */
        }
 
        /* We could add an additional check for streams ie