code: fix typo (#76)

* Update ob_dtl_rpc_channel.cpp

* Update ob_time_convert.cpp

* Update ob_time_convert.h

* Update ob_expr_date_add.cpp

* fix log spell error:faild -> failled, Faild -> Failed

* Update ob_optimizer_util.cpp

* Update ob_sql.cpp

* Update ob_optimizer_util.cpp

* Update ob_plan_cache_manager.cpp

* Update ob_partition_merge_task.cpp
This commit is contained in:
chuancy 2021-06-15 14:50:25 +08:00 committed by GitHub
parent a55849046f
commit a474a9cf55
No known key found for this signature in database
GPG Key ID: 4AEE18F83AFDEB23
36 changed files with 74 additions and 74 deletions

View File

@ -5988,7 +5988,7 @@ int ObTimeConverter::interval_ym_to_str(const ObIntervalYMValue& value, const Ob
buf_len,
pos,
format_str,
display_part.is_negtive_ ? '-' : '+',
display_part.is_negative_ ? '-' : '+',
display_part.parts_[ObIntervalParts::YEAR_PART],
display_part.parts_[ObIntervalParts::MONTH_PART]))) {
LOG_WARN("fail to print interval values", K(ret));
@ -6023,7 +6023,7 @@ int ObTimeConverter::interval_ds_to_str(const ObIntervalDSValue& value, const Ob
buf_len,
pos,
format_str_part1,
display_part.is_negtive_ ? '-' : '+',
display_part.is_negative_ ? '-' : '+',
display_part.parts_[ObIntervalParts::DAY_PART],
display_part.parts_[ObIntervalParts::HOUR_PART],
display_part.parts_[ObIntervalParts::MINUTE_PART],
@ -6349,7 +6349,7 @@ int ObTimeConverter::encode_interval_ym(
ret = OB_SIZE_OVERFLOW;
LOG_WARN("invalid argument", KP(buf), K(len), K(pos), K(data_len));
} else if (OB_FAIL(ObMySQLUtil::store_int1(
buf, len, static_cast<int8_t>(display_parts.is_negtive_), pos))) { // is_negative(1)
buf, len, static_cast<int8_t>(display_parts.is_negative_), pos))) { // is_negative(1)
LOG_WARN("fail to store int", K(ret));
} else if (OB_FAIL(ObMySQLUtil::store_int4(
buf, len, static_cast<int32_t>(display_parts.parts_[ObIntervalParts::YEAR_PART]), pos))) { // years(4)
@ -6404,7 +6404,7 @@ int ObTimeConverter::encode_interval_ds(
ret = OB_SIZE_OVERFLOW;
LOG_WARN("invalid argument", KP(buf), K(len), K(pos), K(data_len));
} else if (OB_FAIL(ObMySQLUtil::store_int1(
buf, len, static_cast<int8_t>(display_parts.is_negtive_), pos))) { // is_negative(1)
buf, len, static_cast<int8_t>(display_parts.is_negative_), pos))) { // is_negative(1)
LOG_WARN("fail to store int", K(ret));
} else if (OB_FAIL(ObMySQLUtil::store_int4(
buf, len, static_cast<int32_t>(display_parts.parts_[ObIntervalParts::DAY_PART]), pos))) { // days(4)
@ -6471,7 +6471,7 @@ void ObTimeConverter::interval_ym_to_display_part(const ObIntervalYMValue& value
int64_t abs_nmonth = std::abs(value.get_nmonth());
display_parts.parts_[ObIntervalParts::YEAR_PART] = static_cast<int32_t>(abs_nmonth / MONTHS_PER_YEAR);
display_parts.parts_[ObIntervalParts::MONTH_PART] = static_cast<int32_t>(abs_nmonth % MONTHS_PER_YEAR);
display_parts.is_negtive_ = value.is_negative();
display_parts.is_negative_ = value.is_negative();
}
void ObTimeConverter::interval_ds_to_display_part(const ObIntervalDSValue& value, ObIntervalParts& display_parts)
@ -6486,7 +6486,7 @@ void ObTimeConverter::interval_ds_to_display_part(const ObIntervalDSValue& value
display_parts.parts_[ObIntervalParts::MINUTE_PART] = static_cast<int32_t>(rest_minutes_in_day % MINS_PER_HOUR);
display_parts.parts_[ObIntervalParts::SECOND_PART] = static_cast<int32_t>(rest_seconds_in_day % SECS_PER_MIN);
display_parts.parts_[ObIntervalParts::FRECTIONAL_SECOND_PART] = abs_fs;
display_parts.is_negtive_ = value.is_negative();
display_parts.is_negative_ = value.is_negative();
}
int ObTimeConverter::iso_str_to_interval_ym(const ObString& str, ObIntervalYMValue& value)
@ -6496,7 +6496,7 @@ int ObTimeConverter::iso_str_to_interval_ym(const ObString& str, ObIntervalYMVal
if (OB_FAIL(iso_interval_str_parse(str, interval_parts, ObIntervalParts::YEAR_PART))) {
LOG_WARN("fail to parse interval str", K(ret));
} else {
value.set_value(interval_parts.is_negtive_,
value.set_value(interval_parts.is_negative_,
interval_parts.parts_[ObIntervalParts::YEAR_PART],
interval_parts.parts_[ObIntervalParts::MONTH_PART]);
if (OB_FAIL(value.validate())) {
@ -6514,7 +6514,7 @@ int ObTimeConverter::iso_str_to_interval_ds(const ObString& str, ObIntervalDSVal
if (OB_FAIL(iso_interval_str_parse(str, interval_parts, ObIntervalParts::DAY_PART))) {
LOG_WARN("fail to parse interval str", K(ret));
} else {
value.set_value(interval_parts.is_negtive_,
value.set_value(interval_parts.is_negative_,
interval_parts.parts_[ObIntervalParts::DAY_PART],
interval_parts.parts_[ObIntervalParts::HOUR_PART],
interval_parts.parts_[ObIntervalParts::MINUTE_PART],
@ -6543,9 +6543,9 @@ int ObTimeConverter::iso_interval_str_parse(
LOG_WARN("empty input str", K(ret));
} else if (parse_ctx.cur_ch_[0] == '-') {
parse_ctx.update(1);
interval_parts.is_negtive_ = true;
interval_parts.is_negative_ = true;
} else {
interval_parts.is_negtive_ = false;
interval_parts.is_negative_ = false;
}
if (OB_FAIL(ret)) {

View File

@ -169,7 +169,7 @@ class ObIntervalParts {
{}
inline void reset()
{
is_negtive_ = false;
is_negative_ = false;
memset(parts_, 0, sizeof(parts_));
}
enum PartName {
@ -185,10 +185,10 @@ class ObIntervalParts {
};
inline int32_t get_part_value(PartName part_name)
{
return (part_name < PART_CNT && part_name > INVALID_PART) ? (parts_[part_name] * (is_negtive_ ? -1 : 1))
return (part_name < PART_CNT && part_name > INVALID_PART) ? (parts_[part_name] * (is_negative_ ? -1 : 1))
: INT32_MAX;
}
bool is_negtive_;
bool is_negative_;
int32_t parts_[PART_CNT];
};

View File

@ -282,7 +282,7 @@ int ObMySQLHandler::write_data(int fd, char* buffer, size_t length) const
is_going_on = false; // continue;
} else {
ret = OB_ERROR;
LOG_WARN("write data faild", K(errno), KERRMSG);
LOG_WARN("write data failed", K(errno), KERRMSG);
}
}
if (is_going_on) {
@ -321,7 +321,7 @@ int ObMySQLHandler::read_data(int fd, char* buffer, size_t length) const
is_going_on = false; // continue;
} else {
ret = OB_ERROR;
LOG_WARN("read data faild", K(errno), KERRMSG);
LOG_WARN("read data failed", K(errno), KERRMSG);
}
}
if (is_going_on) {

View File

@ -460,7 +460,7 @@ int ObArchiveSender::handle(ObArchiveSendTaskStatus& task_status, SendTaskArray&
unused_archived_checkpoint_ts,
unused_clog_epoch_id,
unused_accum_checksum))) {
ARCHIVE_LOG(WARN, "faild to get_max_archived_info", KR(ret), KPC(pg_archive_task));
ARCHIVE_LOG(WARN, "failed to get_max_archived_info", KR(ret), KPC(pg_archive_task));
} else if (OB_FAIL(check_can_send_task_(
epoch, incarnation, archive_round, max_archived_log_id, max_archived_log_ts, array))) {
ARCHIVE_LOG(WARN, "check_can_send_task_ can't send this task", KR(ret), KPC(pg_archive_task));

View File

@ -13393,7 +13393,7 @@ int ObDDLService::record_tablegroup_locality_event_history(const AlterLocalityOp
tablegroup_schema.get_previous_locality_str());
if (job_id < 1) {
ret = OB_SQL_OPT_ERROR;
LOG_WARN("faild to create rs job", K(tablegroup_schema.get_tenant_id()));
LOG_WARN("failed to create rs job", K(tablegroup_schema.get_tenant_id()));
}
} else if (ROLLBACK_ALTER_LOCALITY == alter_locality_op) {
ObRsJobInfo job_info;
@ -13439,7 +13439,7 @@ int ObDDLService::record_tablegroup_locality_event_history(const AlterLocalityOp
tablegroup_schema.get_locality_str());
if (job_id < 1) {
ret = OB_SQL_OPT_ERROR;
LOG_WARN("faild to create rs job", K(tablegroup_schema.get_tenant_id()));
LOG_WARN("failed to create rs job", K(tablegroup_schema.get_tenant_id()));
}
} else if (NOP_LOCALITY_OP == alter_locality_op) {
int64_t job_id = RS_JOB_CREATE(ALTER_TABLEGROUP_LOCALITY,
@ -13456,7 +13456,7 @@ int ObDDLService::record_tablegroup_locality_event_history(const AlterLocalityOp
tablegroup_schema.get_previous_locality_str());
if (job_id < 1) {
ret = OB_SQL_OPT_ERROR;
LOG_WARN("faild to create rs job", K(tablegroup_schema.get_tenant_id()));
LOG_WARN("failed to create rs job", K(tablegroup_schema.get_tenant_id()));
} else if (OB_FAIL(RS_JOB_COMPLETE(job_id, 0, trans))) {
LOG_WARN("failed to complete rs job", K(ret), K(tablegroup_schema.get_tenant_id()));
}

View File

@ -2493,7 +2493,7 @@ int ObSchemaServiceSQLImpl::fetch_new_tenant_id(uint64_t& new_tenant_id)
{
int ret = OB_SUCCESS;
if (OB_FAIL(fetch_new_schema_id(OB_SYS_TENANT_ID, OB_MAX_USED_TENANT_ID_TYPE, new_tenant_id))) {
LOG_WARN("fetch_new_tenant_id faild", K(ret));
LOG_WARN("fetch_new_tenant_id failed", K(ret));
} else {
new_tenant_id = extract_pure_id(new_tenant_id);
}

View File

@ -2080,7 +2080,7 @@ int ObTableSqlService::create_table(ObTableSchema& table, ObISQLClient& sql_clie
if (OB_SUCCESS == ret && 0 != table.get_autoinc_column_id()) {
if (OB_FAIL(add_sequence(
table.get_tenant_id(), table.get_table_id(), table.get_autoinc_column_id(), table.get_auto_increment()))) {
LOG_WARN("insert sequence record faild", K(ret), K(table));
LOG_WARN("insert sequence record failed", K(ret), K(table));
}
end_usec = ObTimeUtility::current_time();
cost_usec = end_usec - start_usec;
@ -2090,7 +2090,7 @@ int ObTableSqlService::create_table(ObTableSchema& table, ObISQLClient& sql_clie
// hidden primary key start with 1; incre
if (OB_SUCCESS == ret && NULL != table.get_column_schema(OB_HIDDEN_PK_INCREMENT_COLUMN_ID)) {
if (OB_FAIL(add_sequence(table.get_tenant_id(), table.get_table_id(), OB_HIDDEN_PK_INCREMENT_COLUMN_ID, 1))) {
LOG_WARN("insert sequence record faild", K(ret), K(table));
LOG_WARN("insert sequence record failed", K(ret), K(table));
}
end_usec = ObTimeUtility::current_time();
cost_usec = end_usec - start_usec;

View File

@ -43,7 +43,7 @@ void ObDtlRpcChannel::SendMsgCB::on_invalid()
void ObDtlRpcChannel::SendMsgCB::on_timeout()
{
LOG_WARN("SendMsgCB timeout, if negtive timeout, check peer cpu load, network packet drop rate", K_(trace_id));
LOG_WARN("SendMsgCB timeout, if negative timeout, check peer cpu load, network packet drop rate", K_(trace_id));
const ObDtlRpcDataResponse& resp = result_;
int ret = response_.on_finish(resp.is_block_, OB_TIMEOUT);
if (OB_FAIL(ret)) {
@ -54,7 +54,7 @@ void ObDtlRpcChannel::SendMsgCB::on_timeout()
int ObDtlRpcChannel::SendMsgCB::process()
{
const ObDtlRpcDataResponse& resp = result_;
// if request queue is full or serialize faild, then rcode is set, and rpc process is not called
// if request queue is full or serialize failed, then rcode is set, and rpc process is not called
int tmp_ret = OB_SUCCESS != rcode_.rcode_ ? rcode_.rcode_ : resp.recode_;
int ret = response_.on_finish(resp.is_block_, tmp_ret);
if (OB_FAIL(ret)) {
@ -90,7 +90,7 @@ void ObDtlRpcChannel::SendBCMsgCB::on_invalid()
void ObDtlRpcChannel::SendBCMsgCB::on_timeout()
{
LOG_WARN("SendBCMsgCB timeout, if negtive timeout, check peer cpu load, network packet drop rate", K_(trace_id));
LOG_WARN("SendBCMsgCB timeout, if negative timeout, check peer cpu load, network packet drop rate", K_(trace_id));
ObIArray<ObDtlRpcDataResponse>& resps = result_.resps_;
for (int64_t i = 0; i < resps.count() && i < responses_.count(); ++i) {
int ret = responses_.at(i)->on_finish(resps.at(i).is_block_, OB_TIMEOUT);
@ -107,7 +107,7 @@ int ObDtlRpcChannel::SendBCMsgCB::process()
if (resps.count() != responses_.count()) {
LOG_ERROR("unexpected status: response count is not match", K(resps.count()), K(responses_.count()));
}
// if request queue is full or serialize faild, then rcode is set, and rpc process is not called
// if request queue is full or serialize failed, then rcode is set, and rpc process is not called
for (int64_t i = 0; i < responses_.count(); ++i) {
bool is_block = i < resps.count() ? resps.at(i).is_block_ : false;
int ret_code =

View File

@ -1849,7 +1849,7 @@ int ObAggregateFunction::add_calc(ObObj& res, const ObObj& left, const ObObj& ri
if (OB_SUCC(ret)) {
if (OB_FAIL(ObExprAdd::calc_for_agg(res_exp, *p_left, *p_right, expr_ctx_, -1))) {
SQL_ENG_LOG(WARN, "add calculate faild", K(*p_left), K(*p_right));
SQL_ENG_LOG(WARN, "add calculate failed", K(*p_left), K(*p_right));
} else {
ret = clone_cell(res_exp, res);
}

View File

@ -223,7 +223,7 @@ int ObExprValues::inner_get_next_row(ObExecContext& ctx, const ObNewRow*& row) c
plan_ctx->set_autoinc_id_tmp(0);
if (get_rows() > 10) {
if (OB_FAIL(THIS_WORKER.check_status())) {
LOG_WARN("check physical plan status faild", K(ret));
LOG_WARN("check physical plan status failed", K(ret));
}
}
}

View File

@ -260,7 +260,7 @@ int ObExprValuesOp::inner_get_next_row()
if (OB_SUCC(ret)) {
plan_ctx->set_autoinc_id_tmp(0);
if (OB_FAIL(try_check_status())) {
LOG_WARN("check physical plan status faild", K(ret));
LOG_WARN("check physical plan status failed", K(ret));
}
}

View File

@ -136,7 +136,7 @@ int ObExprValuesWithChild::inner_get_next_row(ObExecContext& ctx, const ObNewRow
ret = OB_ERR_UNEXPECTED;
LOG_WARN("get physical operator context failed", K(ret), K_(id));
} else if (OB_FAIL(THIS_WORKER.check_status())) {
LOG_WARN("check physical plan status faild", K(ret));
LOG_WARN("check physical plan status failed", K(ret));
} else if (OB_FAIL(calc_next_row(ctx))) {
if (OB_ITER_END != ret) {
LOG_WARN("get next row from row store failed", K(ret));

View File

@ -507,7 +507,7 @@ int ObDupKeyCheckerCtx::shuffle_final_data(
ret = OB_INVALID_ARGUMENT;
SQL_ENG_LOG(WARN, "eval ctx is null", K(ret));
} else if (OB_FAIL(constraint_value.baseline_datum_row_->to_expr(output_exprs, *ctx.get_eval_ctx()))) {
SQL_ENG_LOG(WARN, "stored row to expr faild", K(ret));
SQL_ENG_LOG(WARN, "stored row to expr failed", K(ret));
} else if (OB_FAIL(shuffle_op.shuffle_final_delete_row(ctx, output_exprs))) {
SQL_ENG_LOG(WARN, "shuffle delete row failed", K(ret), K(constraint_value));
}
@ -518,7 +518,7 @@ int ObDupKeyCheckerCtx::shuffle_final_data(
ret = OB_INVALID_ARGUMENT;
SQL_ENG_LOG(WARN, "eval ctx is null", K(ret));
} else if (OB_FAIL(constraint_value.current_datum_row_->to_expr(output_exprs, *ctx.get_eval_ctx()))) {
SQL_ENG_LOG(WARN, "stored row to expr faild", K(ret));
SQL_ENG_LOG(WARN, "stored row to expr failed", K(ret));
} else if (OB_FAIL(shuffle_op.shuffle_final_insert_row(ctx, output_exprs))) {
SQL_ENG_LOG(WARN, "shuffle insert row failed", K(ret), K(constraint_value));
}

View File

@ -129,7 +129,7 @@ int ObConflictDatumIterator::get_next_row(ObNewRow*& row)
const ObChunkDatumStore::StoredRow* sr = NULL;
if (OB_FAIL(row_iter_.get_next_row(sr))) {
if (OB_ITER_END != ret) {
LOG_WARN("get next row faild", K(ret));
LOG_WARN("get next row failed", K(ret));
}
}
if (OB_SUCC(ret)) {

View File

@ -170,7 +170,7 @@ int ObExprDateAdjust::calc_result3(ObObj& result, const ObObj& date, const ObObj
} else {
uint64_t sub_num = 1;
number::ObNumber tmp_sub_num;
// add a positive or minus a negtive number, truncate decimal part.
// add a positive or minus a negative number, truncate decimal part.
if (OB_FAIL(interval_num.trunc(0))) {
LOG_WARN("trunc decimal failed", K(ret));
} else if ((is_add && is_neg)) {

View File

@ -41,7 +41,7 @@ int ObHashJoinBatch::load_next_chunk()
int ret = OB_SUCCESS;
if (OB_FAIL(chunk_iter_.load_next_chunk(row_store_iter_))) {
if (OB_ITER_END != ret) {
LOG_WARN("faild to load next chunk", K(ret));
LOG_WARN("failed to load next chunk", K(ret));
}
}
return ret;

View File

@ -41,7 +41,7 @@ int ObHJBatch::load_next_chunk()
{
int ret = OB_SUCCESS;
if (OB_FAIL(chunk_iter_.load_next_chunk(row_store_iter_))) {
LOG_WARN("faild to load next chunk", K(ret));
LOG_WARN("failed to load next chunk", K(ret));
}
return ret;
}

View File

@ -617,7 +617,7 @@ int ObPxCoord::destroy_all_channel(ObPxCoordCtx& px_ctx) const
}
const ObIArray<ObDfo*>& dfos = px_ctx.coord_info_.dfo_mgr_.get_all_dfos();
/* even if one channel unlink faild, we still continue destroy other channel */
/* even if one channel unlink failed, we still continue destroy other channel */
ARRAY_FOREACH_X(dfos, idx, cnt, true)
{
const ObDfo* edge = dfos.at(idx);
@ -625,7 +625,7 @@ int ObPxCoord::destroy_all_channel(ObPxCoordCtx& px_ctx) const
if (OB_FAIL(edge->get_sqcs(sqcs))) {
LOG_WARN("fail to get sqcs", K(ret));
} else {
/* one channel unlink faild still continue destroy other channel */
/* one channel unlink failed still continue destroy other channel */
ARRAY_FOREACH_X(sqcs, sqc_idx, sqc_cnt, true)
{
const ObDtlChannelInfo& qc_ci = sqcs.at(sqc_idx)->get_qc_channel_info_const();

View File

@ -560,7 +560,7 @@ int ObPxCoordOp::destroy_all_channel()
}
const ObIArray<ObDfo*>& dfos = coord_info_.dfo_mgr_.get_all_dfos();
/* even if one channel unlink faild, we still continue destroy other channel */
/* even if one channel unlink failed, we still continue destroy other channel */
ARRAY_FOREACH_X(dfos, idx, cnt, true)
{
const ObDfo* edge = dfos.at(idx);
@ -568,7 +568,7 @@ int ObPxCoordOp::destroy_all_channel()
if (OB_FAIL(edge->get_sqcs(sqcs))) {
LOG_WARN("fail to get sqcs", K(ret));
} else {
/* one channel unlink faild still continue destroy other channel */
/* one channel unlink failed still continue destroy other channel */
ARRAY_FOREACH_X(sqcs, sqc_idx, sqc_cnt, true)
{
const ObDtlChannelInfo& qc_ci = sqcs.at(sqc_idx)->get_qc_channel_info_const();

View File

@ -1364,16 +1364,16 @@ int ObWindowFunction::ObWindowFunctionCtx::get_next_row(const ObNewRow*& row)
for (int64_t i = ++last_output_row_; i < rw_.count() && OB_SUCC(ret); ++i) {
const ObNewRow* child_row = NULL;
if (OB_FAIL(rw_.at(i, child_row))) {
LOG_WARN("get row faild", K(ret), K(i));
LOG_WARN("get row failed", K(ret), K(i));
} else {
for (int64_t j = 0; j < child_row->get_count() && OB_SUCC(ret); ++j) {
cur_row.cells_[j] = child_row->get_cell(j);
}
const ObNewRow* res_row = NULL;
if (op_->is_parallel_ && OB_FAIL(func_ctx->rw_.at(0, res_row))) {
LOG_WARN("get row faild", K(ret), K(i));
LOG_WARN("get row failed", K(ret), K(i));
} else if (!op_->is_parallel_ && OB_FAIL(func_ctx->rw_.at(i, res_row))) {
LOG_WARN("get row faild", K(ret), K(i));
LOG_WARN("get row failed", K(ret), K(i));
} else {
int64_t cell_idx = res_row->count_;
DLIST_FOREACH_NORET(func, func_list_)
@ -1458,7 +1458,7 @@ int ObWindowFunction::ObWindowFunctionCtx::parallel_winbuf_process()
LOG_WARN("fail to get whole msg", K(ret));
}
} else if (OB_FAIL(func_ctx->rw_.at(0, res_row))) {
LOG_WARN("get row faild", K(ret), K(res_row));
LOG_WARN("get row failed", K(ret), K(res_row));
} else if (OB_FAIL(get_whole_msg(false, whole, res_row))) {
LOG_WARN("fail to get whole msg", K(ret));
} else if (whole.is_empty_) {
@ -1491,7 +1491,7 @@ int ObWindowFunction::ObWindowFunctionCtx::parallel_winbuf_process()
case T_FUN_SUM: {
ObObj res;
if (OB_FAIL(ObExprAdd::calc_for_agg(res, new_row->cells_[index], row->cells_[index], expr_ctx_, -1))) {
LOG_WARN("add calculate faild", K(ret), K(index));
LOG_WARN("add calculate failed", K(ret), K(index));
} else if (res.need_deep_copy()) {
char* copy_data = NULL;
int64_t copy_size = res.get_deep_copy_size();

View File

@ -1188,14 +1188,14 @@ int ObWindowFunctionOp::inner_get_next_row()
const ObRADatumStore::StoredRow* child_row = NULL;
const ObRADatumStore::StoredRow* result_row = NULL;
if (OB_FAIL(rows_store_.get_row(last_output_row_idx_, child_row))) {
LOG_WARN("get row faild", K(ret), K(last_output_row_idx_));
LOG_WARN("get row failed", K(ret), K(last_output_row_idx_));
} else if (OB_FAIL(child_row->to_expr(get_all_expr(), eval_ctx_))) {
LOG_WARN("Failed to get next row", K(ret));
} else if (MY_SPEC.is_parallel_ && OB_FAIL(wf_cell.part_rows_store_.get_row(0, result_row))) {
LOG_WARN("get row faild", K(ret), K(last_output_row_idx_));
LOG_WARN("get row failed", K(ret), K(last_output_row_idx_));
} else if (!MY_SPEC.is_parallel_ &&
OB_FAIL(wf_cell.part_rows_store_.get_row(last_output_row_idx_, result_row))) {
LOG_WARN("get row faild", K(ret), K(last_output_row_idx_));
LOG_WARN("get row failed", K(ret), K(last_output_row_idx_));
} else {
clear_evaluated_flag();
WinFuncCell* tmp_wf_cell = wf_list_.get_first();
@ -1304,7 +1304,7 @@ int ObWindowFunctionOp::parallel_winbuf_process()
LOG_WARN("fail to get whole msg", K(ret));
}
} else if (OB_FAIL(wf_cell.part_rows_store_.get_row(0, res_row))) {
LOG_WARN("get row faild", K(ret), K(res_row));
LOG_WARN("get row failed", K(ret), K(res_row));
} else if (OB_FAIL(get_whole_msg(false, whole, res_row))) {
LOG_WARN("fail to get whole msg", K(ret));
} else if (whole.is_empty_) {

View File

@ -3427,7 +3427,7 @@ int ObSql::calc_pre_calculable_exprs(const ObDMLStmt& stmt, const ObIArray<ObHid
FALSE_IT(phy_plan_ctx->set_cur_time(ObTimeUtility::current_time(), *(exec_ctx.get_my_session())))) {
// do nothing
} else if (OB_FAIL(ObCacheObject::pre_calculation(is_ignore_stmt, *pre_calc_frame, exec_ctx))) {
LOG_WARN("failde to pre calculate exprs", K(ret));
LOG_WARN("failed to pre calculate exprs", K(ret));
} else if (OB_UNLIKELY(!phy_plan.get_pre_calc_frames().add_last(pre_calc_frame))) {
ret = OB_ERR_UNEXPECTED;
LOG_WARN("failed to add list element", K(ret));

View File

@ -575,7 +575,7 @@ int ObSqlPartitionLocationCache::build_distribute_location(
ret = OB_ERR_UNEXPECTED;
LOG_WARN("task exec ctx is NULL", K(ret), K(table_id), K(partition_id));
} else if (OB_FAIL(task_exec_ctx_->get_addr_by_virtual_partition_id(partition_id, addr))) {
LOG_WARN("get addr by virtual partition id faild", K(ret), K(table_id), K(partition_id));
LOG_WARN("get addr by virtual partition id failed", K(ret), K(table_id), K(partition_id));
} else if (FALSE_IT(replica_location.server_ = addr)) {
} else if (OB_FAIL(location.add(replica_location))) {
LOG_WARN("location add failed", K(ret), K(table_id), K(partition_id));

View File

@ -2813,7 +2813,7 @@ int ObOptimizerUtil::classify_get_scan_ranges(const common::ObIArray<ObNewRange>
ret = OB_INVALID_ARGUMENT;
LOG_WARN("table_schema is NULL", K(ret));
} else if (OB_FAIL(deep_copy_range(allocator, input_ranges.at(i), tmp_range))) {
LOG_WARN("failde to deep copy range", K(ret));
LOG_WARN("failed to deep copy range", K(ret));
} else if (OB_FAIL(table_schema->get_rowkey_column_ids(rowkey_descs))) {
LOG_WARN("get rowkey column desc failed", K(ret));
} else if (OB_FAIL(ObTableScan::transform_rowid_range(allocator, rowkey_descs, tmp_range))) {
@ -2822,7 +2822,7 @@ int ObOptimizerUtil::classify_get_scan_ranges(const common::ObIArray<ObNewRange>
LOG_WARN("failed to push back range", K(ret));
}
} else if (OB_FAIL(used_input_ranges.push_back(input_ranges.at(i)))) {
LOG_WARN("failde to push back range", K(ret));
LOG_WARN("failed to push back range", K(ret));
}
if (OB_SUCC(ret)) {
LOG_TRACE("used input range", K(used_input_ranges.at(used_input_ranges.count() - 1)));

View File

@ -411,7 +411,7 @@ void ObPlanCacheManager::ObPlanCacheEliminationTask::run_free_cache_obj_task()
ObCacheObject* to_del_obj = NULL;
for (int j = 0; j < deleted_objs.count(); j++) {
if (OB_FAIL(ObCacheObjectFactory::destroy_cache_obj(true, deleted_objs.at(j).obj_id_, plan_cache))) {
LOG_WARN("failde to destroy cache obj", K(ret));
LOG_WARN("failed to destroy cache obj", K(ret));
}
} // end inner loop
}

View File

@ -268,7 +268,7 @@ int ObDMLResolver::resolve_sql_expr(
if (OB_SUCC(ret) && op_exprs.count() > 0) {
if (OB_FAIL(ObRawExprUtils::resolve_op_exprs_for_oracle_implicit_cast(
ctx.expr_factory_, ctx.session_info_, op_exprs))) {
LOG_WARN("implicit cast faild", K(ret));
LOG_WARN("implicit cast failed", K(ret));
}
}

View File

@ -1161,7 +1161,7 @@ int ObResolverUtils::resolve_const_expr(
LOG_WARN("impicit cast for oracle", K(ret));
if (OB_FAIL(ObRawExprUtils::resolve_op_exprs_for_oracle_implicit_cast(
ctx.expr_factory_, ctx.session_info_, op_exprs))) {
LOG_WARN("impicit cast faild", K(ret));
LOG_WARN("impicit cast failed", K(ret));
}
}

View File

@ -1461,9 +1461,9 @@ int ObTransformJoinElimination::EliminationHelper::push_back(
{
int ret = OB_SUCCESS;
if (OB_FAIL(child_table_items_.push_back(child))) {
LOG_WARN("faild to push back table item", K(ret));
LOG_WARN("failed to push back table item", K(ret));
} else if (OB_FAIL(parent_table_items_.push_back(parent))) {
LOG_WARN("faild to push back table item", K(ret));
LOG_WARN("failed to push back table item", K(ret));
} else if (OB_FAIL(foreign_key_infos_.push_back(info))) {
LOG_WARN("failed to push back foreign key info", K(ret));
} else if (OB_FAIL(bitmap_.push_back(false))) {
@ -1485,7 +1485,7 @@ int ObTransformJoinElimination::EliminationHelper::get_eliminable_group(
if (bitmap_.at(i)) {
/* table already eliminated */
} else if (OB_FAIL(is_table_in_child_items(parent_table_items_.at(i), in_child))) {
LOG_WARN("faild to find table item", K(ret));
LOG_WARN("failed to find table item", K(ret));
} else if (in_child) {
/* do nothing */
} else {

View File

@ -53,7 +53,7 @@ int ObBloomFilterMacroBlockReader::read_macro_block(
} else if (OB_FAIL(decompress_micro_block(full_meta, block_buf, block_size))) {
STORAGE_LOG(WARN, "Failed to decompress micro block", K(ret));
} else if (OB_FAIL(read_micro_block(block_buf, block_size, bf_buf, bf_size))) {
STORAGE_LOG(WARN, "Faild to read micro block to bloom filter", K(ret));
STORAGE_LOG(WARN, "Failed to read micro block to bloom filter", K(ret));
}
return ret;

View File

@ -409,7 +409,7 @@ int ObBloomFilterMacroBlockWriter::flush_macro_block()
full_meta.meta_ = &macro_meta;
ObStorageFile* file = NULL;
if (OB_FAIL(build_macro_meta(full_meta))) {
STORAGE_LOG(WARN, "Faild to generate bloomfilter macro meta", K(ret));
STORAGE_LOG(WARN, "Failed to generate bloomfilter macro meta", K(ret));
} else if (OB_ISNULL(file = file_handle_.get_storage_file())) {
ret = OB_ERR_UNEXPECTED;
STORAGE_LOG(WARN, "fail to get pg file", K(ret), K(file_handle_));

View File

@ -272,7 +272,7 @@ int ObMacroBlockBuilder::init_bloomfilter_if_need(storage::ObSSTableMergeCtx& ct
} else if (!sstable->has_bloom_filter_macro_block()) {
need_build_bloom_filter_ = false;
} else if (OB_FAIL(sstable->get_bf_macro_block_ctx(bf_block_ctx))) {
STORAGE_LOG(WARN, "Faild to get bloomfilter block ctx", K(ret));
STORAGE_LOG(WARN, "Failed to get bloomfilter block ctx", K(ret));
} else if (nullptr == file && OB_ISNULL(file = desc_.file_handle_.get_storage_file())) {
ret = OB_ERR_UNEXPECTED;
STORAGE_LOG(WARN, "fail to get pg_file", K(ret), K(desc_.file_handle_));
@ -568,7 +568,7 @@ int ObMacroBlockBuilder::process(const ObStoreRow& row, const ObCompactRowType::
} else if (OB_FAIL(writer_->append_row(row))) { // del_row need been stored when minor merge
STORAGE_LOG(WARN, "Fail to append row to builder_", K(ret), K_(merge_type));
} else if (need_build_bloom_filter_ && OB_FAIL(append_bloom_filter(row))) {
STORAGE_LOG(WARN, "Faild to append row to bloomfilter", K(ret));
STORAGE_LOG(WARN, "Failed to append row to bloomfilter", K(ret));
} else {
STORAGE_LOG(DEBUG, "Success to append row to builder_", K(ret), K_(merge_type), K(row));
}

View File

@ -1819,7 +1819,7 @@ int ObTransTableMergeTask::get_merged_trans_sstable(ObTableHandle& table_handle,
if (OB_FAIL(tables_handle_.get_first_sstable(sstable))) {
LOG_WARN("failed to get fist sstable", K(ret), K_(pg_key), K(table_key));
} else if (OB_FAIL(table_handle.set_table(sstable))) {
LOG_WARN("failde to set table", K(ret), K_(pg_key), K(table_key));
LOG_WARN("failed to set table", K(ret), K_(pg_key), K(table_key));
}
} else if (OB_FAIL(data_blocks.push_back(&writer.get_macro_block_write_ctx()))) {
LOG_WARN("fail to push back data block", K(ret));

View File

@ -1144,7 +1144,7 @@ int ObRecoveryData::get_unneed_recovery_points(
if (!need_left && curr->get_snapshot_version() <= snapshot_gc_ts) {
if (OB_FAIL(points_data.push_back(curr))) {
ret = OB_ERR_UNEXPECTED;
LOG_ERROR("faild to push back into array", K(ret));
LOG_ERROR("failed to push back into array", K(ret));
} else {
LOG_INFO("get unneeded recovery point", K(ret), KPC(curr));
}
@ -1887,7 +1887,7 @@ int ObRecoveryDataMgr::add_restore_point(const int64_t snapshot_version, const O
partition_store_metas,
tables_handle,
restore_point_data_))) {
LOG_WARN("faild to add restore point", K(ret), K(pg_meta));
LOG_WARN("failed to add restore point", K(ret), K(pg_meta));
}
return ret;
}
@ -1934,7 +1934,7 @@ int ObRecoveryDataMgr::get_all_points_info(ObIArray<ObRecoveryPointInfo>& points
// LOG_INFO("get_all_points_info get restore point ", K(point_info));
if (OB_FAIL(points_info.push_back(point_info))) {
ret = OB_ERR_UNEXPECTED;
LOG_ERROR("faild to push back into array", K(ret));
LOG_ERROR("failed to push back into array", K(ret));
}
point = point->get_next();
}
@ -1949,7 +1949,7 @@ int ObRecoveryDataMgr::get_all_points_info(ObIArray<ObRecoveryPointInfo>& points
// LOG_INFO("get_all_points_info get backup point ", K(point_info));
if (OB_FAIL(points_info.push_back(point_info))) {
ret = OB_ERR_UNEXPECTED;
LOG_ERROR("faild to push back into array", K(ret));
LOG_ERROR("failed to push back into array", K(ret));
}
point = point->get_next();
}
@ -2085,7 +2085,7 @@ int ObRecoveryDataMgr::add_backup_point(const int64_t snapshot_version, const Ob
partition_store_metas,
tables_handle,
backup_point_data_))) {
LOG_WARN("faild to add backup point", K(ret), K(pg_meta));
LOG_WARN("failed to add backup point", K(ret), K(pg_meta));
}
return ret;
}

View File

@ -878,7 +878,7 @@ int ObLogReplayEngine::do_replay_task(storage::ObIPartitionGroup* partition, ObR
REPLAY_LOG(INFO, "succ to replay offline partition log", K(ret), K(*replay_task));
} else {
EVENT_INC(CLOG_FAIL_REPLAY_OFFLINE_COUNT);
REPLAY_LOG(WARN, "faild to replay offline partition log", K(ret), K(*replay_task));
REPLAY_LOG(WARN, "failed to replay offline partition log", K(ret), K(*replay_task));
}
} else {
// no need replay
@ -934,7 +934,7 @@ int ObLogReplayEngine::do_replay_task(storage::ObIPartitionGroup* partition, ObR
EVENT_INC(CLOG_SUCC_REPLAY_META_LOG_COUNT);
REPLAY_LOG(INFO, "succ to replay partition meta log", K(ret), K(*replay_task));
} else {
REPLAY_LOG(WARN, "faild to replay partition meta log", K(ret), K(*replay_task));
REPLAY_LOG(WARN, "failed to replay partition meta log", K(ret), K(*replay_task));
EVENT_INC(CLOG_FAIL_REPLAY_META_LOG_COUNT);
}
} else if (ObStorageLogTypeChecker::is_add_partition_to_pg_log(log_type)) {
@ -972,7 +972,7 @@ int ObLogReplayEngine::do_replay_task(storage::ObIPartitionGroup* partition, ObR
REPLAY_LOG(INFO, "succ to replay offline partition log", K(ret), K(*replay_task));
} else {
EVENT_INC(CLOG_FAIL_REPLAY_OFFLINE_COUNT);
REPLAY_LOG(WARN, "faild to replay offline partition log", K(ret), K(*replay_task));
REPLAY_LOG(WARN, "failed to replay offline partition log", K(ret), K(*replay_task));
}
} else if (ObStorageLogTypeChecker::is_schema_version_change_log(log_type)) {
REPLAY_LOG(INFO, "start to replay partition schema version change log", "replay_task", *replay_task);

View File

@ -115,7 +115,7 @@ int ObTransAuditRecord::get_trans_sql_audit_data(
// Invalid sql record
continue;
} else if (OB_FAIL(stmt_info_iter.push(stmt_info_[i]))) {
TRANS_LOG(WARN, "iterate sql audit faild", KR(ret));
TRANS_LOG(WARN, "iterate sql audit failed", KR(ret));
break;
}
}

View File

@ -351,7 +351,7 @@ int ObTransCtx::alloc_audit_rec_and_trace_log_(ObTransService* trans_service, Ob
while (retry_times--) {
if (OB_FAIL(record_mgr->get_empty_record(tmp_rec))) {
if (REACH_TIME_INTERVAL(1 * 1000 * 1000)) {
TRANS_LOG(WARN, "get empty audit record faild", KR(ret));
TRANS_LOG(WARN, "get empty audit record failed", KR(ret));
}
} else if (OB_FAIL(tmp_rec->init(this))) {
TRANS_LOG(WARN, "set trans ctx in audit record failed", KR(ret));