You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kudu.apache.org by al...@apache.org on 2021/03/08 06:56:04 UTC

[kudu] branch master updated: [txn_status_manager] remove test-only crutch

This is an automated email from the ASF dual-hosted git repository.

alexey pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/kudu.git


The following commit(s) were added to refs/heads/master by this push:
     new 4897758  [txn_status_manager] remove test-only crutch
4897758 is described below

commit 4897758e83764086939ad575a42dc1b403bd49e8
Author: Alexey Serbin <al...@apache.org>
AuthorDate: Sun Mar 7 22:06:41 2021 -0800

    [txn_status_manager] remove test-only crutch
    
    This patch removes --txn_status_manager_finalize_commit_on_begin
    test-only flag since the orchestration of multi-row transaction commit
    is now implemented with b9a8f2e63.
    
    Change-Id: I00e39c987802d13efb4032b7aa7aaf28ec291f9d
    Reviewed-on: http://gerrit.cloudera.org:8080/17157
    Reviewed-by: Andrew Wong <aw...@cloudera.com>
    Tested-by: Kudu Jenkins
---
 src/kudu/transactions/txn_status_manager.cc | 16 ----------------
 1 file changed, 16 deletions(-)

diff --git a/src/kudu/transactions/txn_status_manager.cc b/src/kudu/transactions/txn_status_manager.cc
index e6ec4da..8981c5a 100644
--- a/src/kudu/transactions/txn_status_manager.cc
+++ b/src/kudu/transactions/txn_status_manager.cc
@@ -91,16 +91,6 @@ DEFINE_uint32(txn_staleness_tracker_interval_ms, 10000,
 TAG_FLAG(txn_staleness_tracker_interval_ms, experimental);
 TAG_FLAG(txn_staleness_tracker_interval_ms, runtime);
 
-// TODO(aserbin): remove this test-only crutch once the orchestration of
-//                the two phase commit is implemented
-DEFINE_bool(txn_status_manager_finalize_commit_on_begin, false,
-            "Finalize committing a transaction automatically right after "
-            "changing its state to COMMIT_IN_PROGRESS during processing "
-            "a call to CoordinateTransaction() of the BEGIN_COMMIT_TXN type. "
-            "Used only for tests.");
-TAG_FLAG(txn_status_manager_finalize_commit_on_begin, hidden);
-TAG_FLAG(txn_status_manager_finalize_commit_on_begin, unsafe);
-
 DEFINE_int32(txn_status_tablet_failover_catchup_timeout_ms, 30 * 1000, // 30 sec
              "Amount of time to give a newly-elected leader tserver of transaction "
              "status tablet to load the metadata containing all operations replicated "
@@ -949,12 +939,6 @@ Status TxnStatusManager::BeginCommitTransaction(int64_t txn_id, const string& us
   }
   txn_lock.Commit();
 
-  // TODO(aserbin): remove this test-only crutch once the orchestration of
-  //                the two phase commit is implemented
-  if (PREDICT_FALSE(FLAGS_txn_status_manager_finalize_commit_on_begin)) {
-    RETURN_NOT_OK(FinalizeCommitTransaction(txn_id, Timestamp::kInitialTimestamp, ts_error));
-  }
-
   return Status::OK();
 }