Change code owners

This commit is contained in:
JiahuaChen
2024-02-08 02:26:43 +00:00
committed by ob-robot
parent 74e0a412d9
commit ccfccee77b
13 changed files with 40 additions and 41 deletions

View File

@ -64,7 +64,6 @@ public:
static const int64_t MAX_MEMORY_ALLOCATION = OB_MAX_SYS_BKGD_THREAD_NUM * 2 * OB_DEFAULT_MACRO_BLOCK_SIZE; //256MB
private:
// TODO(zhuixin.gsy) reduce 128*2M size to 64*2M, which is expanded temporarily for generating index blocks
static const int64_t MAX_MEMORY_IN_MINI_MODE = 64 * OB_DEFAULT_MACRO_BLOCK_SIZE; //128MB
bool is_inited_;

View File

@ -1,3 +1,15 @@
/**
* Copyright (c) 2023 OceanBase
* OceanBase CE is licensed under Mulan PubL v2.
* You can use this software according to the terms and conditions of the Mulan PubL v2.
* You may obtain a copy of Mulan PubL v2 at:
* http://license.coscl.org.cn/MulanPubL-2.0
* THIS SOFTWARE IS PROVIDED ON AN "AS IS" BASIS, WITHOUT WARRANTIES OF ANY KIND,
* EITHER EXPRESS OR IMPLIED, INCLUDING BUT NOT LIMITED TO NON-INFRINGEMENT,
* MERCHANTABILITY OR FIT FOR A PARTICULAR PURPOSE.
* See the Mulan PubL v2 for more details.
*/
#include <gtest/gtest.h>
#define private public
#define protected public
@ -144,12 +156,6 @@ TEST_F(TestCgSSTable, test_cg_index_tree_cursor)
cg_rowkey[0].set_int(i);
OK(tree_cursor.pull_up_to_root());
OK(tree_cursor.drill_down(rowkey, ObIndexBlockTreeCursor::MoveDepth::LEAF, true, equal, is_beyond_range));
// {
// STORAGE_LOG(INFO, "zhuixin debug", K(i), KPC(tree_cursor.curr_path_item_));
// OK(tree_cursor.get_idx_parser(parser));
// OK(tree_cursor.get_current_endkey(endkey));
// STORAGE_LOG(INFO, "zhuixin debug", KPC(parser), K(endkey), K(is_beyond_range));
// }
ASSERT_FALSE(is_beyond_range);
if (is_macro_start) {
OK(tree_cursor.get_current_endkey(endkey));

View File

@ -1296,7 +1296,7 @@ TEST_F(TestIndexTree, test_reuse_macro_block)
TEST_F(TestIndexTree, DISABLED_test_writer_try_to_append_row)
{
// TODO(zhuixin.gsy) fix try_to_append_row, enable this case
// fix try_to_append_row, enable this case
int ret = OB_SUCCESS;
ObDatumRow row;
OK(row.init(allocator_, TEST_COLUMN_CNT));
@ -1320,7 +1320,6 @@ TEST_F(TestIndexTree, DISABLED_test_writer_try_to_append_row)
}
OK(micro_writer->build_micro_block_desc(micro_block_desc));
const int64_t need_store_size = micro_block_desc.buf_size_ + micro_block_desc.header_->header_size_;
STORAGE_LOG(INFO, "zhuixin debug block", K(micro_block_desc));
{ // set size upper bound after reuse
micro_writer->reuse();

View File

@ -9913,7 +9913,7 @@ def_table_schema(
)
def_table_schema(
owner = 'zhuixin.gsy',
owner = 'luhaopeng.lhp',
table_name = '__all_virtual_table_mgr',
table_id = '12034',
table_type = 'VIRTUAL_TABLE',
@ -16834,7 +16834,7 @@ WHERE SVR_IP=HOST_IP() AND SVR_PORT=RPC_PORT()
)
def_table_schema(
owner = 'zhuixin.gsy',
owner = 'luhaopeng.lhp',
table_name = 'GV$OB_SSTABLES',
table_id = '21100',
table_type = 'SYSTEM_VIEW',
@ -16872,7 +16872,7 @@ FROM
)
def_table_schema(
owner = 'zhuixin.gsy',
owner = 'luhaopeng.lhp',
table_name = 'V$OB_SSTABLES',
table_id = '21101',
table_type = 'SYSTEM_VIEW',
@ -51877,7 +51877,7 @@ def_table_schema(
)
def_table_schema(
owner = 'zhuixin.gsy',
owner = 'luhaopeng.lhp',
table_name = 'GV$OB_SSTABLES',
name_postfix = '_ORA',
database_id = 'OB_ORA_SYS_DATABASE_ID',
@ -51913,7 +51913,7 @@ FROM
)
def_table_schema(
owner = 'zhuixin.gsy',
owner = 'luhaopeng.lhp',
table_name = 'V$OB_SSTABLES',
name_postfix = '_ORA',
database_id = 'OB_ORA_SYS_DATABASE_ID',

View File

@ -1,12 +1,14 @@
// Copyright (c) 2021 Ant Group CO., Ltd.
// OceanBase is licensed under Mulan PubL v1.
// You can use this software according to the terms and conditions of the Mulan PubL v1.
// You may obtain a copy of Mulan PubL v1 at:
// http://license.coscl.org.cn/MulanPubL-1.0
// THIS SOFTWARE IS PROVIDED ON AN "AS IS" BASIS, WITHOUT WARRANTIES OF ANY KIND,
// EITHER EXPRESS OR IMPLIED, INCLUDING BUT NOT LIMITED TO NON-INFRINGEMENT,
// MERCHANTABILITY OR FIT FOR A PARTICULAR PURPOSE.
// See the Mulan PubL v1 for more details.
/**
* Copyright (c) 2023 OceanBase
* OceanBase CE is licensed under Mulan PubL v2.
* You can use this software according to the terms and conditions of the Mulan PubL v2.
* You may obtain a copy of Mulan PubL v2 at:
* http://license.coscl.org.cn/MulanPubL-2.0
* THIS SOFTWARE IS PROVIDED ON AN "AS IS" BASIS, WITHOUT WARRANTIES OF ANY KIND,
* EITHER EXPRESS OR IMPLIED, INCLUDING BUT NOT LIMITED TO NON-INFRINGEMENT,
* MERCHANTABILITY OR FIT FOR A PARTICULAR PURPOSE.
* See the Mulan PubL v2 for more details.
*/
#define USING_LOG_PREFIX STORAGE
#include "storage/blocksstable/index_block/ob_agg_row_struct.h"
@ -83,7 +85,7 @@ int ObAggRowWriter::sort_metas(const ObIArray<ObSkipIndexColMeta> &agg_col_arr,
}
std::sort(col_meta_list_.begin(), col_meta_list_.end());
for (int64_t i = 0; OB_SUCC(ret) && i < column_count_; ++i) {
LOG_DEBUG("zhuixin debug sort", K(i), K(col_meta_list_.at(i).first), K(col_meta_list_.at(i).second));
LOG_DEBUG("sort", K(i), K(col_meta_list_.at(i).first), K(col_meta_list_.at(i).second));
}
}
return ret;
@ -195,13 +197,13 @@ int ObAggRowWriter::write_cell(
} else {
col_off_arr.set(idx, pos - orig_pos);
MEMCPY(buf + pos, datum.ptr_, datum.len_); // copy data
LOG_DEBUG("zhuixin debug write cell", K(idx), K(datum), K(pos), K(val), K(start), K(end));
LOG_DEBUG("write cell", K(idx), K(datum), K(pos), K(val), K(start), K(end));
pos += datum.len_;
}
++idx;
}
if (OB_SUCC(ret) && stored_col_cnt > 0) {
LOG_DEBUG("zhuixin debug write cell(reserved)", K(idx), K(pos), K(orig_pos), K(header_size_));
LOG_DEBUG("write cell(reserved)", K(idx), K(pos), K(orig_pos), K(header_size_));
col_off_arr.set(stored_col_cnt - 1, pos - orig_pos); // cell end
}
}
@ -432,7 +434,7 @@ int ObAggRowReader::read_cell(
}
col_off = col_off_arr.at(pre_cnt);
col_len = col_off_arr.at(pre_cnt + 1) - col_off;
LOG_DEBUG("zhuixin debug read cell", K(ret), K(pre_cnt), K(col_off), K(col_len));
LOG_DEBUG("read cell", K(ret), K(pre_cnt), K(col_off), K(col_len));
}
return ret;
}

