You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kudu.apache.org by ad...@apache.org on 2017/06/14 00:17:55 UTC

[2/3] kudu git commit: tidy: fix misc-move-const-args

tidy: fix misc-move-const-args

Change-Id: I3b78afde183061112d69e422ca81b88c3fa2492d
Reviewed-on: http://gerrit.cloudera.org:8080/7133
Tested-by: Kudu Jenkins
Reviewed-by: Adar Dembo <ad...@cloudera.com>


Project: http://git-wip-us.apache.org/repos/asf/kudu/repo
Commit: http://git-wip-us.apache.org/repos/asf/kudu/commit/01deeab4
Tree: http://git-wip-us.apache.org/repos/asf/kudu/tree/01deeab4
Diff: http://git-wip-us.apache.org/repos/asf/kudu/diff/01deeab4

Branch: refs/heads/master
Commit: 01deeab47be415fd09e089d4ba833585b8d07f14
Parents: 312492d
Author: Todd Lipcon <to...@cloudera.com>
Authored: Mon Jun 12 19:05:59 2017 -0700
Committer: Todd Lipcon <to...@apache.org>
Committed: Tue Jun 13 22:54:25 2017 +0000

----------------------------------------------------------------------
 src/kudu/cfile/binary_dict_block.cc                   |  2 +-
 src/kudu/cfile/binary_plain_block.cc                  |  2 +-
 src/kudu/cfile/binary_prefix_block.cc                 |  2 +-
 src/kudu/cfile/block_handle.h                         |  2 +-
 src/kudu/cfile/bshuf_block.h                          |  2 +-
 src/kudu/cfile/plain_bitmap_block.h                   |  2 +-
 src/kudu/cfile/plain_block.h                          |  2 +-
 src/kudu/cfile/rle_block.h                            |  4 ++--
 src/kudu/client/meta_cache.cc                         | 10 +++++-----
 src/kudu/common/columnblock.h                         |  2 +-
 src/kudu/common/generic_iterators.cc                  |  4 ++--
 src/kudu/common/partition.cc                          |  2 +-
 src/kudu/common/partition_pruner-test.cc              |  2 +-
 src/kudu/common/row_changelist.h                      |  2 +-
 src/kudu/common/schema.h                              |  2 +-
 src/kudu/fs/file_block_manager.cc                     |  2 +-
 src/kudu/integration-tests/linked_list-test-util.h    |  2 +-
 src/kudu/integration-tests/tablet_history_gc-itest.cc |  6 +++---
 src/kudu/master/catalog_manager.cc                    |  4 ++--
 src/kudu/rpc/acceptor_pool.cc                         |  2 +-
 src/kudu/rpc/messenger.h                              |  2 +-
 src/kudu/tablet/concurrent_btree.h                    |  2 +-
 src/kudu/tablet/delta_key.h                           |  2 +-
 src/kudu/tablet/diskrowset.cc                         |  4 ++--
 src/kudu/tablet/rowset.h                              |  2 +-
 src/kudu/tablet/rowset_tree.h                         |  2 +-
 src/kudu/tools/ksck-test.cc                           |  2 +-
 src/kudu/tools/ksck.cc                                |  2 +-
 src/kudu/tools/ksck_remote.cc                         |  2 +-
 src/kudu/tserver/heartbeater.cc                       |  2 +-
 src/kudu/util/failure_detector.cc                     |  2 +-
 src/kudu/util/metrics.cc                              |  2 +-
 src/kudu/util/pstack_watcher.cc                       |  2 +-
 src/kudu/util/resettable_heartbeater.cc               |  2 +-
 34 files changed, 44 insertions(+), 44 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/cfile/binary_dict_block.cc
