Skip to content

Commit

Permalink
[FEAT MERGE] log4100 branch
Browse files Browse the repository at this point in the history
Co-authored-by: tino247 <tino247@126.com>
Co-authored-by: BinChenn <binchenn.bc@gmail.com>
Co-authored-by: HaHaJeff <jeffzhouhhh@gmail.com>
  • Loading branch information
4 people authored and ob-robot committed Jan 28, 2023
1 parent a269ffe commit 50024b3
Show file tree
Hide file tree
Showing 772 changed files with 60,596 additions and 11,622 deletions.
3 changes: 2 additions & 1 deletion deps/oblib/src/common/ob_learner_list.h
Original file line number Diff line number Diff line change
Expand Up @@ -40,6 +40,7 @@ class BaseLearnerList
// dangerous
T &get_learner(const int64_t idx);
int get_server_by_index(const int64_t idx, common::ObAddr &server) const;
int get_member_by_index(const int64_t idx, common::ObMember &member) const;
int add_learner(const T &learner);
int remove_learner(const T &learner);
int remove_learner(const common::ObAddr &server);
Expand Down Expand Up @@ -69,4 +70,4 @@ typedef BaseLearnerList<OB_MAX_MEMBER_NUMBER + OB_MAX_GLOBAL_LEARNER_NUMBER, com
} // namespace common end
} // namespace oceanbase end
#include "ob_learner_list.ipp"
#endif
#endif
14 changes: 13 additions & 1 deletion deps/oblib/src/common/ob_learner_list.ipp
Original file line number Diff line number Diff line change
Expand Up @@ -215,6 +215,18 @@ int BaseLearnerList<MAX_SIZE, T>::get_server_by_index(const int64_t idx, common:
return ret;
}

template <int64_t MAX_SIZE, typename T>
int BaseLearnerList<MAX_SIZE, T>::get_member_by_index(const int64_t idx, common::ObMember &member) const
{
int ret = OB_SUCCESS;
T learner;
if (OB_FAIL(get_learner(idx, learner))) {
} else {
member = learner;
}
return ret;
}

template <int64_t MAX_SIZE, typename T>
BaseLearnerList<MAX_SIZE, T> &BaseLearnerList<MAX_SIZE, T>::operator=(const BaseLearnerList<MAX_SIZE, T> &learner_list)
{
Expand Down Expand Up @@ -309,4 +321,4 @@ int64_t BaseLearnerList<MAX_SIZE, T>::get_serialize_size() const
return size;
}
} // namespace common end
} // namespace oceanbase end
} // namespace oceanbase end
23 changes: 22 additions & 1 deletion deps/oblib/src/common/rowkey/ob_rowkey_info.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -50,7 +50,7 @@ DEFINE_DESERIALIZE(ObRowkeyColumn)
} else if (OB_FAIL(serialization::decode_vi64(
buf, data_len, tmp_pos, reinterpret_cast<int64_t *>(&column_id_)))) {
COMMON_LOG(WARN, "decode column_id error.", K_(column_id), K(ret));
} else if (OB_FAIL(type_.deserialize(buf, data_len, pos))) {
} else if (OB_FAIL(type_.deserialize(buf, data_len, tmp_pos))) {
COMMON_LOG(WARN, "decode type error.", K_(type), K(ret));
} else if (OB_FAIL(serialization::decode_vi32(
buf, data_len, tmp_pos, reinterpret_cast<int32_t *>(&order_)))) {
Expand All @@ -71,6 +71,27 @@ DEFINE_GET_SERIALIZE_SIZE(ObRowkeyColumn)
return len;
}

ObRowkeyColumn& ObRowkeyColumn::operator=(const ObRowkeyColumn &other)
{
this->length_ = other.length_;
this->column_id_ = other.column_id_;
this->type_ = other.type_;
this->order_ = other.order_;
this->fulltext_flag_ = other.fulltext_flag_;
this->spatial_flag_ = other.spatial_flag_;
return *this;
}

