]> git.apps.os.sepia.ceph.com Git - ceph.git/commitdiff
rbd: fix spelling errors 51228/head
authorJosh Soref <2119212+jsoref@users.noreply.github.com>
Thu, 23 Jun 2022 01:24:32 +0000 (21:24 -0400)
committerJosh Soref <2119212+jsoref@users.noreply.github.com>
Wed, 26 Apr 2023 13:30:53 +0000 (09:30 -0400)
* acquire
* are
* asynchronous
* attempt
* bootstrap
* concurrent
* consume
* couldn't
* cumulative
* disable
* disabling
* disaster
* disconnected
* endianness
* entries
* exclusive
* filesystem
* flag
* generic
* github
* image
* information
* initiating
* latency
* limitations
* metadata
* modify
* namespace
* noautoconsole
* ourselves
* prefetch
* propagate
* protection
* recorder
* recover
* release
* replicated
* reserved
* selection
* sentinel
* several
* snapshot
* source
* specifying
* suppress
* synchronize
* the
* transfer
* triggering
* unknown
* validation
* version
* visible
* write log entries

Signed-off-by: Josh Soref <2119212+jsoref@users.noreply.github.com>
48 files changed:
qa/tasks/qemu.py
qa/tasks/rbd_fio.py
qa/workunits/rbd/concurrent.sh
qa/workunits/rbd/image_read.sh
qa/workunits/windows/libvirt_vm/setup.sh
qa/workunits/windows/test_rbd_wnbd.py
src/cls/rbd/cls_rbd.cc
src/common/options/rbd-mirror.yaml.in
src/include/rbd/librbd.h
src/journal/JournalRecorder.cc
src/journal/ObjectRecorder.h
src/librbd/api/Migration.cc
src/librbd/cache/ObjectCacherObjectDispatch.cc
src/librbd/cache/WriteAroundObjectDispatch.cc
src/librbd/cache/pwl/AbstractWriteLog.cc
src/librbd/cache/pwl/AbstractWriteLog.h
src/librbd/cache/pwl/LogEntry.h
src/librbd/cache/pwl/LogMap.cc
src/librbd/crypto/luks/LoadRequest.cc
src/librbd/deep_copy/ObjectCopyRequest.cc
src/librbd/deep_copy/Utils.cc
src/librbd/exclusive_lock/ImageDispatch.cc
src/librbd/image/OpenRequest.h
src/librbd/image/ValidatePoolRequest.cc
src/librbd/io/ObjectRequest.cc
src/librbd/io/RefreshImageDispatch.cc
src/librbd/librbd.cc
src/librbd/migration/HttpClient.cc
src/librbd/migration/QCOWFormat.cc
src/librbd/operation/DisableFeaturesRequest.h
src/librbd/operation/SnapshotRemoveRequest.h
src/pybind/rbd/rbd.pyx
src/test/journal/test_JournalPlayer.cc
src/test/librbd/cache/test_mock_ParentCacheObjectDispatch.cc
src/test/librbd/deep_copy/test_mock_MetadataCopyRequest.cc
src/test/librbd/fsx.cc
src/test/librbd/test_librbd.cc
src/test/rbd_mirror/mock/MockBaseRequest.h
src/test/rbd_mirror/test_mock_InstanceWatcher.cc
src/tools/rbd/action/MirrorPool.cc
src/tools/rbd/action/Perf.cc
src/tools/rbd_mirror/PoolReplayer.cc
src/tools/rbd_mirror/RemotePoolPoller.cc
src/tools/rbd_mirror/image_replayer/journal/Replayer.cc
src/tools/rbd_recover_tool/README
src/tools/rbd_recover_tool/common_h
src/tools/rbd_recover_tool/rbd-recover-tool
src/tools/rbd_wnbd/rbd_wnbd.cc

index 6533026b4abb80b53195a29f2f5684453fa28344..336d2a0fe671af05afd38949ad079e1f651d9b96 100644 (file)
@@ -654,7 +654,7 @@ def task(ctx, config):
                         action: create / clone / none (optional, defaults to create)
                         image_name: <image name> (optional)
                         parent_name: <parent_name> (if action == clone),
-                        type: filesystem / block (optional, defaults to fileystem)
+                        type: filesystem / block (optional, defaults to filesystem)
                         image_url: <URL> (optional),
                         image_size: <MiB> (optional)
                         encryption_format: luks1 / luks2 / none (optional, defaults to none)
index 959d07d49ae0e8e06cf884c159b2ecb3245b96e6..2eff607fd245b6a312771c69b40f52db24208fd2 100644 (file)
@@ -87,7 +87,7 @@ def run_rbd_map(remote, image, iodepth):
 def run_fio(remote, config, rbd_test_dir):
     """
     create fio config file with options based on above config
-    get the fio from github, generate binary, and use it to run on
+    get the fio from GitHub, generate binary, and use it to run on
     the generated fio config file
     """
     fio_config=NamedTemporaryFile(mode='w', prefix='fio_rbd_', dir='/tmp/', delete=False)