----------------------------------------------------------------------
diff --git a/src/kudu/cfile/binary_dict_block.cc b/src/kudu/cfile/binary_dict_block.cc
index 247a74b..6189aec 100644
--- a/src/kudu/cfile/binary_dict_block.cc
+++ b/src/kudu/cfile/binary_dict_block.cc
@@ -191,7 +191,7 @@ Status BinaryDictBlockBuilder::GetLastKey(void* key_void) const {
 ////////////////////////////////////////////////////////////
 
 BinaryDictBlockDecoder::BinaryDictBlockDecoder(Slice slice, CFileIterator* iter)
-    : data_(std::move(slice)),
+    : data_(slice),
       parsed_(false),
       dict_decoder_(iter->GetDictDecoder()),
       parent_cfile_iter_(iter) {

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/cfile/binary_plain_block.cc
----------------------------------------------------------------------
diff --git a/src/kudu/cfile/binary_plain_block.cc b/src/kudu/cfile/binary_plain_block.cc
index 430edcb..e13a952 100644
--- a/src/kudu/cfile/binary_plain_block.cc
+++ b/src/kudu/cfile/binary_plain_block.cc
@@ -150,7 +150,7 @@ Status BinaryPlainBlockBuilder::GetLastKey(void *key_void) const {
 ////////////////////////////////////////////////////////////
 
 BinaryPlainBlockDecoder::BinaryPlainBlockDecoder(Slice slice)
-    : data_(std::move(slice)),
+    : data_(slice),
       parsed_(false),
       num_elems_(0),
       ordinal_pos_base_(0),

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/cfile/binary_prefix_block.cc
----------------------------------------------------------------------
diff --git a/src/kudu/cfile/binary_prefix_block.cc b/src/kudu/cfile/binary_prefix_block.cc
index cc6eab7..c045895 100644
--- a/src/kudu/cfile/binary_prefix_block.cc
+++ b/src/kudu/cfile/binary_prefix_block.cc
@@ -208,7 +208,7 @@ Status BinaryPrefixBlockBuilder::GetLastKey(void *key) const {
 ////////////////////////////////////////////////////////////
 
 BinaryPrefixBlockDecoder::BinaryPrefixBlockDecoder(Slice slice)
-    : data_(std::move(slice)),
+    : data_(slice),
       parsed_(false),
       num_elems_(0),
       ordinal_pos_base_(0),

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/cfile/block_handle.h
----------------------------------------------------------------------
diff --git a/src/kudu/cfile/block_handle.h b/src/kudu/cfile/block_handle.h
index 2a668e5..3a5dbf1 100644
--- a/src/kudu/cfile/block_handle.h
+++ b/src/kudu/cfile/block_handle.h
@@ -69,7 +69,7 @@ class BlockHandle {
   bool is_data_owner_;
 
   explicit BlockHandle(Slice data)
-      : data_(std::move(data)),
+      : data_(data),
         is_data_owner_(true) {
   }
 

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/cfile/bshuf_block.h
----------------------------------------------------------------------
diff --git a/src/kudu/cfile/bshuf_block.h b/src/kudu/cfile/bshuf_block.h
index 7ec0bae..5efa62d 100644
--- a/src/kudu/cfile/bshuf_block.h
+++ b/src/kudu/cfile/bshuf_block.h
@@ -218,7 +218,7 @@ template<DataType Type>
 class BShufBlockDecoder final : public BlockDecoder {
  public:
   explicit BShufBlockDecoder(Slice slice)
-      : data_(std::move(slice)),
+      : data_(slice),
         parsed_(false),
         ordinal_pos_base_(0),
         num_elems_(0),

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/cfile/plain_bitmap_block.h
----------------------------------------------------------------------
diff --git a/src/kudu/cfile/plain_bitmap_block.h b/src/kudu/cfile/plain_bitmap_block.h
index 5414344..0691a18 100644
--- a/src/kudu/cfile/plain_bitmap_block.h
+++ b/src/kudu/cfile/plain_bitmap_block.h
@@ -109,7 +109,7 @@ class PlainBitMapBlockBuilder final : public BlockBuilder {
 class PlainBitMapBlockDecoder final : public BlockDecoder {
  public:
   explicit PlainBitMapBlockDecoder(Slice slice)
-      : data_(std::move(slice)),
+      : data_(slice),
         parsed_(false),
         num_elems_(0),
         ordinal_pos_base_(0),

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/cfile/plain_block.h
----------------------------------------------------------------------
diff --git a/src/kudu/cfile/plain_block.h b/src/kudu/cfile/plain_block.h
index 4f9bcd6..9fcca2f 100644
--- a/src/kudu/cfile/plain_block.h
+++ b/src/kudu/cfile/plain_block.h
@@ -112,7 +112,7 @@ template<DataType Type>
 class PlainBlockDecoder final : public BlockDecoder {
  public:
   explicit PlainBlockDecoder(Slice slice)
-      : data_(std::move(slice)),
+      : data_(slice),
         parsed_(false),
         num_elems_(0),
         ordinal_pos_base_(0),

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/cfile/rle_block.h
----------------------------------------------------------------------
diff --git a/src/kudu/cfile/rle_block.h b/src/kudu/cfile/rle_block.h
index c8ed76b..6918a2c 100644
--- a/src/kudu/cfile/rle_block.h
+++ b/src/kudu/cfile/rle_block.h
@@ -110,7 +110,7 @@ class RleBitMapBlockBuilder final : public BlockBuilder {
 class RleBitMapBlockDecoder final : public BlockDecoder {
  public:
   explicit RleBitMapBlockDecoder(Slice slice)
-      : data_(std::move(slice)),
+      : data_(slice),
         parsed_(false),
         num_elems_(0),
         ordinal_pos_base_(0),
@@ -299,7 +299,7 @@ template <DataType IntType>
 class RleIntBlockDecoder final : public BlockDecoder {
  public:
   explicit RleIntBlockDecoder(Slice slice)
-      : data_(std::move(slice)),
+      : data_(slice),
         parsed_(false),
         num_elems_(0),
         ordinal_pos_base_(0),

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/client/meta_cache.cc
----------------------------------------------------------------------
diff --git a/src/kudu/client/meta_cache.cc b/src/kudu/client/meta_cache.cc
index de9698e..f7a11cd 100644
--- a/src/kudu/client/meta_cache.cc
+++ b/src/kudu/client/meta_cache.cc
@@ -814,7 +814,7 @@ Status MetaCache::ProcessLookupResponse(const LookupRpc& rpc,
     tablets_by_key.clear();
     MetaCacheEntry entry(expiration_time, "", "");
     VLOG(3) << "Caching '" << rpc.table_name() << "' entry " << entry.DebugString(rpc.table());
-    InsertOrDie(&tablets_by_key, "", std::move(entry));
+    InsertOrDie(&tablets_by_key, "", entry);
   } else {
 
     // The comments below will reference the following diagram:
@@ -841,7 +841,7 @@ Status MetaCache::ProcessLookupResponse(const LookupRpc& rpc,
       tablets_by_key.erase(tablets_by_key.begin(), tablets_by_key.lower_bound(first_lower_bound));
       MetaCacheEntry entry(expiration_time, "", first_lower_bound);
       VLOG(3) << "Caching '" << rpc.table_name() << "' entry " << entry.DebugString(rpc.table());
-      InsertOrDie(&tablets_by_key, "", std::move(entry));
+      InsertOrDie(&tablets_by_key, "", entry);
     }
 
     // last_upper_bound tracks the upper bound of the previously processed
@@ -861,7 +861,7 @@ Status MetaCache::ProcessLookupResponse(const LookupRpc& rpc,
 
         MetaCacheEntry entry(expiration_time, last_upper_bound, tablet_lower_bound);
         VLOG(3) << "Caching '" << rpc.table_name() << "' entry " << entry.DebugString(rpc.table());
-        InsertOrDie(&tablets_by_key, last_upper_bound, std::move(entry));
+        InsertOrDie(&tablets_by_key, last_upper_bound, entry);
       }
       last_upper_bound = tablet_upper_bound;
 
@@ -907,7 +907,7 @@ Status MetaCache::ProcessLookupResponse(const LookupRpc& rpc,
       VLOG(3) << "Caching '" << rpc.table_name() << "' entry " << entry.DebugString(rpc.table());
 
       InsertOrDie(&tablets_by_id_, tablet_id, remote);
-      InsertOrDie(&tablets_by_key, tablet_lower_bound, std::move(entry));
+      InsertOrDie(&tablets_by_key, tablet_lower_bound, entry);
     }
 
     if (!last_upper_bound.empty() && tablet_locations.size() < kMaxReturnedTableLocations) {
@@ -920,7 +920,7 @@ Status MetaCache::ProcessLookupResponse(const LookupRpc& rpc,
 
       MetaCacheEntry entry(expiration_time, last_upper_bound, "");
       VLOG(3) << "Caching '" << rpc.table_name() << "' entry " << entry.DebugString(rpc.table());
-      InsertOrDie(&tablets_by_key, last_upper_bound, std::move(entry));
+      InsertOrDie(&tablets_by_key, last_upper_bound, entry);
     }
   }
 

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/common/columnblock.h
----------------------------------------------------------------------
diff --git a/src/kudu/common/columnblock.h b/src/kudu/common/columnblock.h
index 6fae578..071e4eb 100644
--- a/src/kudu/common/columnblock.h
+++ b/src/kudu/common/columnblock.h
@@ -127,7 +127,7 @@ class ColumnBlock {
 class ColumnBlockCell {
  public:
   ColumnBlockCell(ColumnBlock block, size_t row_idx)
-      : block_(std::move(block)), row_idx_(row_idx) {}
+      : block_(block), row_idx_(row_idx) {}
 
   const TypeInfo* typeinfo() const { return block_.type_info(); }
   size_t size() const { return block_.type_info()->size(); }

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/common/generic_iterators.cc
----------------------------------------------------------------------
diff --git a/src/kudu/common/generic_iterators.cc b/src/kudu/common/generic_iterators.cc
index b0d6b85..2634a77 100644
--- a/src/kudu/common/generic_iterators.cc
+++ b/src/kudu/common/generic_iterators.cc
@@ -460,7 +460,7 @@ Status MaterializingIterator::Init(ScanSpec *spec) {
         return Status::InvalidArgument("No such column", col_pred.first);
       }
       VLOG(1) << "Pushing down predicate " << pred.ToString();
-      col_idx_predicates_.emplace_back(col_idx, move(col_pred.second));
+      col_idx_predicates_.emplace_back(col_idx, col_pred.second);
     }
 
     for (int32_t col_idx = 0; col_idx < schema().num_columns(); col_idx++) {
@@ -587,7 +587,7 @@ Status PredicateEvaluatingIterator::Init(ScanSpec *spec) {
   col_idx_predicates_.clear();
   col_idx_predicates_.reserve(spec->predicates().size());
   for (auto& predicate : spec->predicates()) {
-    col_idx_predicates_.emplace_back(move(predicate.second));
+    col_idx_predicates_.emplace_back(predicate.second);
   }
   spec->RemovePredicates();
 

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/common/partition.cc
----------------------------------------------------------------------
diff --git a/src/kudu/common/partition.cc b/src/kudu/common/partition.cc
index 6d4b6f6..593d554 100644
--- a/src/kudu/common/partition.cc
+++ b/src/kudu/common/partition.cc
@@ -330,7 +330,7 @@ Status PartitionSchema::SplitRangeBounds(const Schema& schema,
       lower = std::move(*split);
     }
 
-    new_bounds.emplace_back(std::move(lower), std::move(upper));
+    new_bounds.emplace_back(std::move(lower), upper);
   }
 
   if (split != splits.end()) {

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/common/partition_pruner-test.cc
----------------------------------------------------------------------
diff --git a/src/kudu/common/partition_pruner-test.cc b/src/kudu/common/partition_pruner-test.cc
index 7e2dac1..6af578c 100644
--- a/src/kudu/common/partition_pruner-test.cc
+++ b/src/kudu/common/partition_pruner-test.cc
@@ -781,7 +781,7 @@ TEST_F(PartitionPrunerTest, TestPruning) {
   ASSERT_OK(split.SetUnixTimeMicros("time", 10));
 
   vector<Partition> partitions;
-  ASSERT_OK(partition_schema.CreatePartitions(vector<KuduPartialRow>{ move(split) },
+  ASSERT_OK(partition_schema.CreatePartitions(vector<KuduPartialRow>{ split },
                                               {}, schema, &partitions));
   ASSERT_EQ(4, partitions.size());
 

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/common/row_changelist.h
----------------------------------------------------------------------
diff --git a/src/kudu/common/row_changelist.h b/src/kudu/common/row_changelist.h
index 5c1987d..d6e2f3b 100644
--- a/src/kudu/common/row_changelist.h
+++ b/src/kudu/common/row_changelist.h
@@ -95,7 +95,7 @@ class RowChangeList {
     : encoded_data_(fs) {
   }
 
-  explicit RowChangeList(Slice s) : encoded_data_(std::move(s)) {}
+  explicit RowChangeList(Slice s) : encoded_data_(s) {}
 
   // Create a RowChangeList which represents a delete.
   // This points to static (const) memory and should not be

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/common/schema.h
----------------------------------------------------------------------
diff --git a/src/kudu/common/schema.h b/src/kudu/common/schema.h
index c94c4e9..a06581f 100644
--- a/src/kudu/common/schema.h
+++ b/src/kudu/common/schema.h
@@ -166,7 +166,7 @@ class ColumnSchema {
         type_info_(GetTypeInfo(type)),
         is_nullable_(is_nullable),
         read_default_(read_default ? new Variant(type, read_default) : NULL),
-        attributes_(std::move(attributes)) {
+        attributes_(attributes) {
     if (write_default == read_default) {
       write_default_ = read_default_;
     } else if (write_default != NULL) {

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/fs/file_block_manager.cc
----------------------------------------------------------------------
diff --git a/src/kudu/fs/file_block_manager.cc b/src/kudu/fs/file_block_manager.cc
index 80df53b..e7a14f2 100644
--- a/src/kudu/fs/file_block_manager.cc
+++ b/src/kudu/fs/file_block_manager.cc
@@ -266,7 +266,7 @@ FileWritableBlock::FileWritableBlock(FileBlockManager* block_manager,
                                      FileBlockLocation location,
                                      shared_ptr<WritableFile> writer)
     : block_manager_(block_manager),
-      location_(std::move(location)),
+      location_(location),
       writer_(std::move(writer)),
       state_(CLEAN),
       bytes_appended_(0) {

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/integration-tests/linked_list-test-util.h
----------------------------------------------------------------------
diff --git a/src/kudu/integration-tests/linked_list-test-util.h b/src/kudu/integration-tests/linked_list-test-util.h
index 0ce6de1..baf9ebf 100644
--- a/src/kudu/integration-tests/linked_list-test-util.h
+++ b/src/kudu/integration-tests/linked_list-test-util.h
@@ -304,7 +304,7 @@ class PeriodicWebUIChecker {
  public:
   PeriodicWebUIChecker(const ExternalMiniCluster& cluster,
                        const std::string& tablet_id, MonoDelta period)
-      : period_(std::move(period)), is_running_(true) {
+      : period_(period), is_running_(true) {
     // List of master and ts web pages to fetch
     vector<std::string> master_pages, ts_pages;
 

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/integration-tests/tablet_history_gc-itest.cc
----------------------------------------------------------------------
diff --git a/src/kudu/integration-tests/tablet_history_gc-itest.cc b/src/kudu/integration-tests/tablet_history_gc-itest.cc
index e307cd4..b17de97 100644
--- a/src/kudu/integration-tests/tablet_history_gc-itest.cc
+++ b/src/kudu/integration-tests/tablet_history_gc-itest.cc
@@ -308,10 +308,10 @@ class RandomizedTabletHistoryGcITest : public TabletHistoryGcITest {
                        int verify_round) {
     CHECK_GE(verify_round, cur_round_);
     if (verify_round == cur_round_) {
-      NO_FATALS(VerifySnapshotScan(std::move(scanner), std::move(snap_ts), verify_round));
+      NO_FATALS(VerifySnapshotScan(std::move(scanner), snap_ts, verify_round));
       return;
     }
-    ScannerTSPair pair(std::move(scanner), std::move(snap_ts));
+    ScannerTSPair pair(std::move(scanner), snap_ts);
     ScannerMap::value_type entry(verify_round, std::move(pair));
     scanners_.insert(std::move(entry));
   }
@@ -810,7 +810,7 @@ TEST_F(RandomizedTabletHistoryGcITest, TestRandomHistoryGCWorkload) {
         ASSERT_OK(scanner->SetSnapshotRaw(snapshot_ts.ToUint64()));
         ASSERT_OK(scanner->Open());
 
-        NO_FATALS(RegisterScanner(std::move(scanner), std::move(snapshot_ts), read_round));
+        NO_FATALS(RegisterScanner(std::move(scanner), snapshot_ts, read_round));
         break;
       }
       default: {

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/master/catalog_manager.cc
----------------------------------------------------------------------
diff --git a/src/kudu/master/catalog_manager.cc b/src/kudu/master/catalog_manager.cc
index 0065d88..de632f9 100644
--- a/src/kudu/master/catalog_manager.cc
+++ b/src/kudu/master/catalog_manager.cc
@@ -1494,7 +1494,7 @@ Status CatalogManager::CreateTable(const CreateTableRequestPB* orig_req,
     table_ids_map_[table->id()] = table;
     table_names_map_[req.name()] = table;
     for (const auto& tablet : tablet_refs) {
-      InsertOrDie(&tablet_map_, tablet->tablet_id(), std::move(tablet));
+      InsertOrDie(&tablet_map_, tablet->tablet_id(), tablet);
     }
   }
   TRACE("Inserted table and tablets into CatalogManager maps");
@@ -2150,7 +2150,7 @@ Status CatalogManager::AlterTable(const AlterTableRequestPB* req,
     // Insert new tablets into the global tablet map. After this, the tablets
     // will be visible in GetTabletLocations RPCs.
     for (const auto& tablet : tablets_to_add) {
-      InsertOrDie(&tablet_map_, tablet->tablet_id(), std::move(tablet));
+      InsertOrDie(&tablet_map_, tablet->tablet_id(), tablet);
     }
   }
 

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/rpc/acceptor_pool.cc
----------------------------------------------------------------------
diff --git a/src/kudu/rpc/acceptor_pool.cc b/src/kudu/rpc/acceptor_pool.cc
index f3c935c..640b884 100644
--- a/src/kudu/rpc/acceptor_pool.cc
+++ b/src/kudu/rpc/acceptor_pool.cc
@@ -63,7 +63,7 @@ AcceptorPool::AcceptorPool(Messenger* messenger, Socket* socket,
                            Sockaddr bind_address)
     : messenger_(messenger),
       socket_(socket->Release()),
-      bind_address_(std::move(bind_address)),
+      bind_address_(bind_address),
       rpc_connections_accepted_(METRIC_rpc_connections_accepted.Instantiate(
           messenger->metric_entity())),
       closing_(false) {}

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/rpc/messenger.h
----------------------------------------------------------------------
diff --git a/src/kudu/rpc/messenger.h b/src/kudu/rpc/messenger.h
index 1ba76a7..c60ddaa 100644
--- a/src/kudu/rpc/messenger.h
+++ b/src/kudu/rpc/messenger.h
@@ -64,7 +64,7 @@ class RpczStore;
 struct AcceptorPoolInfo {
  public:
   explicit AcceptorPoolInfo(Sockaddr bind_address)
-      : bind_address_(std::move(bind_address)) {}
+      : bind_address_(bind_address) {}
 
   Sockaddr bind_address() const {
     return bind_address_;

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/tablet/concurrent_btree.h
----------------------------------------------------------------------
diff --git a/src/kudu/tablet/concurrent_btree.h b/src/kudu/tablet/concurrent_btree.h
index ac7e536..1a2af12 100644
--- a/src/kudu/tablet/concurrent_btree.h
+++ b/src/kudu/tablet/concurrent_btree.h
@@ -836,7 +836,7 @@ class PreparedMutation {
   // The data referred to by the 'key' Slice passed in themust remain
   // valid for the lifetime of the PreparedMutation object.
   explicit PreparedMutation(Slice key)
-      : key_(std::move(key)), tree_(NULL), leaf_(NULL), needs_unlock_(false) {}
+      : key_(key), tree_(NULL), leaf_(NULL), needs_unlock_(false) {}
 
   ~PreparedMutation() {
     UnPrepare();

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/tablet/delta_key.h
----------------------------------------------------------------------
diff --git a/src/kudu/tablet/delta_key.h b/src/kudu/tablet/delta_key.h
index be5e946..7ad6b0a 100644
--- a/src/kudu/tablet/delta_key.h
+++ b/src/kudu/tablet/delta_key.h
@@ -53,7 +53,7 @@ class DeltaKey {
   {}
 
   DeltaKey(rowid_t id, Timestamp timestamp)
-      : row_idx_(id), timestamp_(std::move(timestamp)) {}
+      : row_idx_(id), timestamp_(timestamp) {}
 
   // Encode this key into the given buffer.
   //

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/tablet/diskrowset.cc
----------------------------------------------------------------------
diff --git a/src/kudu/tablet/diskrowset.cc b/src/kudu/tablet/diskrowset.cc
index ab8280e..db6daf6 100644
--- a/src/kudu/tablet/diskrowset.cc
+++ b/src/kudu/tablet/diskrowset.cc
@@ -81,7 +81,7 @@ DiskRowSetWriter::DiskRowSetWriter(RowSetMetadata* rowset_metadata,
                                    BloomFilterSizing bloom_sizing)
     : rowset_metadata_(rowset_metadata),
       schema_(schema),
-      bloom_sizing_(std::move(bloom_sizing)),
+      bloom_sizing_(bloom_sizing),
       finished_(false),
       written_count_(0) {
   CHECK(schema->has_column_ids());
@@ -293,7 +293,7 @@ RollingDiskRowSetWriter::RollingDiskRowSetWriter(
     : state_(kInitialized),
       tablet_metadata_(DCHECK_NOTNULL(tablet_metadata)),
       schema_(schema),
-      bloom_sizing_(std::move(bloom_sizing)),
+      bloom_sizing_(bloom_sizing),
       target_rowset_size_(target_rowset_size),
       row_idx_in_cur_drs_(0),
       can_roll_(false),

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/tablet/rowset.h
----------------------------------------------------------------------
diff --git a/src/kudu/tablet/rowset.h b/src/kudu/tablet/rowset.h
index f85d2c7..b5b7c4b 100644
--- a/src/kudu/tablet/rowset.h
+++ b/src/kudu/tablet/rowset.h
@@ -229,7 +229,7 @@ class RowSetKeyProbe {
   // NOTE: row_key is not copied and must be valid for the lifetime
   // of this object.
   explicit RowSetKeyProbe(ConstContiguousRow row_key)
-      : row_key_(std::move(row_key)) {
+      : row_key_(row_key) {
     encoded_key_ = EncodedKey::FromContiguousRow(row_key_);
     bloom_probe_ = BloomKeyProbe(encoded_key_slice());
   }

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/tablet/rowset_tree.h
----------------------------------------------------------------------
diff --git a/src/kudu/tablet/rowset_tree.h b/src/kudu/tablet/rowset_tree.h
index 3994d3f..eb98138 100644
--- a/src/kudu/tablet/rowset_tree.h
+++ b/src/kudu/tablet/rowset_tree.h
@@ -55,7 +55,7 @@ class RowSetTree {
   };
   struct RSEndpoint {
     RSEndpoint(RowSet *rowset, EndpointType endpoint, Slice slice)
-        : rowset_(rowset), endpoint_(endpoint), slice_(std::move(slice)) {}
+        : rowset_(rowset), endpoint_(endpoint), slice_(slice) {}
 
     RowSet* rowset_;
     enum EndpointType endpoint_;

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/tools/ksck-test.cc
----------------------------------------------------------------------
diff --git a/src/kudu/tools/ksck-test.cc b/src/kudu/tools/ksck-test.cc
index 90a8f1d..b6ed5b3 100644
--- a/src/kudu/tools/ksck-test.cc
+++ b/src/kudu/tools/ksck-test.cc
@@ -256,7 +256,7 @@ class KsckTest : public KuduTest {
     pb.set_tablet_id(tablet_id);
     pb.set_table_name("fake-table");
     pb.set_state(is_running ? tablet::RUNNING : tablet::FAILED);
-    InsertOrDie(&ts->tablet_status_map_, tablet_id, std::move(pb));
+    InsertOrDie(&ts->tablet_status_map_, tablet_id, pb);
   }
 
   Status RunKsck() {

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/tools/ksck.cc
----------------------------------------------------------------------
diff --git a/src/kudu/tools/ksck.cc b/src/kudu/tools/ksck.cc
index 7505b67..b4fa190 100644
--- a/src/kudu/tools/ksck.cc
+++ b/src/kudu/tools/ksck.cc
@@ -359,7 +359,7 @@ class TabletServerChecksumCallbacks : public ChecksumProgressCallbacks {
       reporter_(std::move(reporter)),
       tablet_server_(std::move(tablet_server)),
       queue_(std::move(queue)),
-      options_(std::move(options)),
+      options_(options),
       tablet_id_(std::move(tablet_id)) {
   }
 

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/tools/ksck_remote.cc
----------------------------------------------------------------------
diff --git a/src/kudu/tools/ksck_remote.cc b/src/kudu/tools/ksck_remote.cc
index 6b4d98f..1e0403a 100644
--- a/src/kudu/tools/ksck_remote.cc
+++ b/src/kudu/tools/ksck_remote.cc
@@ -158,7 +158,7 @@ class ChecksumStepper {
       : schema_(schema),
         tablet_id_(std::move(tablet_id)),
         server_uuid_(std::move(server_uuid)),
-        options_(std::move(options)),
+        options_(options),
         callbacks_(callbacks),
         proxy_(std::move(proxy)),
         call_seq_id_(0),

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/tserver/heartbeater.cc
----------------------------------------------------------------------
diff --git a/src/kudu/tserver/heartbeater.cc b/src/kudu/tserver/heartbeater.cc
index 3c0f56e..f5695d7 100644
--- a/src/kudu/tserver/heartbeater.cc
+++ b/src/kudu/tserver/heartbeater.cc
@@ -587,7 +587,7 @@ void Heartbeater::Thread::MarkTabletDirty(const string& tablet_id, const string&
     state->change_seq = seqno;
   } else {
     TabletReportState state = { seqno };
-    InsertOrDie(&dirty_tablets_, tablet_id, std::move(state));
+    InsertOrDie(&dirty_tablets_, tablet_id, state);
   }
 }
 

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/util/failure_detector.cc
----------------------------------------------------------------------
diff --git a/src/kudu/util/failure_detector.cc b/src/kudu/util/failure_detector.cc
index 510cbca..baa29ed 100644
--- a/src/kudu/util/failure_detector.cc
+++ b/src/kudu/util/failure_detector.cc
@@ -37,7 +37,7 @@ using strings::Substitute;
 const int64_t RandomizedFailureMonitor::kMinWakeUpTimeMillis = 10;
 
 TimedFailureDetector::TimedFailureDetector(MonoDelta failure_period)
-    : failure_period_(std::move(failure_period)) {}
+    : failure_period_(failure_period) {}
 
 TimedFailureDetector::~TimedFailureDetector() {
   STLDeleteValues(&nodes_);

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/util/metrics.cc
----------------------------------------------------------------------
diff --git a/src/kudu/util/metrics.cc b/src/kudu/util/metrics.cc
index 079bf89..df226d4 100644
--- a/src/kudu/util/metrics.cc
+++ b/src/kudu/util/metrics.cc
@@ -428,7 +428,7 @@ void MetricPrototypeRegistry::WriteAsJsonAndExit() const {
 //
 // MetricPrototype
 //
-MetricPrototype::MetricPrototype(CtorArgs args) : args_(std::move(args)) {
+MetricPrototype::MetricPrototype(CtorArgs args) : args_(args) {
   MetricPrototypeRegistry::get()->AddMetric(this);
 }
 

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/util/pstack_watcher.cc
----------------------------------------------------------------------
diff --git a/src/kudu/util/pstack_watcher.cc b/src/kudu/util/pstack_watcher.cc
index e4fbddf..1963f99 100644
--- a/src/kudu/util/pstack_watcher.cc
+++ b/src/kudu/util/pstack_watcher.cc
@@ -38,7 +38,7 @@ using std::vector;
 using strings::Substitute;
 
 PstackWatcher::PstackWatcher(MonoDelta timeout)
-    : timeout_(std::move(timeout)), running_(true), cond_(&lock_) {
+    : timeout_(timeout), running_(true), cond_(&lock_) {
   CHECK_OK(Thread::Create("pstack_watcher", "pstack_watcher",
                  boost::bind(&PstackWatcher::Run, this), &thread_));
 }

http://git-wip-us.apache.org/repos/asf/kudu/blob/01deeab4/src/kudu/util/resettable_heartbeater.cc
----------------------------------------------------------------------
diff --git a/src/kudu/util/resettable_heartbeater.cc b/src/kudu/util/resettable_heartbeater.cc
index 91c4587..848590c 100644
--- a/src/kudu/util/resettable_heartbeater.cc
+++ b/src/kudu/util/resettable_heartbeater.cc
@@ -90,7 +90,7 @@ ResettableHeartbeater::~ResettableHeartbeater() {
 ResettableHeartbeaterThread::ResettableHeartbeaterThread(
     std::string name, MonoDelta period, HeartbeatFunction function)
     : name_(std::move(name)),
-      period_(std::move(period)),
+      period_(period),
       function_(std::move(function)),
       run_latch_(0),
       shutdown_(false) {}