bool ObRowkeyColumn::operator==(const ObRowkeyColumn &other) const
{
return
this->length_ == other.length_ &&
this->column_id_ == other.column_id_ &&
this->type_ == other.type_ &&
this->order_ == other.order_ &&
this->fulltext_flag_ == other.fulltext_flag_ &&
this->spatial_flag_ == other.spatial_flag_;
}

ObRowkeyInfo::ObRowkeyInfo()
: columns_(NULL), size_(0), capacity_(0), arena_(ObModIds::OB_SCHEMA_ROW_KEY), allocator_(&arena_)
Expand Down
2 changes: 2 additions & 0 deletions deps/oblib/src/common/rowkey/ob_rowkey_info.h
Original file line number Diff line number Diff line change
Expand Up @@ -36,6 +36,8 @@ struct ObRowkeyColumn
return (ObURowIDType == type_.get_type() || length_ >= 0) && common::OB_INVALID_ID != column_id_
&& common::ob_is_valid_obj_type(static_cast<ObObjType>(type_.get_type()));
}
ObRowkeyColumn &operator=(const ObRowkeyColumn &other);
bool operator==(const ObRowkeyColumn &other) const;
const ObObjMeta get_meta_type() const { return type_; }
TO_STRING_KV(K_(length), K_(column_id), K_(type), K_(order), K_(fulltext_flag), K(spatial_flag_));

Expand Down
1 change: 1 addition & 0 deletions deps/oblib/src/lib/CMakeLists.txt
Original file line number Diff line number Diff line change
Expand Up @@ -88,6 +88,7 @@ ob_set_subtarget(oblib_lib common_mixed
encrypt/ob_encrypted_helper.cpp
file/file_directory_utils.cpp
file/ob_file.cpp
file/ob_string_util.cpp
hash/ob_concurrent_hash_map.cpp
hash/ob_hashutils.cpp
hash/xxhash.c
Expand Down
16 changes: 16 additions & 0 deletions deps/oblib/src/lib/ob_define.h
Original file line number Diff line number Diff line change
Expand Up @@ -109,6 +109,7 @@ const int64_t MAX_ZONE_STATUS_LENGTH = 16;
const int64_t MAX_REPLICA_STATUS_LENGTH = 64;
const int64_t MAX_REPLICA_TYPE_LENGTH = 16;
const int64_t MAX_DISASTER_RECOVERY_TASK_TYPE_LENGTH = 64;
const int64_t MAX_ARB_REPLICA_TASK_TYPE_LENGTH = 32;
const int64_t MAX_TENANT_STATUS_LENGTH = 64;
const int64_t MAX_RESOURCE_POOL_NAME_LEN = 128;
const int32_t MAX_REPLICA_COUNT_PER_ZONE = 5;
Expand All @@ -124,9 +125,11 @@ const int64_t MAX_PATH_SIZE = 1024;
const int64_t MAX_DISK_ALIAS_NAME = 128;
const int64_t MAX_DISKGROUP_NAME = 128;
const int64_t DEFAULT_BUF_LENGTH = 4096;
const int64_t MAX_SINGLE_MEMBER_LENGTH = (MAX_IP_PORT_LENGTH + 17 /* timestamp length*/ + 1);
const int64_t MAX_MEMBER_LIST_LENGTH = MAX_ZONE_NUM * (MAX_IP_PORT_LENGTH + 17 /* timestamp length*/ + 1);
const int64_t OB_MAX_MEMBER_NUMBER = 7;
const int64_t OB_MAX_GLOBAL_LEARNER_NUMBER = 2000;
const int64_t MAX_LEARNER_LIST_LENGTH = OB_MAX_GLOBAL_LEARNER_NUMBER * (MAX_IP_PORT_LENGTH + 17 /* timestamp length*/ + 1);
const int64_t OB_MAX_CHILD_MEMBER_NUMBER = 15;
const int64_t OB_MAX_CHILD_MEMBER_NUMBER_IN_FOLLOWER = 5;
const int64_t OB_DEFAULT_MEMBER_NUMBER = 3;
Expand Down Expand Up @@ -1320,6 +1323,8 @@ OB_INLINE bool is_inner_pl_object_id(const uint64_t object_id)
const char* const OB_PRIMARY_INDEX_NAME = "PRIMARY";

const int64_t OB_MAX_CONFIG_URL_LENGTH = 512;
const int64_t OB_MAX_ARBITRATION_SERVICE_NAME_LENGTH = 256;
const int64_t OB_MAX_ARBITRATION_SERVICE_LENGTH = 512;

const int64_t OB_MIGRATE_ACTION_LENGTH = 64;
const int64_t OB_MIGRATE_REPLICA_STATE_LENGTH = 64;
Expand Down Expand Up @@ -1895,6 +1900,9 @@ enum ObReplicaType
REPLICA_TYPE_READONLY = (ASYNC_CLOG | WITH_SSSTORE | WITH_MEMSTORE), // 16
// Incremental copy: not a member of paxos; no ssstore; memstore
REPLICA_TYPE_MEMONLY = (ASYNC_CLOG | WITHOUT_SSSTORE | WITH_MEMSTORE), // 20
// TODO by yunlong: is it proper to use ASYNC_CLOG
// Arbitration copy: a member of paxos; no ssstore; no memstore
REPLICA_TYPE_ARBITRATION = (ASYNC_CLOG | WITHOUT_SSSTORE | WITHOUT_MEMSTORE), // 21
// Encrypted log copy: encrypted; paxos member; no sstore; no memstore
REPLICA_TYPE_ENCRYPTION_LOGONLY = (WITH_ENCRYPTION | SYNC_CLOG | WITHOUT_SSSTORE | WITHOUT_MEMSTORE), // 261
// invalid value
Expand Down Expand Up @@ -2336,10 +2344,18 @@ OB_INLINE char *ob_get_tname()
return tname.v_;
}