index abaad75f581823ac90c26c3f364263e223417b6c..da6c8e577baffd211063ba55899e5e1f529b4026 100755 (executable)
@@ -26,7 +26,7 @@
 # the background.
 #
 # An iteration of the test consists of performing some number of
-# passes, initating each pass as a background job, and finally
+# passes, initiating each pass as a background job, and finally
 # sleeping for a variable delay.  The delay is initially a specified
 # value, but each iteration shortens that proportionally, such that
 # the last iteration will not delay at all.
index ddca8356ef6b7e8d2a3ea050f84b8f81b64c255c..63367147dc06503a960ee6d121cfa36463e51f3c 100755 (executable)
@@ -219,7 +219,7 @@ function parseargs() {
        echo "    object order is ${OBJECT_ORDER}, so" \
                "objects are ${OBJECT_SIZE} bytes"
        echo "    page size is ${PAGE_SIZE} bytes, so" \
-               "there are are ${OBJECT_PAGES} pages in an object"
+               "there are ${OBJECT_PAGES} pages in an object"
        echo "    derived image size is ${IMAGE_SIZE} MB, so" \
                "there are ${IMAGE_OBJECTS} objects in an image"
        if [ "${TEST_CLONES}" = true ]; then
index 51e91ec42b1ae648469b7ab192c56585410c1c79..001958a58090b8768bb3b83d59b80946d8f7468d 100755 (executable)
@@ -77,7 +77,7 @@ sudo virt-install \
     --network network=default,model=virtio \
     --controller type=virtio-serial \
     --channel unix,target_type=virtio,name=org.qemu.guest_agent.0 \
-    --noautoconsol
+    --noautoconsole
 
 export SSH_USER="administrator"
 export SSH_KNOWN_HOSTS_FILE="${DIR}/known_hosts"
index f22810e2ea14a138153bd728da18dd9d05ec89a0..db14234a2b5f0823e45dcbbd1e803f1f5ba87359 100644 (file)
@@ -900,7 +900,7 @@ if __name__ == '__main__':
     try:
         test_cls = TESTS[args.test_name]
     except KeyError:
-        raise CephTestException("Unkown test: {}".format(args.test_name))
+        raise CephTestException("Unknown test: {}".format(args.test_name))
 
     runner = TestRunner(
         test_cls,
index b4efc23ceb60b966164cc9ac300ef52a14c7c27f..7ed55e1230bae2a8ad4c2c78e5ee3d8444d91cd2 100644 (file)
@@ -1134,7 +1134,7 @@ int get_protection_status(cls_method_context_t hctx, bufferlist *in,
 }
 
 /**
- * set the proctection status of a snapshot
+ * set the protection status of a snapshot
  *
  * Input:
  * @param snapid (uint64_t) which snapshot to set the status of
@@ -3002,7 +3002,7 @@ static int dir_remove_image_helper(cls_method_context_t hctx,
  * Rename an image in the directory, updating both indexes
  * atomically. This can't be done from the client calling
  * dir_add_image and dir_remove_image in one transaction because the
- * results of the first method are not visibale to later steps.
+ * results of the first method are not visible to later steps.
  *
  * Input:
  * @param src original name of the image
@@ -6800,7 +6800,7 @@ int mirror_image_snapshot_unlink_peer(cls_method_context_t hctx, bufferlist *in,
 /**
  * Input:
  * @param snap_id: snapshot id
- * @param complete: true if shapshot fully copied/complete
+ * @param complete: true if snapshot fully copied/complete
  * @param last_copied_object_number: last copied object number
  *
  * Output:
index 93c059ff227a1ea96db8ee8a14f541484eb63ad2..ba7681d04d3532d5eb61eaa58608b694f1a4ef6f 100644 (file)
@@ -111,7 +111,7 @@ options:
 - name: rbd_mirror_image_policy_rebalance_timeout
   type: float
   level: advanced
-  desc: number of seconds policy should be idle before trigerring reshuffle (rebalance)
+  desc: number of seconds policy should be idle before triggering reshuffle (rebalance)
     of images
   default: 0
   services:
index 7ae20e4dd583beb6ad76c376dd5c0a7dbedc049d..50901cb8a82d13e8dd0baf6ffae313b4ac89be65 100644 (file)
@@ -905,7 +905,7 @@ CEPH_RBD_API int rbd_snap_rename(rbd_image_t image, const char *snapname,
  */
 CEPH_RBD_API int rbd_snap_protect(rbd_image_t image, const char *snap_name);
 /**
- * Allow a snaphshot to be deleted.
+ * Allow a snapshot to be deleted.
  *
  * @param snap_name which snapshot to unprotect
  * @returns 0 on success, negative error code on failure
index 0304ae777a96c31ca38f991e2732c5a7f0c26312..d2b0c3dc970cdd5b40bf8570ddf932834a5c316a 100644 (file)
@@ -189,9 +189,9 @@ void JournalRecorder::flush(Context *on_safe) {
 ceph::ref_t<ObjectRecorder> JournalRecorder::get_object(uint8_t splay_offset) {
   ceph_assert(ceph_mutex_is_locked(m_lock));
 
-  const auto& object_recoder = m_object_ptrs.at(splay_offset);
-  ceph_assert(object_recoder);
-  return object_recoder;
+  const auto& object_recorder = m_object_ptrs.at(splay_offset);
+  ceph_assert(object_recorder);
+  return object_recorder;
 }
 
 void JournalRecorder::close_and_advance_object_set(uint64_t object_set) {
index 5c5f88c86db96f130ccb979620c587310adb5c62..a4d75b3a7e38d341662161631b9c287fb5a153ef 100644 (file)
@@ -146,7 +146,7 @@ private:
   ceph::condition_variable m_in_flight_callbacks_cond;
   uint64_t m_in_flight_bytes = 0;
 
-  bool send_appends(bool force, ceph::ref_t<FutureImpl> flush_sentinal);
+  bool send_appends(bool force, ceph::ref_t<FutureImpl> flush_sentinel);
   void handle_append_flushed(uint64_t tid, int r);
   void append_overflowed();
 
index 957c872ac5515ab970113e6ef646dbb0f7d563ef..ae95a7191c8c9bf6539358481921cfbf246ba0f2 100644 (file)
@@ -1787,7 +1787,7 @@ int Migration<I>::enable_mirroring(
 // When relinking children we should be careful as it my be interrupted
 // at any moment by some reason and we may end up in an inconsistent
 // state, which we have to be able to fix with "migration abort". Below
-// are all possible states during migration (P1 - sourse parent, P2 -
+// are all possible states during migration (P1 - source parent, P2 -
 // destination parent, C - child):
 //
 //   P1  P2    P1  P2    P1  P2    P1  P2
index 822a053e1431c414563ed1c5f96318a45c0b919b..91d720abe90aaccc413e9cade173ef77d0df2d42 100644 (file)
@@ -207,7 +207,7 @@ bool ObjectCacherObjectDispatch<I>::read(
   on_dispatched = util::create_async_context_callback(*m_image_ctx,
                                                       on_dispatched);
 
-  // embed the RBD-internal read flags in the genenric RADOS op_flags and
+  // embed the RBD-internal read flags in the generic RADOS op_flags and
   op_flags = ((op_flags & ~ObjectCacherWriteback::READ_FLAGS_MASK) |
               ((read_flags << ObjectCacherWriteback::READ_FLAGS_SHIFT) &
                ObjectCacherWriteback::READ_FLAGS_MASK));
index fafb73f409ae3c8869239bca5107415d3f2dfb2b..bb3edb75b1fe02844369c4ad48a22b2ba09d6af0 100644 (file)
@@ -402,7 +402,7 @@ void WriteAroundObjectDispatch<I>::handle_in_flight_io_complete(
   }
 
   // complete flushes that were waiting on in-flight IO
-  // (and propogate any IO error to first flush)
+  // (and propagate any IO error to first flush)
   for (auto& it : finished_flushes) {
     ldout(cct, 20) << "completing flush: tid=" << it.first << ", "
                    << "r=" << pending_flush_error << dendl;
@@ -447,7 +447,7 @@ void WriteAroundObjectDispatch<I>::handle_in_flight_flush_complete(
   m_lock.unlock();
 
   // complete flushes that were waiting on in-flight IO
-  // (and propogate any IO errors)
+  // (and propagate any IO errors)
   for (auto& it : finished_flushes) {
     ldout(cct, 20) << "completing flush: tid=" << it.first << dendl;
     it.second->complete(pending_flush_error);
index 1e784f6b56696c8093aa4995acb92d1091591a66..b6af9b2ec2d279f41a13bf901cbb65464117c16a 100644 (file)
@@ -259,7 +259,7 @@ void AbstractWriteLog<I>::perf_start(std::string name) {
 
   plb.add_u64_counter(l_librbd_pwl_cmp, "cmp", "Compare and Write requests");
   plb.add_u64_counter(l_librbd_pwl_cmp_bytes, "cmp_bytes", "Compare and Write bytes compared/written");
-  plb.add_time_avg(l_librbd_pwl_cmp_latency, "cmp_lat", "Compare and Write latecy");
+  plb.add_time_avg(l_librbd_pwl_cmp_latency, "cmp_lat", "Compare and Write latency");
   plb.add_u64_counter(l_librbd_pwl_cmp_fails, "cmp_fails", "Compare and Write compare fails");
 
   plb.add_u64_counter(l_librbd_pwl_internal_flush, "internal_flush", "Flush RWL (write back to OSD)");
@@ -517,7 +517,7 @@ void AbstractWriteLog<I>::pwl_init(Context *on_finish, DeferredContexts &later)
   if ((!m_cache_state->present) &&
       (access(m_log_pool_name.c_str(), F_OK) == 0)) {
     ldout(cct, 5) << "There's an existing pool file " << m_log_pool_name
-                  << ", While there's no cache in the image metatata." << dendl;
+                  << ", While there's no cache in the image metadata." << dendl;
     if (remove(m_log_pool_name.c_str()) != 0) {
       lderr(cct) << "failed to remove the pool file " << m_log_pool_name
                  << dendl;
@@ -1752,7 +1752,7 @@ void AbstractWriteLog<I>::process_writeback_dirty_entries() {
     std::lock_guard locker(m_lock);
     while (flushed < IN_FLIGHT_FLUSH_WRITE_LIMIT) {
       if (m_shutting_down) {
-        ldout(cct, 5) << "Flush during shutdown supressed" << dendl;
+        ldout(cct, 5) << "Flush during shutdown suppressed" << dendl;
         /* Do flush complete only when all flush ops are finished */
         all_clean = !m_flush_ops_in_flight;
         break;
index ffe299c37d3e3d2cfc7d088722bf96cb1095189c..30f466cf07cd59c59d08d1593ba3c7f318f223e8 100644 (file)
@@ -298,7 +298,7 @@ protected:
   mutable ceph::mutex m_log_retire_lock;
   /* Hold a read lock on m_entry_reader_lock to add readers to log entry
    * bufs. Hold a write lock to prevent readers from being added (e.g. when
-   * removing log entrys from the map). No lock required to remove readers. */
+   * removing log entries from the map). No lock required to remove readers. */
   mutable RWLock m_entry_reader_lock;
   /* Hold m_log_append_lock while appending or retiring log entries. */
   mutable ceph::mutex m_log_append_lock;
index ecaca0b7b70d6157fcf3fcaddcda1f88cd14272e..0a4afe3e228134a3d31dbf2649dc6079930c9360 100644 (file)
@@ -162,7 +162,7 @@ protected:
   buffer::ptr cache_bp;
   buffer::list cache_bl;
   std::atomic<int> bl_refs = {0}; /* The refs held on cache_bp by cache_bl */
-  /* Used in WriteLogEntry::get_cache_bl() to syncronize between threads making entries readable */
+  /* Used in WriteLogEntry::get_cache_bl() to synchronize between threads making entries readable */
   mutable ceph::mutex m_entry_bl_lock;
 
   virtual void init_cache_bp() {}
index b3e7022b08b17e3cc828c2d0e3739ea142ea2913..8804e38516787470807ed7f65d47b22d003fc217 100644 (file)
@@ -250,7 +250,7 @@ LogMapEntries<T> LogMap<T>::find_map_entries_locked(const BlockExtent &block_ext
  * represent the entire block extent of the GenericWriteLogEntry, and the
  * WriteLogMapEntry is added to the set.
  *
- * The set must not contain overlapping WriteLogMapEntrys. WriteLogMapEntrys
+ * The set must not contain overlapping write log entries. Entries
  * in the set that overlap with one being added are adjusted (shrunk, split,
  * or removed) before the new entry is added.
  *
index b5e16f10016b26c5c07b0a893d02da36d48d0763..25843b5ff63f7411b0e52be8214d3d62f1fb6bbd 100644 (file)
@@ -238,7 +238,7 @@ void LoadRequest<I>::read_volume_key() {
   if (r != 0) {
     auto keyslots_end_offset = m_header.get_data_offset();
     if (m_offset < keyslots_end_offset) {
-      // perhaps we did not feed the the necessary keyslot, retry
+      // perhaps we did not feed the necessary keyslot, retry
       auto ctx = create_context_callback<
               LoadRequest<I>, &LoadRequest<I>::handle_read_keyslots>(this);
       read(keyslots_end_offset, ctx);
index e8b42b68f7deebdff610220bf76fed899df0e07e..4c380c642c15264f5bcf3d5acef7c9fbb4a48b42 100644 (file)
@@ -574,7 +574,7 @@ void ObjectCopyRequest<I>::merge_write_ops() {
   for (auto& [write_read_snap_ids, read_op] : m_read_ops) {
     auto src_snap_seq = write_read_snap_ids.first;
 
-    // convert the the resulting sparse image extent map to an interval ...
+    // convert the resulting sparse image extent map to an interval ...
     auto& image_data_interval = m_dst_data_interval[src_snap_seq];
     for (auto [image_offset, image_length] : read_op.image_extent_map) {
       image_data_interval.union_insert(image_offset, image_length);
index c2dd25020e43bb29158563e4626bf390589da7b8..23aad8ec4060e8aeac0d1b1c5d6dae8b921e2536 100644 (file)
@@ -36,7 +36,7 @@ void compute_snap_map(CephContext* cct,
       ++dst_snap_id_it;
     }
 
-    // we should only have the HEAD revision in the the last snap seq
+    // we should only have the HEAD revision in the last snap seq
     ceph_assert(snap_ids.empty() || snap_ids[0] != CEPH_NOSNAP);
     snap_ids.insert(snap_ids.begin(), it.second);
 
index f53b3692a1b1c25505a212807e2d5ccb2d7a4f3b..92544148c57a14bb213beebf1eb2a23fe80e97b4 100644 (file)
@@ -29,7 +29,7 @@ template <typename I>
 ImageDispatch<I>::ImageDispatch(I* image_ctx)
   : m_image_ctx(image_ctx),
     m_lock(ceph::make_shared_mutex(
-      util::unique_lock_name("librbd::exclusve_lock::ImageDispatch::m_lock",
+      util::unique_lock_name("librbd::exclusive_lock::ImageDispatch::m_lock",
                              this))) {
 }
 
index 0fe218a3982892705667b4e8ea6ee454f4ca4189..30352d18ac4fdfe94793eaf5c82007c24a96297c 100644 (file)
@@ -55,7 +55,7 @@ private:
    *            V2_GET_CREATE_TIMESTAMP             |
    *                |                               |
    *                v                               |
-   *            V2_GET_ACCESS_MODIFIY_TIMESTAMP     |
+   *            V2_GET_ACCESS_MODIFY_TIMESTAMP      |
    *                |                               |
    *                v                               |
    *            V2_GET_DATA_POOL --------------> REFRESH
index 6f2872e256291422f14eac639dd272f0da49429b..17641086ce284d91b963d578b75b13287f83a484 100644 (file)
@@ -34,7 +34,7 @@ ValidatePoolRequest<I>::ValidatePoolRequest(librados::IoCtx& io_ctx,
                                             Context *on_finish)
     : m_cct(reinterpret_cast<CephContext*>(io_ctx.cct())),
       m_on_finish(on_finish) {
-    // validatation should occur in default namespace
+    // validation should occur in default namespace
     m_io_ctx.dup(io_ctx);
     m_io_ctx.set_namespace("");
   }
index 6d246cdf33fef2d7335e60f6f37197d7b20218c7..827f551d1f79d5d9f4b1a2e5ee4492b5a08684dc 100644 (file)
@@ -1008,7 +1008,7 @@ void ObjectListSnapsRequest<I>::handle_list_from_parent(int r) {
   }
 
   // the write/read snapshot id key is not useful for parent images so
-  // map the the special-case INITIAL_WRITE_READ_SNAP_IDS key
+  // map the special-case INITIAL_WRITE_READ_SNAP_IDS key
   *m_snapshot_delta = {};
   auto& intervals = (*m_snapshot_delta)[INITIAL_WRITE_READ_SNAP_IDS];
   for (auto& [key, image_extents] : m_parent_snapshot_delta) {
index 5199f01d85d8f257cad62e86d9ce84103f856bdd..4af3f368311e0e87170297ede0341a31346856d3 100644 (file)
@@ -131,7 +131,7 @@ bool RefreshImageDispatch<I>::flush(
   ldout(cct, 20) << "tid=" << tid << dendl;
 
   // The refresh state machine can initiate a flush and it can
-  // enable the exclusive-lock which will also attmept to flush.
+  // enable the exclusive-lock which will also attempt to flush.
   if (flush_source == FLUSH_SOURCE_REFRESH ||
       flush_source == FLUSH_SOURCE_EXCLUSIVE_LOCK_SKIP_REFRESH ||
       flush_source == FLUSH_SOURCE_SHUTDOWN) {
index 54a2d02051eb61496a641ff05714b060b4e2c963..1272d95dd7e5c0f6dfffa7a62832ef0ad3bba6a2 100644 (file)
@@ -2401,7 +2401,7 @@ namespace librbd {
     return exists;
   }
 
-  // A safer verion of snap_exists.
+  // A safer version of snap_exists.
   int Image::snap_exists2(const char *snap_name, bool *exists)
   {
     ImageCtx *ictx = (ImageCtx *)ctx;
index 90d5723ed84cb1de25983a026fe9151ceb0cb036..2475ff00c368f65fc974c7c2c7b123fa5e84024f 100644 (file)
@@ -389,7 +389,7 @@ private:
     // receive the response for this request
     m_parser.emplace();
     if (work->header_only()) {
-      // HEAD requests don't trasfer data but the parser still cares about max
+      // HEAD requests don't transfer data but the parser still cares about max
       // content-length
       m_header_parser.emplace();
       m_header_parser->body_limit(std::numeric_limits<uint64_t>::max());
index cedf9aa20f02c7176735b7c1a67c28c60e3ab9ea..300bb712335eee28a4163230800a363d9e916139 100644 (file)
@@ -70,7 +70,7 @@ void LookupTable::decode() {
     return;
   }
 
-  // translate the lookup table (big-endian -> CPU endianess)
+  // translate the lookup table (big-endian -> CPU endianness)
   for (auto idx = 0UL; idx < size; ++idx) {
     cluster_offsets[idx] = big_to_native(cluster_offsets[idx]);
   }
index 719a033990918c966d206916c746cd421ad50bfb..dda1a161af73aaef102424a2b989e6baa3475090 100644 (file)
@@ -56,7 +56,7 @@ private:
    *    v
    * STATE_ACQUIRE_EXCLUSIVE_LOCK (skip if not
    *    |                          required)
-   *    | (disbling journaling)
+   *    | (disabling journaling)
    *    \-------------------\
    *    |                    |
    *    |                    V
@@ -92,8 +92,8 @@ private:
    * STATE_NOTIFY_UPDATE
    *    |
    *    v
-   * STATE_REALEASE_EXCLUSIVE_LOCK (skip if not
-   *    |                           required)
+   * STATE_RELEASE_EXCLUSIVE_LOCK (skip if not
+   *    |                          required)
    *    | (unblock writes)
    *    v
    * <finish>
index 17638a52917e7a4bbd979c33403bf0bb9b07d4d5..226015fde9434957fcd25b476347ae4d75704d69 100644 (file)
@@ -43,7 +43,7 @@ public:
    *    v (skip if disabled/in-use)
    * REMOVE_OBJECT_MAP
    *    |
-   *    v (skip if not mirror snpashot)
+   *    v (skip if not mirror snapshot)
    * REMOVE_IMAGE_STATE
    *    |
    *    v (skip if in-use)
index f2d22b4a16cba1a4356cc35faea08866ecb1aa50..61b96366c52727cfc6eec008e4e1f4073c04b0ef 100644 (file)
@@ -480,7 +480,7 @@ cdef class Completion(object):
 
     def get_return_value(self):
         """
-        Get the return value of an asychronous operation
+        Get the return value of an asynchronous operation
 
         The return value is set when the operation is complete.
 
@@ -2127,7 +2127,7 @@ class RBD(object):
         :param name: the name of the image
         :type name: str
         :param snapshot: which snapshot to read from
-        :type snaphshot: str
+        :type snapshot: str
         :param read_only: whether to open the image in read-only mode
         :type read_only: bool
         :param image_id: the id of the image
@@ -2809,7 +2809,7 @@ cdef class Image(object):
         :param name: the name of the image
         :type name: str
         :param snapshot: which snapshot to read from
-        :type snaphshot: str
+        :type snapshot: str
         :param read_only: whether to open the image in read-only mode
         :type read_only: bool
         :param image_id: the id of the image
index 63d2d0a30d6c7348ddc251ddd404f3fccf896cc6..33e72912dd21f1cde88e60c60684312593de7747 100644 (file)
@@ -955,7 +955,7 @@ TYPED_TEST(TestJournalPlayer, LiveReplayRefetchRemoveEmpty) {
   ASSERT_EQ(expected_entries, entries);
 }
 
-TYPED_TEST(TestJournalPlayer, PrefechShutDown) {
+TYPED_TEST(TestJournalPlayer, PrefetchShutDown) {
   std::string oid = this->get_temp_oid();
 
   ASSERT_EQ(0, this->create(oid));
index 05e56f52066eb05657ccce03a694702547e9892e..747ed8a7ff764988d2c9e850effa546e4c14aa71 100644 (file)
@@ -274,7 +274,7 @@ TEST_F(TestMockParentCacheObjectDispatch, test_initialization_fail_at_register)
   delete mock_parent_image_cache;
 }
 
-TEST_F(TestMockParentCacheObjectDispatch, test_disble_interface) {
+TEST_F(TestMockParentCacheObjectDispatch, test_disable_interface) {
   librbd::ImageCtx* ictx;
   ASSERT_EQ(0, open_image(m_image_name, &ictx));
   MockParentImageCacheImageCtx mock_image_ctx(*ictx);
index ba59e3cdb7c5961d860f2330cc84d00a7727157e..c5759179e5e64a31af1f57c310fffea12c6d3d7b 100644 (file)
@@ -55,7 +55,7 @@ struct GetMetadataRequest<MockTestImageCtx> {
 
 GetMetadataRequest<MockTestImageCtx>* GetMetadataRequest<MockTestImageCtx>::s_instance = nullptr;
 
-} // namspace image
+} // namespace image
 } // namespace librbd
 
 // template definitions
index b8be4708e2d01c9b1c8f9dfb46770c4a11c6ade4..13f052248b37eeca27c036af4031c84d83ec102d 100644 (file)
@@ -1,7 +1,7 @@
 // -*- mode:C++; tab-width:8; c-basic-offset:8; indent-tabs-mode:t -*-
 // vim: ts=8 sw=8 smarttab
 /*
- *     Copyright (C) 1991, NeXT Computer, Inc.  All Rights Reserverd.
+ *     Copyright (C) 1991, NeXT Computer, Inc.  All Rights Reserved.
  *
  *     File:   fsx.cc
  *     Author: Avadis Tevanian, Jr.
@@ -103,7 +103,7 @@ int                 logcount = 0;   /* total ops */
  * When mapped read/writes are disabled, they are simply converted to normal
  * reads and writes. When fallocate/fpunch calls are disabled, they are
  * converted to OP_SKIPPED. Hence OP_SKIPPED needs to have a number higher than
- * the operation selction matrix, as does the OP_CLOSEOPEN which is an
+ * the operation selection matrix, as does the OP_CLOSEOPEN which is an
  * operation modifier rather than an operation in itself.
  *
  * Because of the "lite" version, we also need to have different "maximum
@@ -159,7 +159,7 @@ unsigned long       debugstart = 0;         /* -D flag */
 int    flush_enabled = 0;              /* -f flag */
 int    deep_copy = 0;                  /* -g flag */
 int    holebdy = 1;                    /* -h flag */
-bool    journal_replay = false;         /* -j flah */
+bool    journal_replay = false;         /* -j flag */
 int    keep_on_success = 0;            /* -k flag */
 int    do_fsync = 0;                   /* -y flag */
 unsigned long  maxfilelen = 256 * 1024;        /* -l flag */
index 8c7eb2ba4ca8b6df78ffa81bafb24ecc26bdda62..1cc79e601bdaa419f511d5363531404f97993c5a 100644 (file)
@@ -12476,7 +12476,7 @@ TEST_F(TestLibRBD, WriteZeroesThickProvision) {
   ASSERT_EQ(0, image.close());
 }
 
-TEST_F(TestLibRBD, ConcurentOperations)
+TEST_F(TestLibRBD, ConcurrentOperations)
 {
   REQUIRE_FEATURE(RBD_FEATURE_EXCLUSIVE_LOCK);
 
index c85eab43455f26146e04046aa24f6dba7f7efe6f..04bb5745b3c01b48db49f639041057d92a2a100d 100644 (file)
@@ -21,6 +21,6 @@ struct MockBaseRequest : public BaseRequest {
 };
 
 } // namespace mirror
-} // namepace rbd
+} // namespace rbd
 
 #endif // CEPH_MOCK_BASE_REQUEST_H
index f57654b367659822d31c2448ef00d3167c466a62..1467caa5dda01efea52796bb66feb01b20e38fa6 100644 (file)
@@ -362,7 +362,7 @@ TEST_F(TestMockInstanceWatcher, ImageAcquireRelease) {
   expect_acquire_lock(mock_managed_lock, 0);
   ASSERT_EQ(0, instance_watcher2->init());
 
-  // Acquire Image on the the same instance
+  // Acquire Image on the same instance
   EXPECT_CALL(mock_instance_replayer1, acquire_image(instance_watcher1, "gid",
                                                      _))
       .WillOnce(WithArg<2>(CompleteContext(0)));
@@ -378,7 +378,7 @@ TEST_F(TestMockInstanceWatcher, ImageAcquireRelease) {
   instance_watcher1->notify_image_acquire(instance_id2, "gid", &on_acquire2);
   ASSERT_EQ(0, on_acquire2.wait());
 
-  // Release Image on the the same instance
+  // Release Image on the same instance
   EXPECT_CALL(mock_instance_replayer1, release_image("gid", _))
       .WillOnce(WithArg<1>(CompleteContext(0)));
   C_SaferCond on_release1;
index b714c3babadec338b876aff722aac670d7080494..5c58ea8ef7efc22f28f2153167378cedeefb55da 100644 (file)
@@ -1724,7 +1724,7 @@ Shell::Action action_bootstrap_create(
   {"mirror", "pool", "peer", "bootstrap", "create"}, {},
   "Create a peer bootstrap token to import in a remote cluster", "",
   &get_peer_bootstrap_create_arguments, &execute_peer_bootstrap_create);
-Shell::Action action_bootstreap_import(
+Shell::Action action_bootstrap_import(
   {"mirror", "pool", "peer", "bootstrap", "import"}, {},
   "Import a peer bootstrap token created from a remote cluster", "",
   &get_peer_bootstrap_import_arguments, &execute_peer_bootstrap_import);
index b39beac9148e4b3ada134dc42022933c493332fb..788162c66264af077351d7969e05075849c60b97 100644 (file)
@@ -604,7 +604,7 @@ int execute_iostat(const po::variables_map &vm,
 
   auto f = formatter.get();
   if (iterations > 1 && f != nullptr) {
-    std::cerr << "rbd: specifing iterations is not valid with formatted output"
+    std::cerr << "rbd: specifying iterations is not valid with formatted output"
               << std::endl;
     return -EINVAL;
   }
index 8a04219da06861487371000cc0dff01c31495dbe..71c58ad8ee046ac4c221f167be8808bee9a78b3d 100644 (file)
@@ -705,7 +705,7 @@ void PoolReplayer<I>::update_namespace_replayers() {
     for (auto &name : mirroring_namespaces) {
       auto it = m_namespace_replayers.find(name);
       if (it == m_namespace_replayers.end()) {
-        // acuire leader for this namespace replayer failed
+        // acquire leader for this namespace replayer failed
         continue;
       }
       it->second->handle_instances_added(instance_ids);
index 8bfb35d4af1efeb1fd2e40235ca6fec0353a434e..b9b88010d5dbc58ce0271956e8a0a5d12c92a183 100644 (file)
@@ -138,14 +138,14 @@ void RemotePoolPoller<I>::handle_mirror_peer_ping(int r) {
   dout(10) << "r=" << r << dendl;
 
   if (r == -EOPNOTSUPP) {
-    // older OSD that doesn't support snaphot-based mirroring, so no need
+    // older OSD that doesn't support snapshot-based mirroring, so no need
     // to query remote peers
     dout(10) << "remote peer does not support snapshot-based mirroring"
              << dendl;
     notify_listener();
     return;
   } else if (r < 0) {
-    // we can still see if we can perform a peer list and find outselves
+    // we can still see if we can perform a peer list and find ourselves
     derr << "failed to ping remote mirror peer: " << cpp_strerror(r) << dendl;
   }
 
index 20560038ca7d9e504e162b8541e06a07a4faf248..432e8d99698b0e4d056c6fa6932dc460e6346029 100644 (file)
@@ -540,7 +540,7 @@ void Replayer<I>::handle_close_local_image(int r) {
 
   std::unique_lock locker{m_lock};
   if (r < 0) {
-    derr << "error closing local iamge: " << cpp_strerror(r) << dendl;
+    derr << "error closing local image: " << cpp_strerror(r) << dendl;
     handle_replay_error(r, "failed to close local image");
   }
 
index d289c11caac2a2f27a8fff5755bf050a4011bdea..c0774494a747133499131f9b3e4f11f089695107 100644 (file)
@@ -10,11 +10,11 @@ and rbd images can not be accessed. In this case, a tool to recover rbd image is
   ceph rbd recover tool is just used for this, it can collect all objects of an image from distributed
 osd nodes with the latest pg epoch, and splice objects by offset to a complete image. To make sure
 object data is complete, this tool does flush osd journal on each osd node before recovering.
-  but, there are some limitions:
+  but, there are some limitations:
 -need ssh service and unobstructed network 
 -osd data must be accessed on local disk
 -clone image is not supported, while snapshot is supported
--only support relicated pool
+-only support replicated pool
 
 before you run this tool, you should make sure that:
 1). all processes (ceph-osd, ceph-mon, ceph-mds) are shutdown
@@ -64,7 +64,7 @@ osd_host: all osd node hostname #generated by admin_job, user ignore it
 
 
 -usage:
-rbd-recovert-tool <operation>
+rbd-recover-tool <operation>
 <operation> :
 database               #generating offline database: hobject path, node hostname, pg_epoch and image metadata
 list                   #list all images from offline database
index f2df662ad692b7515c97e4ead67958a59afa68d3..d2a7a8522079e3e7df5b6b0734da6deaa49dcf5e 100644 (file)
@@ -191,7 +191,7 @@ function init_env_admin()
       exit
     fi
     lines=$(($lines + 1))
-    # in case : there are servral hostnames on the same node
+    # in case : there are several hostnames on the same node
     # just need output of `hostname`
     local hostname_alias=
     hostname_alias=`ssh $ssh_option $node "hostname" 2>/dev/null </dev/null`
index b7a258650e5f27e32bd366964b7582c4dfb3cdb6..50849a462674691b1e355ab71d71d45b2073cb8c 100755 (executable)
@@ -18,7 +18,7 @@
 
 # rbd-recover-tool is an offline recover tool for rbd image in replicated pool
 # when ceph cluster is stopped.
-# it is a simple disater recovery policy, just for urgent condition
+# it is a simple disaster recovery policy, just for urgent condition
 
 my_dir=$(dirname "$0")
 
@@ -185,7 +185,7 @@ function usage()
   echo "$cmd_name database
                        gather pg info, object info, image metadata, 
                        and epoch info from all osd nodes,
-                       this will cosume a long time, just be patient, 
+                       this will consume a long time, just be patient, 
                        especially when scale up to 1000+ osds"
   echo "$cmd_name list
                        list all rbd images of all replicated pools, 
@@ -193,7 +193,7 @@ function usage()
   echo "$cmd_name lookup  <pool_id>/<image_name>[@[<snap_name>]]
                        show image metadata: image format, rbd id, size, order, snapseq
                        In addition, for image with snapshots, 
-                       this will list all snapshot infomations"
+                       this will list all snapshot information"
   echo "$cmd_name recover <pool_id>/<image_name>[@[<snap_name>]] [</path/to/store/image>]
                        all snapshots share one image head, to economize disk space
                        so there is only one snapshot at any time,
index 2e8f3ee0434bcc2bde0a203d6d033bedddb08b33..fd78841e0567f0b81c871957bfe821d625f1e8f5 100644 (file)
@@ -419,7 +419,7 @@ int map_device_using_suprocess(std::string arguments, int timeout_ms)
     case WAIT_OBJECT_0:
       if (!GetOverlappedResult(pipe_handle, &connect_o, &bytes_read, TRUE)) {
         err = GetLastError();
-        derr << "Couln't establish a connection with the child process. "
+        derr << "Couldn't establish a connection with the child process. "
              << "Error: " << win32_strerror(err) << dendl;
         exit_code = -ECHILD;
         goto clean_process;
@@ -1086,13 +1086,13 @@ Unmap options:
   --soft-disconnect-timeout   Soft disconnect timeout in seconds. The soft
                               disconnect operation uses PnP to notify the
                               Windows storage stack that the device is going to
-                              be disconnectd. Storage drivers can block this
+                              be disconnected. Storage drivers can block this
                               operation if there are pending operations,
                               unflushed caches or open handles. Default: 15
 
 Service options:
   --hard-disconnect             Skip attempting a soft disconnect
-  --soft-disconnect-timeout     Cummulative soft disconnect timeout in seconds,
+  --soft-disconnect-timeout     Cumulative soft disconnect timeout in seconds,
                                 used when disconnecting existing mappings. A hard
                                 disconnect will be issued when hitting the timeout
   --service-thread-count        The number of workers used when mapping or