Whamcloud - gitweb
LU-11975 test: fix for llog test 10h
[fs/lustre-release.git] / lustre / obdclass / llog.c
index 8a589aa..43bf396 100644 (file)
@@ -23,7 +23,7 @@
  * Copyright (c) 2003, 2010, Oracle and/or its affiliates. All rights reserved.
  * Use is subject to license terms.
  *
- * Copyright (c) 2012, 2016, Intel Corporation.
+ * Copyright (c) 2012, 2017, Intel Corporation.
  */
 /*
  * This file is part of Lustre, http://www.lustre.org/
@@ -47,6 +47,7 @@
 #include <linux/kthread.h>
 #include <llog_swab.h>
 #include <lustre_log.h>
+#include <obd_support.h>
 #include <obd_class.h>
 #include "llog_internal.h"
 /*
@@ -63,6 +64,7 @@ static struct llog_handle *llog_alloc_handle(void)
 
        init_rwsem(&loghandle->lgh_lock);
        mutex_init(&loghandle->lgh_hdr_mutex);
+       init_rwsem(&loghandle->lgh_last_sem);
        INIT_LIST_HEAD(&loghandle->u.phd.phd_entry);
        atomic_set(&loghandle->lgh_refcount, 1);
 
@@ -169,6 +171,9 @@ int llog_destroy(const struct lu_env *env, struct llog_handle *handle)
 
        dt = lu2dt_dev(handle->lgh_obj->do_lu.lo_dev);
 
+       if (unlikely(unlikely(dt->dd_rdonly)))
+               RETURN(-EROFS);
+
        th = dt_trans_create(env, dt);
        if (IS_ERR(th))
                RETURN(PTR_ERR(th));
@@ -191,38 +196,39 @@ out_trans:
 EXPORT_SYMBOL(llog_destroy);
 
 /* returns negative on error; 0 if success; 1 if success & log destroyed */