// There are many clusters in arbitration server, we need a field identify the different clusters.
OB_INLINE int64_t &ob_get_cluster_id()
{
RLOCAL(int64_t, cluster_id);
return cluster_id;
}

#define GETTID() ob_gettid()
#define GETTNAME() ob_get_tname()
#define GET_TENANT_ID() ob_get_tenant_id()
#define gettid GETTID
#define GET_CLUSTER_ID() ob_get_cluster_id()

//for explain
#define LEFT_BRACKET "("
Expand Down
14 changes: 10 additions & 4 deletions deps/oblib/src/lib/oblog/ob_log.cpp
Original file line number Diff line number Diff line change
Expand Up @@ -460,7 +460,7 @@ ObLogger::ObLogger()
enable_wf_flag_(false), rec_old_file_flag_(false), can_print_(true),
enable_async_log_(true), use_multi_flush_(false), stop_append_log_(false), enable_perf_mode_(false),
last_async_flush_count_per_sec_(0), log_mem_limiter_(nullptr),
allocator_(nullptr), error_allocator_(nullptr), enable_log_limit_(true)
allocator_(nullptr), error_allocator_(nullptr), enable_log_limit_(true), is_arb_replica_(false)
{
id_level_map_.set_level(OB_LOG_LEVEL_ERROR);

Expand Down Expand Up @@ -649,12 +649,16 @@ int ObLogger::log_head(const char *mod_name,
tm.tm_year + 1900, tm.tm_mon + 1, tm.tm_mday, tm.tm_hour, tm.tm_min,
tm.tm_sec, tv.tv_usec, GETTID(), GETTNAME(), GET_TENANT_ID(), TRACE_ID_FORMAT_PARAM(trace_id));
} else {
constexpr int cluster_id_buf_len = 8;
char cluster_id_buf[cluster_id_buf_len] = {'\0'};
(void)snprintf(cluster_id_buf, cluster_id_buf_len, "[C%lu]", GET_CLUSTER_ID());
ret = logdata_printf(buf, buf_len, pos,
"[%04d-%02d-%02d %02d:%02d:%02d.%06ld] "
"%-5s %s%s (%s:%d) [%ld][%s][T%lu][" TRACE_ID_FORMAT_V2 "] [lt=%ld] ",
"%-5s %s%s (%s:%d) [%ld][%s]%s[T%lu][" TRACE_ID_FORMAT_V2 "] [lt=%ld] ",
tm.tm_year + 1900, tm.tm_mon + 1, tm.tm_mday, tm.tm_hour, tm.tm_min,
tm.tm_sec, tv.tv_usec, errstr_[level], mod_name, function,
base_file_name, line, GETTID(), GETTNAME(), GET_TENANT_ID(), TRACE_ID_FORMAT_PARAM(trace_id),
base_file_name, line, GETTID(), GETTNAME(), is_arb_replica_ ? cluster_id_buf : "",
GET_TENANT_ID(), TRACE_ID_FORMAT_PARAM(trace_id),
last_logging_cost_time_us_);
}
}
Expand Down Expand Up @@ -1315,7 +1319,8 @@ int ObLogger::add_files_to_list(void *files,
return ret;
}

