fix some typo error

This commit is contained in:
obdev
2023-09-08 12:35:44 +08:00
committed by ob-robot
parent 23e5e34042
commit ca21045824
21 changed files with 86 additions and 86 deletions

View File

@ -676,7 +676,7 @@ inline int ObExprGeneratorImpl::visit_regex_expr(ObOpRawExpr &expr, ObExprRegexp
ObIArray<ObRawExpr*> &param_exprs = expr.get_param_exprs();
if (OB_ISNULL(regexp_op)) {
ret = OB_ERR_UNEXPECTED;
LOG_WARN("regexpr_op is NULL");
LOG_WARN("regexp_op is NULL");
} else if (OB_UNLIKELY(2 != param_exprs.count())) {
ret = OB_INVALID_ARGUMENT;
LOG_WARN("regex op should have 2 arguments", K(param_exprs.count()));
@ -779,7 +779,7 @@ inline int ObExprGeneratorImpl::visit_in_expr(ObOpRawExpr &expr, ObExprInOrNotIn
}
}
//for row_type in left_param of EXPR IN
//if min_cluster_version < 3.1, do not check params can use hash optimizition
//if min_cluster_version < 3.1, do not check params can use hash optimization
bool param_all_const = true;
bool param_all_same_type = true;
bool param_all_same_cs_type = true;
@ -875,7 +875,7 @@ inline int ObExprGeneratorImpl::visit_in_expr(ObOpRawExpr &expr, ObExprInOrNotIn
? param_all_same_cs_type
: (param_all_same_cs_type &= param_all_same_cs_level));
in_op->set_param_is_ext_type_oracle(param_all_is_ext);
//now only support c1 in (1,2,3,4,5...) to vecotrized
//now only support c1 in (1,2,3,4,5...) to vectorized
if (param_all_can_vectorize && expr.get_param_expr(0)->is_vectorize_result()) {
in_op->set_param_can_vectorized();
}
@ -893,7 +893,7 @@ int ObExprGeneratorImpl::visit_decode_expr(ObNonTerminalRawExpr &expr, ObExprOra
} else {
// decode(col, cond1, val1, cond2, val2, ......, condN, valN, def_val)
// cmp type of decode is always equal to cond1, or varchar if cond1 is const null.
// res type of decode is always euqal to val1, or varchar if val1 is const null.
// res type of decode is always equal to val1, or varchar if val1 is const null.
bool cond_all_same_meta = true;
bool val_all_same_meta = true;
int64_t param_count = expr.get_param_count();
@ -1454,7 +1454,7 @@ int ObExprGeneratorImpl::visit_pl_integer_checker_expr(ObOpRawExpr &expr,
ObPLIntegerCheckerRawExpr &pl_expr = static_cast<ObPLIntegerCheckerRawExpr&>(expr);
if (OB_ISNULL(checker)) {
ret = OB_ERR_UNEXPECTED;
LOG_ERROR("pl interger checker operator is null", K(ret));
LOG_ERROR("pl integer checker operator is null", K(ret));
} else {
checker->set_pl_integer_type(pl_expr.get_pl_integer_type());
checker->set_range(pl_expr.get_lower(), pl_expr.get_upper());

View File

@ -693,7 +693,7 @@ int ObStaticEngineCG::check_vectorize_supported(bool &support,
support = false;
stop_checking = true;
}
LOG_DEBUG("check_vectorie_supported", K(disable_vectorize), K(support), K(stop_checking),
LOG_DEBUG("check_vectorize_supported", K(disable_vectorize), K(support), K(stop_checking),
K(op->get_num_of_child()));
// continue searching until found an operator with vectorization explicitly disabled
for (int64_t i = 0; !stop_checking && OB_SUCC(ret) && i < op->get_num_of_child(); i++) {
@ -709,7 +709,7 @@ int ObStaticEngineCG::check_vectorize_supported(bool &support,
// 从raw expr中获取rt_expr,并将raw expr push到cur_op_exprs_中
//
// 设置operater的rt expr, 从raw expr中获取时,均需要通过该接口,
// 设置operator的rt expr, 从raw expr中获取时,均需要通过该接口,
// 其中ObStaticEngineExprCG::generate_rt_expr是ObRawExpr的友元函数, 可直接访问ObRawExpr中rt expr,
//
// 为什么不是ObRawExpr中直接提供访问rt expr的接口给外部使用, 而是用友元函数的方式处理?
@ -2837,7 +2837,7 @@ int ObStaticEngineCG::generate_spec(ObLogGranuleIterator &op, ObGranuleIteratorS
"desc", op.desc_order(),
"flags", op.get_gi_flags(),
"tsc_ids", spec.pw_dml_tsc_ids_,
"repart_prunint_idx", spec.repart_pruning_tsc_idx_,
"repart_pruning_tsc_idx", spec.repart_pruning_tsc_idx_,
K(pwj_gi), K(enable_repart_pruning));
return ret;
}
@ -3300,7 +3300,7 @@ int ObStaticEngineCG::generate_spec(ObLogExchange &op, ObPxRepartTransmitSpec &s
// repartition_exprs_ only use by null aware anti join
// now just support single join key
// either repart_keys or repart_sub_keys exists join key
// so we can generate from one of them driectly
// so we can generate from one of them directly
if (op.get_repart_keys().count() > 0) {
if (OB_FAIL(generate_rt_exprs(op.get_repart_keys(), spec.repartition_exprs_))) {
LOG_WARN("failed to generate repart exprs", K(ret));
@ -3792,7 +3792,7 @@ int ObStaticEngineCG::generate_dist_aggr_group(ObLogGroupBy &op, ObGroupBySpec &
const ObDistinctAggrBatch &distinct_batch = op.get_distinct_aggr_batch().at(i);
aggr_group_idx += distinct_batch.mocked_aggrs_.count();
if (OB_FAIL(spec.dist_aggr_group_idxes_.push_back(aggr_group_idx))) {
LOG_WARN("failed to push back aggr group aggr inndex", K(ret));
LOG_WARN("failed to push back aggr group aggr index", K(ret));
}
} // end for
return ret;
@ -3979,7 +3979,7 @@ int ObStaticEngineCG::generate_normal_tsc(ObLogTableScan &op, ObTableScanSpec &s
}
root = root->and_next_;
}
// TODO @baixian.zr the above optimization is overrided by ObTscCgService::generate_tsc_ctdef before this commit
// TODO @baixian.zr the above optimization is overrode by ObTscCgService::generate_tsc_ctdef before this commit
// but after the deep copy of pre_query_range_ is removed in ObTscCgService::generate_tsc_ctdef,
// error is returned in such sql 'set global x=y', should fix this;
// spec.tsc_ctdef_.pre_query_range_.set_is_equal_and(is_equal_and);
@ -4654,7 +4654,7 @@ int ObStaticEngineCG::generate_join_spec(ObLogJoin &op, ObJoinSpec &spec)
for (auto l_output_idx = 0;
OB_SUCC(ret) && l_output_idx < nlj.get_left()->output_.count();
l_output_idx++) {
// check if left child expr appears in other_condtion
// check if left child expr appears in other_condition
bool appears_in_cond = false;
if (OB_FAIL(cond->contain_expr(
nlj.get_left()->output_.at(l_output_idx), appears_in_cond))) {
@ -4814,7 +4814,7 @@ int ObStaticEngineCG::generate_join_spec(ObLogJoin &op, ObJoinSpec &spec)
//} else if (exec_params.count() == 0) {
//// Do nothing
//} else if (exec_params.count() != 1) {
//// Only one ? expr for all level expr in connent by clause.
//// Only one ? expr for all level expr in connect by clause.
//ret = OB_ERR_UNEXPECTED;
//LOG_WARN("unexpected exec params count in connect by", K(exec_params.count()), K(ret));
//} else if (OB_FAIL(nlj_op->init_exec_param_count(exec_params.count()))) {
@ -5052,7 +5052,7 @@ int ObStaticEngineCG::recursive_get_column_expr(const ObColumnRefRawExpr *&colum
LOG_WARN("get unexpected null", K(ret));
} else if ((table_item->is_generated_table() || table_item->is_temp_table()) &&
OB_FAIL(recursive_get_column_expr(inner_column, *table_item))) {
LOG_WARN("faield to recursive get column expr", K(ret));
LOG_WARN("failed to recursive get column expr", K(ret));
} else {
column = inner_column;
}
@ -5383,7 +5383,7 @@ int ObStaticEngineCG::generate_spec(ObLogInsert &op, ObPxMultiPartSSTableInsertS
const ObExecContext *exec_ctx = nullptr;
ObLogPlan *log_plan = nullptr;
if (OB_FAIL(generate_spec(op, static_cast<ObPxMultiPartInsertSpec &>(spec), in_root_job))) {
LOG_WARN("generge multi part sstable insert spec failed", K(ret));
LOG_WARN("generate multi part sstable insert spec failed", K(ret));
} else if (OB_ISNULL(log_plan = op.get_plan()) ||
OB_ISNULL(exec_ctx = log_plan->get_optimizer_context().get_exec_ctx())) {
ret = OB_INVALID_ARGUMENT;
@ -6621,7 +6621,7 @@ int ObStaticEngineCG::generate_insert_all_with_das(ObLogInsertAll &op, ObTableIn
OB_ISNULL(phy_plan_) ||
OB_UNLIKELY(op.get_table_list().count() != op.get_insert_all_table_info()->count())) {
ret = OB_ERR_UNEXPECTED;
LOG_WARN("get unexpeceted error", K(ret), K(phy_plan_), K(op.get_insert_all_table_info()));
LOG_WARN("get unexpected error", K(ret), K(phy_plan_), K(op.get_insert_all_table_info()));
} else if (OB_FAIL(spec.ins_ctdefs_.allocate_array(phy_plan_->get_allocator(),
op.get_table_list().count()))) {
LOG_WARN("allocate insert ctdef array failed", K(ret));
@ -6723,7 +6723,7 @@ int ObStaticEngineCG::generate_spec(ObLogStatCollector &op,
}
} else {
ret = OB_ERR_UNEXPECTED;
LOG_WARN("unexpcted type", K(spec.type_));
LOG_WARN("unexpected type", K(spec.type_));
}
return ret;
}
@ -7003,7 +7003,7 @@ int ObStaticEngineCG::set_other_properties(const ObLogPlan &log_plan, ObPhysical
}
if (OB_SUCC(ret) && metas.count() > 0) {
if (OB_FAIL(phy_plan.get_encrypt_meta_array().assign(metas))) {
LOG_WARN("fail to assgin encrypt meta", K(ret));
LOG_WARN("fail to assign encrypt meta", K(ret));
}
}
}
@ -7546,7 +7546,7 @@ int ObStaticEngineCG::add_output_datum_check_flag(ObOpSpec &spec)
} else {
// Because the Unpivot will affect the output datum of the SubplanScan,
// which is an by designed case, we need to set the SubplanScan operator
// to not check the ouput datum.
// to not check the output datum.
spec.get_child(0)->need_check_output_datum_ = false;
}
} else {

View File

@ -229,7 +229,7 @@ int ObStaticEngineExprCG::cg_exprs(const ObIArray<ObRawExpr *> &raw_exprs,
// cg_expr_parents must be after cg_expr_by_operator,
// because cg_expr_by_operator may replace rt_expr.args_
} else if (OB_FAIL(cg_expr_parents(raw_exprs))) {
LOG_WARN("fail to init expr parenets", K(ret), K(raw_exprs));
LOG_WARN("fail to init expr parents", K(ret), K(raw_exprs));
// init res_buf_len_, frame_idx_, datum_off_, res_buf_off_
} else if (OB_FAIL(cg_all_frame_layout(raw_exprs, expr_info))) {
LOG_WARN("fail to init expr data layout", K(ret), K(raw_exprs));
@ -701,7 +701,7 @@ int ObStaticEngineExprCG::cg_frame_layout_vector_version(const ObIArray<ObRawExp
LOG_WARN("Failed to create tmp frame info", K(ret));
}
// calulate the datums layout in each frame
// caculate the datums layout in each frame
for (int64_t idx = 0; OB_SUCC(ret) && idx < tmp_frame_infos.count(); idx++) {
const ObFrameInfo &frame = tmp_frame_infos.at(idx).frame_info_;
int64_t expr_start_pos = tmp_frame_infos.at(idx).expr_start_pos_;
@ -898,7 +898,7 @@ int ObStaticEngineExprCG::arrange_datums_data(ObIArray<ObRawExpr *> &exprs,
{
int ret = OB_SUCCESS;
if (continuous_datum) {
// Layout1: Frame is seperated from meta part and data part.
// Layout1: Frame is separated from meta part and data part.
// Meta part(datum header) are allocated continuously.
// Reserved data/buf part are allocated continuously
// Frame layouts:
@ -987,7 +987,7 @@ int ObStaticEngineExprCG::arrange_datums_data(ObIArray<ObRawExpr *> &exprs,
CK((total_header_len + expr_data_offset) == frame.frame_size_);
} else {
// Layout2: Frame is seperated by exprs
// All data(metas + reserved data/buf) within one expr are allocated continously
// All data(metas + reserved data/buf) within one expr are allocated continuously
// Frame layouts:
// +--------------------------------+
// | Datums in Expr1 |
@ -1297,7 +1297,7 @@ int ObStaticEngineExprCG::calc_exprs_res_buf_len(const ObIArray<ObRawExpr *> &ra
rt_expr->res_buf_len_ = min(def_res_len,
static_cast<uint32_t>(rt_expr->max_length_));
} else {
// max_length may eaual -1
// max_length may equal -1
rt_expr->res_buf_len_ = def_res_len;
}
} else {
@ -1336,7 +1336,7 @@ int ObStaticEngineExprCG::create_tmp_frameinfo(const common::ObIArray<ObRawExpr
// FIXME: should never hit this block.
// expr_datums_size larger than max frame size, means _rowsets_max_rows is tool large.
// So far manually tune sys arg _rowsets_max_rows to a smaller value.
// Long term: create a function automaticly tune the datums size
// Long term: create a function automaticaly tune the datums size
LOG_WARN("Frame allocation failure, please tune _rowsets_max_rows to a smaller number",
K(expr_datums_size));
ret = OB_ERR_UNEXPECTED;

View File

@ -163,7 +163,7 @@ public:
const RowDesc &row_desc,
ObIAllocator &alloctor,
ObSQLSessionInfo *session,
share::schema::ObSchemaGetterGuard *schema_gaurd,
share::schema::ObSchemaGetterGuard *schema_guard,
ObTempExpr *&temp_expr);
static int init_temp_expr_mem_size(ObTempExpr &temp_expr);