-int llog_cancel_rec(const struct lu_env *env, struct llog_handle *loghandle,
-                   int index)
+int llog_cancel_arr_rec(const struct lu_env *env, struct llog_handle *loghandle,
+                       int num, int *index)
 {
        struct llog_thread_info *lgi = llog_info(env);
        struct dt_device        *dt;
-       struct llog_log_hdr     *llh = loghandle->lgh_hdr;
+       struct llog_log_hdr     *llh;
        struct thandle          *th;
-       int                      rc;
+       __u32                    tmp_lgc_index;
+       int                      rc, i = 0;
        int rc1;
        bool subtract_count = false;
 
        ENTRY;
 
-       CDEBUG(D_RPCTRACE, "Canceling %d in log "DOSTID"\n", index,
-              POSTID(&loghandle->lgh_id.lgl_oi));
-
-       if (index == 0) {
-               CERROR("Can't cancel index 0 which is header\n");
-               RETURN(-EINVAL);
-       }
-
        LASSERT(loghandle != NULL);
        LASSERT(loghandle->lgh_ctxt != NULL);
        LASSERT(loghandle->lgh_obj != NULL);
 
+       llh = loghandle->lgh_hdr;
+
+       CDEBUG(D_RPCTRACE, "Canceling %d records, first %d in log "DFID"\n",
+              num, index[0], PFID(&loghandle->lgh_id.lgl_oi.oi_fid));
+
        dt = lu2dt_dev(loghandle->lgh_obj->do_lu.lo_dev);
 
+       if (unlikely(unlikely(dt->dd_rdonly)))
+               RETURN(0);
+
        th = dt_trans_create(env, dt);
        if (IS_ERR(th))
                RETURN(PTR_ERR(th));
 
-       rc = llog_declare_write_rec(env, loghandle, &llh->llh_hdr, index, th);
+       rc = llog_declare_write_rec(env, loghandle, &llh->llh_hdr, 0, th);
        if (rc < 0)
                GOTO(out_trans, rc);
 
@@ -240,19 +246,32 @@ int llog_cancel_rec(const struct lu_env *env, struct llog_handle *loghandle,
        down_write(&loghandle->lgh_lock);
        /* clear bitmap */
        mutex_lock(&loghandle->lgh_hdr_mutex);
-       if (!ext2_clear_bit(index, LLOG_HDR_BITMAP(llh))) {
-               CDEBUG(D_RPCTRACE, "Catalog index %u already clear?\n", index);
-               GOTO(out_unlock, rc);
+       for (i = 0; i < num; ++i) {
+               if (index[i] == 0) {
+                       CERROR("Can't cancel index 0 which is header\n");
+                       GOTO(out_unlock, rc = -EINVAL);
+               }
+               if (!ext2_clear_bit(index[i], LLOG_HDR_BITMAP(llh))) {
+                       CDEBUG(D_RPCTRACE, "Catalog index %u already clear?\n",
+                              index[i]);
+                       GOTO(out_unlock, rc = -ENOENT);
+               }
        }
-
-       loghandle->lgh_hdr->llh_count--;
+       loghandle->lgh_hdr->llh_count -= num;
        subtract_count = true;
+
+       /* Since llog_process_thread use lgi_cookie, it`s better to save them
+        * and restore after using
+        */
+       tmp_lgc_index = lgi->lgi_cookie.lgc_index;
        /* Pass this index to llog_osd_write_rec(), which will use the index
         * to only update the necesary bitmap. */
-       lgi->lgi_cookie.lgc_index = index;
+       lgi->lgi_cookie.lgc_index = index[0];
        /* update header */
-       rc = llog_write_rec(env, loghandle, &llh->llh_hdr, &lgi->lgi_cookie,
-                           LLOG_HEADER_IDX, th);
+       rc = llog_write_rec(env, loghandle, &llh->llh_hdr, (num != 1 ? NULL :
+                           &lgi->lgi_cookie), LLOG_HEADER_IDX, th);
+       lgi->lgi_cookie.lgc_index = tmp_lgc_index;
+
        if (rc != 0)
                GOTO(out_unlock, rc);
 
@@ -270,11 +289,9 @@ int llog_cancel_rec(const struct lu_env *env, struct llog_handle *loghandle,
                         * the bitmap has been clearly, so the record can not
                         * be accessed anymore, let's return 0 for now, and
                         * the orphan will be handled by LFSCK. */
-                       CERROR("%s: can't destroy empty llog #"DOSTID
-                              "#%08x: rc = %d\n",
+                       CERROR("%s: can't destroy empty llog "DFID": rc = %d\n",
                               loghandle->lgh_ctxt->loc_obd->obd_name,
-                              POSTID(&loghandle->lgh_id.lgl_oi),
-                              loghandle->lgh_id.lgl_ogen, rc);
+                              PFID(&loghandle->lgh_id.lgl_oi.oi_fid), rc);
                        GOTO(out_unlock, rc = 0);
                }
                rc = LLOG_DEL_PLAIN;
@@ -287,15 +304,23 @@ out_trans:
        rc1 = dt_trans_stop(env, dt, th);
        if (rc == 0)
                rc = rc1;
-       if (rc < 0 && subtract_count) {
+       if (rc < 0) {
                mutex_lock(&loghandle->lgh_hdr_mutex);
-               loghandle->lgh_hdr->llh_count++;
-               ext2_set_bit(index, LLOG_HDR_BITMAP(llh));
+               if (subtract_count)
+                       loghandle->lgh_hdr->llh_count += num;
+               for (i = i - 1; i >= 0; i--)
+                       ext2_set_bit(index[i], LLOG_HDR_BITMAP(llh));
                mutex_unlock(&loghandle->lgh_hdr_mutex);
        }
        RETURN(rc);
 }
 
+int llog_cancel_rec(const struct lu_env *env, struct llog_handle *loghandle,
+                   int index)
+{
+       return llog_cancel_arr_rec(env, loghandle, 1, &index);
+}
+
 int llog_read_header(const struct lu_env *env, struct llog_handle *handle,
                     const struct obd_uuid *uuid)
 {
@@ -421,18 +446,22 @@ static int llog_process_thread(void *arg)
        struct llog_handle              *loghandle = lpi->lpi_loghandle;
        struct llog_log_hdr             *llh = loghandle->lgh_hdr;
        struct llog_process_cat_data    *cd  = lpi->lpi_catdata;
+       struct llog_thread_info         *lti;
        char                            *buf;
        size_t                           chunk_size;
-       __u64                            cur_offset, tmp_offset;
+       __u64                            cur_offset;
        int                              rc = 0, index = 1, last_index;
        int                              saved_index = 0;
        int                              last_called_index = 0;
+       bool                             repeated = false;
 
        ENTRY;
 
        if (llh == NULL)
                RETURN(-EINVAL);
 
+       lti = lpi->lpi_env == NULL ? NULL : llog_info(lpi->lpi_env);
+
        cur_offset = chunk_size = llh->llh_hdr.lrh_len;
        /* expect chunk_size to be power of two */
        LASSERT(is_power_of_2(chunk_size));
@@ -454,9 +483,11 @@ static int llog_process_thread(void *arg)
 
        while (rc == 0) {
                struct llog_rec_hdr *rec;
-               off_t chunk_offset;
+               off_t chunk_offset = 0;
                unsigned int buf_offset = 0;
                bool partial_chunk;
+               int     lh_last_idx;
+               int     synced_idx = 0;
 
                /* skip records not set in bitmap */
                while (index <= last_index &&
@@ -473,8 +504,20 @@ static int llog_process_thread(void *arg)
 repeat:
                /* get the buf with our target record; avoid old garbage */
                memset(buf, 0, chunk_size);
+               /* the record index for outdated chunk data */
+               /* it is safe to process buffer until saved lgh_last_idx */
+               lh_last_idx = LLOG_HDR_TAIL(llh)->lrt_index;
                rc = llog_next_block(lpi->lpi_env, loghandle, &saved_index,
                                     index, &cur_offset, buf, chunk_size);
+               if (repeated && rc)
+                       CDEBUG(D_OTHER, "cur_offset %llu, chunk_offset %llu,"
+                              " buf_offset %u, rc = %d\n", cur_offset,
+                              (__u64)chunk_offset, buf_offset, rc);
+               /* we`ve tried to reread the chunk, but there is no
+                * new records */
+               if (rc == -EIO && repeated && (chunk_offset + buf_offset) ==
+                   cur_offset)
+                       GOTO(out, rc = 0);
                if (rc != 0)
                        GOTO(out, rc);
 
@@ -483,8 +526,7 @@ repeat:
                 * The absolute offset of the current chunk is calculated
                 * from cur_offset value and stored in chunk_offset variable.
                 */
-               tmp_offset = cur_offset;
-               if (do_div(tmp_offset, chunk_size) != 0) {
+               if ((cur_offset & (chunk_size - 1)) != 0) {
                        partial_chunk = true;
                        chunk_offset = cur_offset & ~(chunk_size - 1);
                } else {
@@ -508,41 +550,59 @@ repeat:
                        CDEBUG(D_OTHER, "after swabbing, type=%#x idx=%d\n",
                               rec->lrh_type, rec->lrh_index);
 
-                       /* for partial chunk the end of it is zeroed, check
-                        * for index 0 to distinguish it. */
-                       if (partial_chunk && rec->lrh_index == 0) {
-                               /* concurrent llog_add() might add new records
-                                * while llog_processing, check this is not
-                                * the case and re-read the current chunk
-                                * otherwise. */
-                               int records;
-                               if (index > loghandle->lgh_last_idx)
-                                       GOTO(out, rc = 0);
-                               /* <2 records means no more records
-                                * if the last record we processed was
-                                * the final one, then the underlying
-                                * object might have been destroyed yet.
-                                * we better don't access that.. */
-                               mutex_lock(&loghandle->lgh_hdr_mutex);
-                               records = loghandle->lgh_hdr->llh_count;
-                               mutex_unlock(&loghandle->lgh_hdr_mutex);
-                               if (records <= 1)
-                                       GOTO(out, rc = 0);
-                               CDEBUG(D_OTHER, "Re-read last llog buffer for "
-                                      "new records, index %u, last %u\n",
-                                      index, loghandle->lgh_last_idx);
+                       if (index == (synced_idx + 1) &&
+                           synced_idx == LLOG_HDR_TAIL(llh)->lrt_index)
+                               GOTO(out, rc = 0);
+
+                       if (OBD_FAIL_PRECHECK(OBD_FAIL_LLOG_PROCESS_TIMEOUT) &&
+                               cfs_fail_val == (unsigned int)
+                                       (loghandle->lgh_id.lgl_oi.oi.oi_id &
+                                        0xFFFFFFFF)) {
+                               OBD_RACE(OBD_FAIL_LLOG_PROCESS_TIMEOUT);
+                       }
+
+                       /* the bitmap could be changed during processing
+                        * records from the chunk. For wrapped catalog
+                        * it means we can read deleted record and try to
+                        * process it. Check this case and reread the chunk.
+                        * It is safe to process to lh_last_idx, including
+                        * lh_last_idx if it was synced. We can not do <=
+                        * comparison, cause for wrapped catalog lgh_last_idx
+                        * could be less than index. So we detect last index
+                        * for processing as index == lh_last_idx+1. But when
+                        * catalog is wrapped and full lgh_last_idx=llh_cat_idx,
+                        * the first processing index is llh_cat_idx+1.
+                        */
+
+                       if ((index == lh_last_idx && synced_idx != index) ||
+                           (index == (lh_last_idx + 1) &&
+                            !(index == (llh->llh_cat_idx + 1) &&
+                              (llh->llh_flags & LLOG_F_IS_CAT))) ||
+                           (rec->lrh_index == 0 && !repeated)) {
+
                                /* save offset inside buffer for the re-read */
                                buf_offset = (char *)rec - (char *)buf;
                                cur_offset = chunk_offset;
+                               repeated = true;
+                               /* We need to be sure lgh_last_idx
+                                * record was saved to disk
+                                */
+                               down_read(&loghandle->lgh_last_sem);
+                               synced_idx = LLOG_HDR_TAIL(llh)->lrt_index;
+                               up_read(&loghandle->lgh_last_sem);
+                               CDEBUG(D_OTHER, "synced_idx: %d\n", synced_idx);
                                goto repeat;
+
                        }
 
+                       repeated = false;
+
                        if (rec->lrh_len == 0 || rec->lrh_len > chunk_size) {
-                               CWARN("%s: invalid length %d in llog "DOSTID
+                               CWARN("%s: invalid length %d in llog "DFID
                                      "record for index %d/%d\n",
                                       loghandle->lgh_ctxt->loc_obd->obd_name,
                                       rec->lrh_len,
-                                      POSTID(&loghandle->lgh_id.lgl_oi),
+                                      PFID(&loghandle->lgh_id.lgl_oi.oi_fid),
                                       rec->lrh_index, index);
 
                                GOTO(out, rc = -EINVAL);
@@ -555,10 +615,10 @@ repeat:
                        }
 
                        if (rec->lrh_index != index) {
-                               CERROR("%s: "DOSTID" Invalid record: index %u"
+                               CERROR("%s: "DFID" Invalid record: index %u"
                                       " but expected %u\n",
                                       loghandle->lgh_ctxt->loc_obd->obd_name,
-                                      POSTID(&loghandle->lgh_id.lgl_oi),
+                                      PFID(&loghandle->lgh_id.lgl_oi.oi_fid),
                                       rec->lrh_index, index);
                                GOTO(out, rc = -ERANGE);
                        }
@@ -568,15 +628,42 @@ repeat:
                               rec->lrh_index, rec->lrh_len,
                               (int)(buf + chunk_size - (char *)rec));
 
-                       loghandle->lgh_cur_idx = rec->lrh_index;
+                       /* lgh_cur_offset is used only at llog_test_3 */
                        loghandle->lgh_cur_offset = (char *)rec - (char *)buf +
                                                    chunk_offset;
 
                        /* if set, process the callback on this record */
                        if (ext2_test_bit(index, LLOG_HDR_BITMAP(llh))) {
+                               struct llog_cookie *lgc;
+                               __u64   tmp_off;
+                               int     tmp_idx;
+
+                               CDEBUG(D_OTHER, "index: %d, lh_last_idx: %d "
+                                      "synced_idx: %d lgh_last_idx: %d\n",
+                                      index, lh_last_idx, synced_idx,
+                                      loghandle->lgh_last_idx);
+
+                               if (lti != NULL) {
+                                       lgc = &lti->lgi_cookie;
+                                       /* store lu_env for recursive calls */
+                                       tmp_off = lgc->lgc_offset;
+                                       tmp_idx = lgc->lgc_index;
+
+                                       lgc->lgc_offset = (char *)rec -
+                                               (char *)buf + chunk_offset;
+                                       lgc->lgc_index = rec->lrh_index;
+                               }
+                               /* using lu_env for passing record offset to
+                                * llog_write through various callbacks */
                                rc = lpi->lpi_cb(lpi->lpi_env, loghandle, rec,
                                                 lpi->lpi_cbdata);
                                last_called_index = index;
+
+                               if (lti != NULL) {
+                                       lgc->lgc_offset = tmp_off;
+                                       lgc->lgc_index = tmp_idx;
+                               }
+
                                if (rc == LLOG_PROC_BREAK) {
                                        GOTO(out, rc);
                                } else if (rc == LLOG_DEL_RECORD) {
@@ -586,6 +673,12 @@ repeat:
                                }
                                if (rc)
                                        GOTO(out, rc);
+                               /* some stupid callbacks directly cancel records
+                                * and delete llog. Check it and stop
+                                * processing. */
+                               if (loghandle->lgh_hdr == NULL ||
+                                   loghandle->lgh_hdr->llh_count == 1)
+                                       GOTO(out, rc = 0);
                        }
                        /* exit if the last index is reached */
                        if (index >= last_index)
@@ -613,7 +706,14 @@ out:
                         * llog file, probably I/O error or the log got
                         * corrupted to be able to finally release the log we
                         * discard any remaining bits in the header */
-                       CERROR("Local llog found corrupted\n");
+                       CERROR("%s: Local llog found corrupted #"DOSTID":%x"
+                              " %s index %d count %d\n",
+                              loghandle->lgh_ctxt->loc_obd->obd_name,
+                              POSTID(&loghandle->lgh_id.lgl_oi),
+                              loghandle->lgh_id.lgl_ogen,
+                              ((llh->llh_flags & LLOG_F_IS_CAT) ? "catalog" :
+                               "plain"), index, llh->llh_count);
+
                        while (index <= last_index) {
                                if (ext2_test_bit(index,
                                                  LLOG_HDR_BITMAP(llh)) != 0)
@@ -626,8 +726,8 @@ out:
        }
 
        OBD_FREE_LARGE(buf, chunk_size);
-        lpi->lpi_rc = rc;
-        return 0;
+       lpi->lpi_rc = rc;
+       return 0;
 }
 
 static int llog_process_thread_daemonize(void *arg)
@@ -1034,6 +1134,9 @@ int llog_open_create(const struct lu_env *env, struct llog_ctxt *ctxt,
 
        d = lu2dt_dev((*res)->lgh_obj->do_lu.lo_dev);
 
+       if (unlikely(unlikely(d->dd_rdonly)))
+               RETURN(-EROFS);
+
        th = dt_trans_create(env, d);
        if (IS_ERR(th))
                GOTO(out, rc = PTR_ERR(th));
@@ -1101,7 +1204,8 @@ int llog_write(const struct lu_env *env, struct llog_handle *loghandle,
 {
        struct dt_device        *dt;
        struct thandle          *th;
-       int                      rc;
+       bool                    need_cookie;
+       int                     rc;
 
        ENTRY;
 
@@ -1111,6 +1215,9 @@ int llog_write(const struct lu_env *env, struct llog_handle *loghandle,
 
        dt = lu2dt_dev(loghandle->lgh_obj->do_lu.lo_dev);
 
+       if (unlikely(unlikely(dt->dd_rdonly)))
+               RETURN(-EROFS);
+
        th = dt_trans_create(env, dt);
        if (IS_ERR(th))
                RETURN(PTR_ERR(th));
@@ -1124,8 +1231,21 @@ int llog_write(const struct lu_env *env, struct llog_handle *loghandle,
        if (rc)
                GOTO(out_trans, rc);
 
+       need_cookie = !(idx == LLOG_HEADER_IDX || idx == LLOG_NEXT_IDX);
+
        down_write(&loghandle->lgh_lock);
-       rc = llog_write_rec(env, loghandle, rec, NULL, idx, th);
+       if (need_cookie) {
+               struct llog_thread_info *lti = llog_info(env);
+
+               /* cookie comes from llog_process_thread */
+               rc = llog_write_rec(env, loghandle, rec, &lti->lgi_cookie,
+                                   rec->lrh_index, th);
+               /* upper layer didn`t pass cookie so change rc */
+               rc = (rc == 1 ? 0 : rc);
+       } else {
+               rc = llog_write_rec(env, loghandle, rec, NULL, idx, th);
+       }
+
        up_write(&loghandle->lgh_lock);
 out_trans:
        dt_trans_stop(env, dt, th);
@@ -1309,8 +1429,9 @@ __u64 llog_size(const struct lu_env *env, struct llog_handle *llh)
 
        rc = llh->lgh_obj->do_ops->do_attr_get(env, llh->lgh_obj, &la);
        if (rc) {
-               CERROR("%s: attr_get failed, rc = %d\n",
-                      llh->lgh_ctxt->loc_obd->obd_name, rc);
+               CERROR("%s: attr_get failed for "DFID": rc = %d\n",
+                      llh->lgh_ctxt->loc_obd->obd_name,
+                      PFID(&llh->lgh_id.lgl_oi.oi_fid), rc);
                return 0;
        }