int ObLogger::init(const ObBaseLogWriterCfg &log_cfg)
int ObLogger::init(const ObBaseLogWriterCfg &log_cfg,
const bool is_arb_replica)
{
int ret = OB_SUCCESS;

Expand Down Expand Up @@ -1360,6 +1365,7 @@ int ObLogger::init(const ObBaseLogWriterCfg &log_cfg)
} else if (OB_FAIL(ObBaseLogWriter::start())) {
LOG_STDERR("start ObBaseLogWriter error ret=%d\n", ret);
}
is_arb_replica_ = is_arb_replica;
}
}

Expand Down
4 changes: 3 additions & 1 deletion deps/oblib/src/lib/oblog/ob_log.h
Original file line number Diff line number Diff line change
Expand Up @@ -337,7 +337,8 @@ class ObLogger : public ObBaseLogWriter
public:
ObLogger();
virtual ~ObLogger();
virtual int init(const ObBaseLogWriterCfg &log_cfg);
virtual int init(const ObBaseLogWriterCfg &log_cfg,
const bool is_arb_replica);
virtual void destroy();

protected:
Expand Down Expand Up @@ -797,6 +798,7 @@ class ObLogger : public ObBaseLogWriter
uint64_t location_hash_val_;
} probes_[8];
int probe_cnt_ = 0;
bool is_arb_replica_;
};

inline ObLogger& ObLogger::get_logger()
Expand Down
3 changes: 3 additions & 0 deletions deps/oblib/src/lib/oblog/ob_log_module.h
Original file line number Diff line number Diff line change
Expand Up @@ -70,6 +70,7 @@ DEFINE_LOG_SUB_MOD(STANDBY) // primary and standby cluster
DEFINE_LOG_SUB_MOD(REASY) // libreasy
DEFINE_LOG_SUB_MOD(COORDINATOR) // leader coordinator
DEFINE_LOG_SUB_MOD(OBTRACE) // trace
DEFINE_LOG_SUB_MOD(DATA_DICT) // data_dictionary module
DEFINE_LOG_SUB_MOD(MVCC) // concurrency_control
LOG_MOD_END(ROOT)

Expand Down Expand Up @@ -415,6 +416,8 @@ LOG_MOD_END(PL)
#define _COORDINATOR_LOG(level, _fmt_, args...) _OB_MOD_LOG(COORDINATOR, level, _fmt_, ##args)
#define OBTRACE_LOG(level, info_string, args...) OB_MOD_LOG(OBTRACE, level, info_string, ##args)
#define _OBTRACE_LOG(level, _fmt_, args...) _OB_MOD_LOG(OBTRACE, level, _fmt_, ##args)
#define DDLOG(level, info_string, args...) OB_MOD_LOG(DATA_DICT, level, info_string, ##args)
#define _DDLOG(level, _fmt_, args...) _OB_MOD_LOG(DATA_DICT, level, _fmt_, ##args)
#define MVCC_LOG(level, info_string, args...) OB_MOD_LOG(MVCC, level, info_string, ##args)
#define _MVCC_LOG(level, _fmt_, args...) _OB_MOD_LOG(MVCC, level, _fmt_, ##args)

