fix some typo error
This commit is contained in:
@ -50,7 +50,7 @@ int ObGIOpInput::init(ObTaskInfo &task_info)
|
||||
//new parallel framework do not use this interface to set parameters
|
||||
ret = OB_NOT_SUPPORTED;
|
||||
LOG_USER_ERROR(OB_NOT_SUPPORTED, "init gi input");
|
||||
LOG_WARN("the interface shoud not be used", K(ret));
|
||||
LOG_WARN("the interface should not be used", K(ret));
|
||||
return ret;
|
||||
}
|
||||
|
||||
@ -795,7 +795,7 @@ int ObGranuleIteratorOp::prepare_table_scan()
|
||||
ret = OB_ERR_UNEXPECTED;
|
||||
LOG_WARN("unexpected gi state", K(ret), K(state_));
|
||||
} else if (FALSE_IT(state_ = GI_GET_NEXT_GRANULE_TASK)) {
|
||||
} else if (OB_FAIL(get_next_granule_task(true /* prapare */))) {
|
||||
} else if (OB_FAIL(get_next_granule_task(true /* prepare */))) {
|
||||
if (ret != OB_ITER_END) {
|
||||
LOG_WARN("fail to get next granule task", K(ret));
|
||||
} else {
|
||||
@ -979,7 +979,7 @@ int ObGranuleIteratorOp::fetch_rescan_pw_task_infos(const common::ObIArray<int64
|
||||
state_ = GI_END;
|
||||
} else if (OB_UNLIKELY(rescan_task_idx_ + repart_idx >= pwj_rescan_task_infos_.count())) {
|
||||
ret = OB_ERR_UNEXPECTED;
|
||||
LOG_WARN("unexected pwj_rescan_task_infos_ count", K(ret), K(rescan_task_idx_),
|
||||
LOG_WARN("unexpected pwj_rescan_task_infos_ count", K(ret), K(rescan_task_idx_),
|
||||
K(repart_idx), K(pwj_rescan_task_infos_.count()), K(op_ids));
|
||||
} else {
|
||||
partition_pruned = repart_partition_pruned(pwj_rescan_task_infos_.at(rescan_task_idx_ + repart_idx));
|
||||
|
||||
@ -64,7 +64,7 @@ public:
|
||||
private:
|
||||
int deep_copy_range(ObIAllocator *allocator, const ObNewRange &src, ObNewRange &dst);
|
||||
public:
|
||||
// the dop, the QC deside the dop before our task send to SQC server
|
||||
// the dop, the QC decide the dop before our task send to SQC server
|
||||
// but the dop may be change as the worker server don't has enough process.
|
||||
int64_t parallelism_;
|
||||
// 在 affinitize 模式下 GI 需要知道当前 GI 所属的 task id,以拉取对应的 partition 任务
|
||||
|
||||
@ -222,7 +222,7 @@ int ObGITaskSet::construct_taskset(ObIArray<ObDASTabletLoc*> &taskset_tablets,
|
||||
taskset_tablets.count() != taskset_idxs.count() ||
|
||||
taskset_tablets.empty() || ss_ranges.count() > 1)) {
|
||||
ret = OB_ERR_UNEXPECTED;
|
||||
LOG_WARN("taskest count err", K(taskset_tablets.count()),
|
||||
LOG_WARN("taskset count err", K(taskset_tablets.count()),
|
||||
K(taskset_ranges),
|
||||
K(taskset_idxs),
|
||||
K(ss_ranges.count()));
|
||||
@ -687,7 +687,7 @@ int ObGranulePump::get_first_tsc_range_cnt(int64_t &cnt)
|
||||
ObGITaskArray &taskset_array = gi_task_array_map_.at(0).taskset_array_;
|
||||
if (taskset_array.empty()) {
|
||||
ret = OB_ERR_UNEXPECTED;
|
||||
LOG_WARN("unexpeceted taskset array", K(ret));
|
||||
LOG_WARN("unexpected taskset array", K(ret));
|
||||
} else {
|
||||
cnt = taskset_array.at(0).gi_task_set_.count();
|
||||
}
|
||||
@ -765,7 +765,7 @@ int ObGranuleSplitter::split_gi_task(ObGranulePumpArgs &args,
|
||||
range_independent);
|
||||
}
|
||||
if (OB_FAIL(ret)) {
|
||||
LOG_WARN("failed to get graunle task", K(ret), K(ranges), K(tablets), K(is_external_table));
|
||||
LOG_WARN("failed to get granule task", K(ret), K(ranges), K(tablets), K(is_external_table));
|
||||
} else if (OB_FAIL(task_set.construct_taskset(taskset_tablets,
|
||||
taskset_ranges,
|
||||
ss_ranges,
|
||||
@ -1182,7 +1182,7 @@ int ObPartitionWiseGranuleSplitter::split_granule(ObGranulePumpArgs &args,
|
||||
ObGITaskSet::ObGIRandomType random_type,
|
||||
bool partition_granule /* = true */)
|
||||
{
|
||||
// 由于FULL PARTITION WISE的splite方法较为特殊(需要对INSERT进行任务切分),而目前的`ObGranuleSplitter`的接口`split_granule`仅仅考虑了TSC的处理,
|
||||
// 由于FULL PARTITION WISE的split方法较为特殊(需要对INSERT进行任务切分),而目前的`ObGranuleSplitter`的接口`split_granule`仅仅考虑了TSC的处理,
|
||||
// 因此将`ObPartitionWiseGranuleSplitter`的该接口废弃掉
|
||||
UNUSED(args);
|
||||
UNUSED(scan_ops);
|
||||
@ -1265,7 +1265,7 @@ int ObPartitionWiseGranuleSplitter::split_granule(ObGranulePumpArgs &args,
|
||||
LOG_WARN("failed to push back task set", K(ret));
|
||||
} else {
|
||||
// 获得对应的insert/replace op id
|
||||
LOG_TRACE("splite modify gi task successfully", K(modify_op->get_id()));
|
||||
LOG_TRACE("split modify gi task successfully", K(modify_op->get_id()));
|
||||
gi_task_array_result.at(index_idx).tsc_op_id_ = modify_op->get_id();
|
||||
}
|
||||
}
|
||||
@ -1332,7 +1332,7 @@ int ObPartitionWiseGranuleSplitter::split_insert_gi_task(ObGranulePumpArgs &args
|
||||
taskset_ranges,
|
||||
taskset_idxs,
|
||||
range_independent))) {
|
||||
LOG_WARN("failed to get insert graunle task", K(ret), K(each_partition_range), K(tablets));
|
||||
LOG_WARN("failed to get insert granule task", K(ret), K(each_partition_range), K(tablets));
|
||||
} else if (OB_FAIL(task_set.construct_taskset(taskset_tablets, taskset_ranges,
|
||||
empty_ss_ranges, taskset_idxs, random_type))) {
|
||||
// INSERT的任务划分一定是 partition wise的,并且INSERT算子每次rescan仅仅需要每一个task对应的partition key,
|
||||
|
||||
@ -675,7 +675,7 @@ int ObPxCoordOp::destroy_all_channel()
|
||||
}
|
||||
/*
|
||||
* actually, the qc and sqc can see the channel id of sqc.
|
||||
* sqc channel's onwer is SQC, not QC.
|
||||
* sqc channel's owner is SQC, not QC.
|
||||
* if we release there, all these channel will be release twice.
|
||||
* So, sqc channel will be release by sqc, not qc.
|
||||
*
|
||||
@ -792,7 +792,7 @@ int ObPxCoordOp::wait_all_running_dfos_exit()
|
||||
if (OB_FAIL(ret)) {
|
||||
} else if (OB_FAIL(loop.process_one_if(&control_channels, nth_channel))) {
|
||||
if (OB_EAGAIN == ret) {
|
||||
LOG_DEBUG("no msessage, waiting sqc report", K(ret));
|
||||
LOG_DEBUG("no message, waiting sqc report", K(ret));
|
||||
ret = OB_SUCCESS;
|
||||
} else if (OB_ITER_END != ret) {
|
||||
LOG_WARN("fail process message", K(ret));
|
||||
|
||||
@ -76,7 +76,7 @@ public:
|
||||
int64_t row_deleted_count_;
|
||||
};
|
||||
|
||||
// keep for compatiablity. never should be used anymore
|
||||
// keep for compatiblity. never should be used anymore
|
||||
class ObPxTaskMonitorInfo
|
||||
{
|
||||
OB_UNIS_VERSION(1);
|
||||
@ -414,7 +414,7 @@ public:
|
||||
int rc_; // 错误码
|
||||
int das_retry_rc_; //record the error code that cause DAS to retry
|
||||
transaction::ObTxExecResult trans_result_;
|
||||
ObPxTaskMonitorInfoArray task_monitor_info_array_; // deprecated, keep for compatiablity
|
||||
ObPxTaskMonitorInfoArray task_monitor_info_array_; // deprecated, keep for compatiblity
|
||||
int64_t sqc_affected_rows_; // pdml情况下,一个sqc 影响的行数
|
||||
ObPxDmlRowInfo dml_row_info_; // SQC存在DML算子时, 需要统计行 信息
|
||||
uint64_t temp_table_id_;
|
||||
|
||||
@ -311,7 +311,7 @@ int ObPxMsgProc::on_sqc_finish_msg(ObExecContext &ctx,
|
||||
if (OB_FAIL(ctx.add_temp_table_interm_result_ids(pkt.temp_table_id_,
|
||||
sqc->get_exec_addr(),
|
||||
pkt.interm_result_ids_))) {
|
||||
LOG_WARN("failed to add temp table interm resuld ids.", K(ret));
|
||||
LOG_WARN("failed to add temp table interm result ids.", K(ret));
|
||||
} else { /*do nothing.*/ }
|
||||
} else { /*do nothing.*/ }
|
||||
if (OB_SUCC(ret)) {
|
||||
|
||||
@ -629,7 +629,7 @@ int ObPxSQCProxy::make_sqc_sample_piece_msg(ObDynamicSamplePieceMsg &msg, bool &
|
||||
int ret = OB_SUCCESS;
|
||||
if (msg.sample_type_ == HEADER_INPUT_SAMPLE && sample_msg_.row_stores_.empty()) {
|
||||
ret = OB_ERR_UNEXPECTED;
|
||||
LOG_WARN("unexpected row sotres", K(ret));
|
||||
LOG_WARN("unexpected row stores", K(ret));
|
||||
} else if (OB_FAIL(sample_msg_.merge_piece_msg(
|
||||
sqc_ctx_.get_task_count(),
|
||||
msg,
|
||||
|
||||
@ -98,7 +98,7 @@ public:
|
||||
ObPxTargetCond() {}
|
||||
~ObPxTargetCond() {}
|
||||
public:
|
||||
// wait when no resource availiable
|
||||
// wait when no resource available
|
||||
int wait(const int64_t wait_time_us);
|
||||
// notify threads to wakeup and retry
|
||||
void notifyAll();
|
||||
|
||||
@ -1187,7 +1187,7 @@ int ObPXServerAddrUtil::reorder_all_partitions(int64_t table_location_key,
|
||||
ObTabletIdxMap tablet_order_map;
|
||||
if (OB_FAIL(dst_locations.reserve(src_locations.size()))) {
|
||||
LOG_WARN("fail reserve locations", K(ret), K(src_locations.size()));
|
||||
// virtual table is list parttion now,
|
||||
// virtual table is list parition now,
|
||||
// no actual partition define, can't traverse
|
||||
// table schema for partition info
|
||||
} else if (!is_virtual_table(ref_table_id) &&
|
||||
@ -1321,7 +1321,7 @@ int ObPXServerAddrUtil::split_parallel_into_task(const int64_t parallel,
|
||||
/// 把剩下的线程安排出去
|
||||
thread_remain = parallel - total_thread_count;
|
||||
if (thread_remain <= 0) {
|
||||
// 这种情况是正常的,paralllel < sqc count的时候就会出现这种情况。
|
||||
// 这种情况是正常的,parallel < sqc count的时候就会出现这种情况。
|
||||
} else if (thread_remain > sqc_task_metas.count()) {
|
||||
ret = OB_ERR_UNEXPECTED;
|
||||
LOG_WARN("Thread remain is invalid", K(ret), K(thread_remain), K(sqc_task_metas.count()));
|
||||
@ -1452,7 +1452,7 @@ int ObPXServerAddrUtil::build_tablet_idx_map(
|
||||
} else if (is_virtual_table(table_schema->get_table_id())) {
|
||||
// In observer 4.2, the table schema of a distributed virtual table will show all_part_num as 1,
|
||||
// whereas in lower versions it would display as 65536.
|
||||
// For a distrubuted virtual table, we may encounter a situation where part_id is 1 in sqc1,
|
||||
// For a distributed virtual table, we may encounter a situation where part_id is 1 in sqc1,
|
||||
// part_id is 2 in sqc2 and so on, but the idx_map only contains one item with key=1.
|
||||
// Hence, if we seek with part_id=2, the idx_map will return -4201 (OB_HASH_NOT_EXIST)
|
||||
// will return -4201(OB_HASH_NOT_EXIST). In such cases, we can directly obtain the value that equals part_id + 1.
|
||||
@ -2886,7 +2886,7 @@ int ObPxEstimateSizeUtil::get_px_size(
|
||||
}
|
||||
}
|
||||
if (ret_size > total_size || OB_FAIL(ret)) {
|
||||
LOG_WARN("unpexpect status: estimate size is greater than total size",
|
||||
LOG_WARN("unexpect status: estimate size is greater than total size",
|
||||
K(ret_size), K(total_size), K(ret));
|
||||
ret_size = total_size;
|
||||
ret = OB_SUCCESS;
|
||||
@ -3224,7 +3224,7 @@ int ObSlaveMapUtil::build_pkey_affinitized_ch_mn_map(ObDfo &parent,
|
||||
LOG_WARN("unexpected dfo", K(ret), K(parent));
|
||||
} else if (ObPQDistributeMethod::PARTITION_HASH == child.get_dist_method()
|
||||
|| ObPQDistributeMethod::PARTITION_RANGE == child.get_dist_method()) {
|
||||
LOG_TRACE("build pkey affinitiezed channel map",
|
||||
LOG_TRACE("build pkey affinitized channel map",
|
||||
K(parent.get_dfo_id()), K(parent.get_sqcs_count()),
|
||||
K(child.get_dfo_id()), K(child.get_sqcs_count()));
|
||||
// .....
|
||||
|
||||
Reference in New Issue
Block a user