View File

@ -438,7 +438,7 @@ void ObSSTableIndexBuilder::reset()
bool ObSSTableIndexBuilder::check_index_desc(const ObDataStoreDesc &index_desc) const
{
bool ret = true;
// TODO(zhuixin.gsy): these args influence write_micro_block and need to be evaluated
// these args influence write_micro_block and need to be evaluated
if (!index_desc.is_valid()
|| index_desc.merge_info_ != nullptr
|| index_desc.get_row_column_count() != index_desc.get_rowkey_column_count() + 1
@ -644,7 +644,6 @@ int ObSSTableIndexBuilder::trim_empty_roots()
}
int ObSSTableIndexBuilder::ObMacroMetaIter::init(IndexTreeRootCtxList &roots, const bool is_cg)
{
// TODO(zhuixin.gsy) reserve roots_
int ret = OB_SUCCESS;
if (IS_INIT) {
ret = OB_INIT_TWICE;
@ -1523,7 +1522,6 @@ int ObBaseIndexBlockBuilder::close_index_tree(ObBaseIndexBlockBuilder *&root_bui
} else if (OB_UNLIKELY(next_level_builder_ == nullptr)) {
root_builder = this;
} else {
//TODO(zhuixin.gsy) check if row_count == 0 is error?
if (OB_LIKELY(micro_writer_->get_row_count() > 0)) {
if (OB_FAIL(append_index_micro_block())) {
STORAGE_LOG(WARN, "Fail to append index micro block, ", K(ret));
@ -1847,7 +1845,6 @@ int ObDataIndexBlockBuilder::insert_and_update_index_tree(const ObDatumRow *inde
int ObDataIndexBlockBuilder::cal_macro_meta_block_size(
const ObDatumRowkey &rowkey, int64_t &estimate_meta_block_size)
{
// TODO(zhuixin.gsy) fix and add agg_row_buf_ max size
int ret = OB_SUCCESS;
ObDataMacroBlockMeta macro_meta;
const int64_t rowkey_cnt = rowkey.datum_cnt_;

View File

@ -1294,7 +1294,6 @@ int ObMacroBlockWriter::write_micro_block(ObMicroBlockDesc &micro_block_desc)
}
}
// TODO(zhuixin.gsy): ensure bloomfilter correct for index micro block
if (OB_SUCC(ret)) {
last_micro_size_ = micro_block_desc.data_size_;
last_micro_expand_pct_ = micro_block_desc.original_size_ * 100 / micro_block_desc.data_size_;
@ -1343,7 +1342,7 @@ int ObMacroBlockWriter::try_active_flush_macro_block()
int ObMacroBlockWriter::flush_macro_block(ObMacroBlock &macro_block)
{
int ret = OB_SUCCESS;
ObLogicMacroBlockId cur_logic_id; // TODO(zhuixin.gsy) rm this if DDL Rebuild Ready
ObLogicMacroBlockId cur_logic_id;
cur_logic_id.logic_version_ = data_store_desc_->get_logical_version();
cur_logic_id.column_group_idx_ = data_store_desc_->get_table_cg_idx();
cur_logic_id.data_seq_.macro_data_seq_ = current_macro_seq_;

View File

@ -372,7 +372,7 @@ int ObSharedBlockReadHandle::verify_checksum(
header_size = header->header_size_;
buf_len = header->data_size_;
}
LOG_DEBUG("zhuixin debug read shared block", K(ret), KPC(header));
LOG_DEBUG("read shared block", K(ret), KPC(header));
}
return ret;
}
@ -552,7 +552,7 @@ int ObSharedBlockLinkIter::read_next_block(ObSharedBlockReadHandle &block_handle
const ObSharedBlockHeader *header =
reinterpret_cast<const ObSharedBlockHeader *>(macro_handle.get_buffer());
cur_ = header->prev_addr_;
LOG_DEBUG("zhuixin debug get next link block", K(ret), K(head_), K(cur_), KPC(header));
LOG_DEBUG("get next link block", K(ret), K(head_), K(cur_), KPC(header));
}
return ret;
}
@ -926,7 +926,7 @@ int ObSharedBlockReaderWriter::inner_write_block(
} else if (!need_flush) {
hanging_ = true;
}
LOG_DEBUG("zhuixin debug inner write block", K(ret), K(header), K(size), K(need_flush),
LOG_DEBUG("inner write block", K(ret), K(header), K(size), K(need_flush),
K(need_align), K(store_size), K(align_store_size), K(offset_), K(align_offset_),
K(hanging_), K(addr), K(macro_handle));
}

View File

@ -172,7 +172,6 @@ protected:
virtual void reset_obj();
protected:
// TODO(zhuixin.gsy) rm *obj_pool_ and *allocator_
T *obj_;
ObITenantMetaObjPool *obj_pool_;
common::ObIAllocator *allocator_;

View File

@ -758,7 +758,7 @@ int ObStorageMetaCache::batch_get_meta_and_bypass_cache(
ret = OB_INVALID_ARGUMENT;
LOG_WARN("invalid arguments", K(ret), K(meta_types), K(keys));
} else {
// TODO: @zhuixin implement batch read in shared block reader.
// TODO: implement batch read in shared block reader.
for (int64_t i = 0; OB_SUCC(ret) && i < keys.count(); ++i) {
const ObStorageMetaValue::MetaType &meta_type = meta_types.at(i);
const ObStorageMetaKey &key = keys.at(i);

View File

@ -686,7 +686,7 @@ ObITabletFilterOp::~ObITabletFilterOp()
total_tablet_cnt_ += total_cnt_;
not_in_mem_tablet_cnt_ += not_in_mem_cnt_;
invalid_attr_tablet_cnt_ += invalid_attr_cnt_;
LOG_INFO("zhuixin debug filter destructed",
LOG_INFO("tablet skip filter destructed",
K_(total_cnt), K_(skip_cnt), K_(not_in_mem_cnt), K_(invalid_attr_cnt),
K_(total_tablet_cnt), K_(total_skip_cnt), K_(not_in_mem_tablet_cnt), K_(invalid_attr_tablet_cnt));
}

View File

@ -136,7 +136,6 @@ int ObFullTabletCreator::create_tablet(ObTabletHandle &tablet_handle)
ObArenaAllocator, (&tiny_allocator_), mstx_mem_ctx_->get_malloc_allocator(), page_size))) {
ret = OB_ALLOCATE_MEMORY_FAILED;
LOG_WARN("fail to new arena allocator", K(ret));
/* TODO(zhuixin.gsy) rm these set_xx after merge master*/
} else if (FALSE_IT(allocator->set_label("MSTXAllocator"))) {
} else if (FALSE_IT(allocator->set_tenant_id(MTL_ID()))) {
} else if (FALSE_IT(allocator->set_ctx_id(ObCtxIds::DEFAULT_CTX_ID))) {

View File

@ -80,7 +80,6 @@ TEST_F(TestAggRow, test_agg_row)
agg_row.storage_datums_[cnt].set_int(cnt);
}
OK(is_null.push_back(null));
STORAGE_LOG(INFO, "zhuixin debug", K(cnt), K(col_meta), K(null));
has[col_idx][col_type] = true;
++cnt;
}