Expand Down
3 changes: 3 additions & 0 deletions deps/oblib/src/lib/oblog/ob_log_module.ipp
Original file line number Diff line number Diff line change
Expand Up @@ -49,7 +49,9 @@ REG_LOG_PAR_MOD(TLOG)
REG_LOG_PAR_MOD(STORAGETEST)
REG_LOG_PAR_MOD(WRS)
REG_LOG_PAR_MOD(PALF)
REG_LOG_PAR_MOD(ARCHIVE)
REG_LOG_PAR_MOD(LOGTOOL)
REG_LOG_PAR_MOD(DATA_DICT)

//regist WRS's sub-modules
REG_LOG_SUB_MOD(WRS, CLUSTER)
Expand Down Expand Up @@ -123,6 +125,7 @@ REG_LOG_SUB_MOD(STORAGE, BLKMGR)
// reigst CLOG's sub-modules
REG_LOG_SUB_MOD(CLOG, EXTLOG)
REG_LOG_SUB_MOD(CLOG, CSR)
REG_LOG_SUB_MOD(CLOG, ARCHIVE)

//regist SQL's sub-modules
REG_LOG_SUB_MOD(SQL, ENG)
Expand Down
9 changes: 5 additions & 4 deletions deps/oblib/src/lib/stat/ob_latch_define.h
Original file line number Diff line number Diff line change
Expand Up @@ -302,10 +302,11 @@ LATCH_DEF(CLOG_CKPT_RWLOCK, 291, "clog checkpoint rwlock", LATCH_READ_PREFER, 20
LATCH_DEF(REWRITE_RULE_ITEM_LOCK, 292, "rewrite rule item lock", LATCH_FIFO, 2000, 0, REWRITE_RULE_ITEM_LOCK_WAIT, "rewrite rule item lock")

// LATCH_DEF(TENANT_MGR_TENANT_BUCKET_LOCK, 290, "tenant mgr tenant bucket lock", LATCH_READ_PREFER, INT64_MAX, 0, TENANT_MGR_TENANT_BUCKET_LOCK_WAIT, "tenant mgr tenant bucket lock")
LATCH_DEF(SRS_LOCK, 292, "srs lock", LATCH_READ_PREFER, 2000, 0, SRS_LOCK_WAIT, "srs lock")
LATCH_DEF(DDL_EXECUTE_LOCK, 293, "ddl execute lock", LATCH_FIFO, 2000, 0, DDL_EXECUTE_LOCK_WAIT, "ddl execute lock")
LATCH_DEF(TENANT_IO_CONFIG_LOCK, 294, "tenant io config lock", LATCH_FIFO, 2000, 0, TENANT_IO_CONFIG_WAIT, "tenant io config lock")
LATCH_DEF(SQL_WF_PARTICIPATOR_COND_LOCK, 295, "window function participator lock", LATCH_FIFO, 2000, 0, SQL_WF_PARTICIPATOR_COND_WAIT, "window function participator lock")
LATCH_DEF(SRS_LOCK, 293, "srs lock", LATCH_READ_PREFER, 2000, 0, SRS_LOCK_WAIT, "srs lock")
LATCH_DEF(DDL_EXECUTE_LOCK, 294, "ddl execute lock", LATCH_FIFO, 2000, 0, DDL_EXECUTE_LOCK_WAIT, "ddl execute lock")
LATCH_DEF(TENANT_IO_CONFIG_LOCK, 295, "tenant io config lock", LATCH_FIFO, 2000, 0, TENANT_IO_CONFIG_WAIT, "tenant io config lock")
LATCH_DEF(SQL_WF_PARTICIPATOR_COND_LOCK, 296, "window function participator lock", LATCH_FIFO, 2000, 0, SQL_WF_PARTICIPATOR_COND_WAIT, "window function participator lock")
LATCH_DEF(ARB_SERVER_CONFIG_LOCK, 297, "arbserver config lock", LATCH_FIFO, 2000, 0, ARB_SERVER_CONFIG_WAIT, "arbserver config lock")

LATCH_DEF(LATCH_END, 99999, "latch end", LATCH_FIFO, 2000, 0, WAIT_EVENT_END, "latch end")
#endif
Expand Down
2 changes: 1 addition & 1 deletion deps/oblib/src/lib/string/ob_string_holder.h
Original file line number Diff line number Diff line change
Expand Up @@ -44,7 +44,7 @@ class DefaultAllocator : public ObIAllocator

class ObStringHolder
{
static constexpr int64_t TINY_STR_SIZE = 16;// no need count '\0'
static constexpr int64_t TINY_STR_SIZE = 32;// no need count '\0'
public:
ObStringHolder() : buffer_(nullptr), len_(0) {}
~ObStringHolder() { reset(); }
Expand Down
3 changes: 2 additions & 1 deletion deps/oblib/src/lib/thread/thread_define.h
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,8 @@ TG_DEF(TEST3, test3, "", TG_STATIC, DEDUP_QUEUE, ThreadCountPair(1, 1), 8, 8, 16
TG_DEF(TEST4, test4, "", TG_STATIC, THREAD_POOL, ThreadCountPair(1 ,1))
TG_DEF(TEST5, test5, "", TG_STATIC, ASYNC_TASK_QUEUE, ThreadCountPair(1 ,1), 16)
TG_DEF(TEST6, test6, "", TG_STATIC, TIMER_GROUP, ThreadCountPair(2 ,2))
TG_DEF(TEST7, test7, "", TG_STATIC, REENTRANT_THREAD_POOL, ThreadCountPair(1 ,1))
TG_DEF(TEST7, test7, "", TG_STATIC, QUEUE_THREAD, ThreadCountPair(10 ,10), 10)
TG_DEF(TEST8, test8, "", TG_STATIC, REENTRANT_THREAD_POOL, ThreadCountPair(1 ,1))
// other
TG_DEF(MEMORY_DUMP, memDump, "", TG_STATIC, THREAD_POOL, ThreadCountPair(1, 1))
TG_DEF(SchemaRefTask, SchemaRefTask, "", TG_STATIC, DEDUP_QUEUE, ThreadCountPair(1, 1), 1024, 1024, 1L << 30, 512L << 20, common::OB_MALLOC_BIG_BLOCK_SIZE, common::ObModIds::OB_SCHEMA_DEDUP_QUEUE)
Expand Down
16 changes: 15 additions & 1 deletion deps/oblib/src/lib/thread/thread_mgr.h
Original file line number Diff line number Diff line change
Expand Up @@ -193,6 +193,10 @@ class ITG
{
return common::OB_NOT_SUPPORTED;
}
virtual void set_queue_size(const int64_t qsize)
{
UNUSED(qsize);
}
TGHelper *tg_helper_;
lib::ThreadCGroup tg_cgroup_;
TGCommonAttr attr_;
Expand Down Expand Up @@ -508,6 +512,12 @@ class TG<TGType::QUEUE_THREAD> : public ITG
qth_ = nullptr;
}
}
void set_queue_size(const int64_t qsize) override
{
if (0 != qsize) {
task_num_limit_ = qsize;
}
}
private:
char buf_[sizeof(MySimpleThreadPool)];
MySimpleThreadPool *qth_ = nullptr;
Expand Down Expand Up @@ -951,7 +961,10 @@ class TGMgr
return ret;
}
// tenant isolation
int create_tg_tenant(int tg_def_id, int &tg_id, lib::ThreadCGroup cgroup = lib::ThreadCGroup::FRONT_CGROUP)
int create_tg_tenant(int tg_def_id,
int &tg_id,
int64_t qsize = 0,
lib::ThreadCGroup cgroup = lib::ThreadCGroup::FRONT_CGROUP)
{
tg_id = -1;
int ret = common::OB_SUCCESS;
Expand Down Expand Up @@ -979,6 +992,7 @@ class TGMgr
tg->tg_cgroup_ = cgroup;
tg_helper->tg_create_cb(tg_id);
}
tg->set_queue_size(qsize);
tgs_[tg_id] = tg;
OB_LOG(INFO, "create tg succeed",
"tg_id", tg_id,
Expand Down
9 changes: 5 additions & 4 deletions deps/oblib/src/lib/wait_event/ob_wait_event.h
Original file line number Diff line number Diff line change
Expand Up @@ -293,10 +293,11 @@ WAIT_EVENT_DEF(DEADLOCK_DETECT_LOCK_WAIT, 15247, "spinlock: deadlock detect lock
//WAIT_EVENT_DEF(BACKUP_CLEAN_SERVICE_COND_WAIT, 15249, "backup clean service condition wait", "address", "", "", CONCURRENCY, "backup clean service condition wait", true)
//WAIT_EVENT_DEF(BACKUP_ARCHIVE_SERVICE_COND_WAIT, 15250, "backup archive service condition wait", "address", "", "", CONCURRENCY, "backup archive service condition wait", true)
WAIT_EVENT_DEF(SRS_LOCK_WAIT, 15251, "latch: srs lock wait", "address", "number", "tries", CONCURRENCY, "latch: srs lock wait", true)
WAIT_EVENT_DEF(CLOG_CKPT_RWLOCK_WAIT, 15252, "rwlock: clog checkpoint rwlock wait", "address", "number", "tries", CONCURRENCY, "rwlock: clog checkpoint rwlock wait", true)
WAIT_EVENT_DEF(TENANT_IO_CONFIG_WAIT, 15253, "rwlock: tenant io config wait", "address", "number", "tries", CONCURRENCY, "rwlock: tenant io config wait", true)
WAIT_EVENT_DEF(SQL_WF_PARTICIPATOR_LOCK_WAIT, 15254, "latch: window function participator cond lock wait", "address", "", "", CONCURRENCY, "window function participator cond lock wait", true)
WAIT_EVENT_DEF(SQL_WF_PARTICIPATOR_COND_WAIT, 15255, "mutex: window function participator cond wait", "address", "", "", CONCURRENCY, "window function participator cond wait", true)
WAIT_EVENT_DEF(ARB_SERVER_CONFIG_WAIT, 15252, "arbserver config wait", "address", "number", "tries", CONCURRENCY, "arbserver config wait", true)
WAIT_EVENT_DEF(CLOG_CKPT_RWLOCK_WAIT, 15253, "rwlock: clog checkpoint rwlock wait", "address", "number", "tries", CONCURRENCY, "rwlock: clog checkpoint rwlock wait", true)
WAIT_EVENT_DEF(TENANT_IO_CONFIG_WAIT, 15254, "rwlock: tenant io config wait", "address", "number", "tries", CONCURRENCY, "rwlock: tenant io config wait", true)
WAIT_EVENT_DEF(SQL_WF_PARTICIPATOR_LOCK_WAIT, 15255, "latch: window function participator cond lock wait", "address", "", "", CONCURRENCY, "window function participator cond lock wait", true)
WAIT_EVENT_DEF(SQL_WF_PARTICIPATOR_COND_WAIT, 15256, "mutex: window function participator cond wait", "address", "", "", CONCURRENCY, "window function participator cond wait", true)

//transaction
WAIT_EVENT_DEF(END_TRANS_WAIT, 16001, "wait end trans", "rollback", "trans_hash_value", "participant_count", COMMIT,"wait end trans", false)
Expand Down
2 changes: 0 additions & 2 deletions deps/oblib/src/rpc/frame/ob_req_deliver.h
Original file line number Diff line number Diff line change
Expand Up @@ -24,8 +24,6 @@ namespace rpc
class ObRequest;
namespace frame
{
// forewar declarations
struct ObGlobalContext;

// This class plays a deliver role who'll deliver each packet received
// from the upper to responding packet queue. The deliver rules is
Expand Down
Loading

0 comments on commit 50024b3

Please sign in to comment.