From c36014b57e8d6b04d458f690d46b75ffb5ffc890 Mon Sep 17 00:00:00 2001 From: rayzui <1430527996@qq.com> Date: Tue, 15 Jun 2021 14:36:04 +0800 Subject: [PATCH] code: Fix typo of log and variables (#42) --- deps/oblib/src/common/object/ob_object.cpp | 2 +- .../src/lib/bloom_filter/ob_bloomfilter.h | 4 ++-- src/archive/ob_archive_pg_mgr.cpp | 2 +- src/election/ob_election.cpp | 6 +++--- src/election/ob_election.h | 2 +- src/election/ob_election_group.cpp | 4 ++-- ...b_all_virtual_macro_block_marker_status.cpp | 2 +- src/rootserver/ob_root_backup.cpp | 2 +- .../backup/ob_log_archive_backup_info_mgr.cpp | 2 +- .../ob_partition_table_iterator.cpp | 4 ++-- src/share/schema/ob_table_schema.cpp | 2 +- ...partition_base_data_physical_restore_v2.cpp | 18 +++++++++--------- ...b_partition_base_data_physical_restore_v2.h | 2 +- .../blocksstable/ob_block_sstable_struct.cpp | 2 +- .../blocksstable/ob_block_sstable_struct.h | 10 +++++----- .../blocksstable/ob_bloom_filter_cache.cpp | 12 ++++++------ .../ob_bloom_filter_data_reader.cpp | 10 +++++----- .../ob_bloom_filter_data_writer.cpp | 18 +++++++++--------- .../blocksstable/ob_lob_data_reader.cpp | 2 +- .../blocksstable/ob_lob_merge_writer.cpp | 4 ++-- .../blocksstable/ob_macro_block_checker.cpp | 4 ++-- .../blocksstable/ob_macro_block_reader.cpp | 6 +++--- .../blocksstable/ob_meta_block_reader.cpp | 16 ++++++++-------- .../blocksstable/ob_micro_block_index_mgr.cpp | 2 +- .../ob_micro_block_index_transformer.cpp | 6 +++--- .../ob_micro_block_index_writer.cpp | 2 +- .../blocksstable/ob_raid_file_system.cpp | 12 ++++++------ src/storage/blocksstable/ob_row_reader.cpp | 10 +++++----- .../blocksstable/ob_storage_cache_suite.cpp | 2 +- src/storage/blocksstable/ob_store_file.cpp | 2 +- src/storage/compaction/ob_partition_merge.cpp | 10 +++++----- .../compaction/ob_partition_merge_builder.cpp | 14 +++++++------- .../compaction/ob_partition_merge_util.cpp | 6 +++--- src/storage/ob_ms_row_iterator.cpp | 2 +- src/storage/ob_old_sstable.cpp | 4 ++-- ...ob_partition_base_data_physical_restore.cpp | 18 +++++++++--------- .../ob_partition_base_data_physical_restore.h | 10 +++++----- src/storage/ob_partition_merge_task.cpp | 2 +- src/storage/ob_sstable.cpp | 4 ++-- src/storage/ob_sstable_rowkey_helper.cpp | 2 +- src/storage/ob_storage_struct.cpp | 2 +- src/storage/ob_table_store.cpp | 4 ++-- 42 files changed, 125 insertions(+), 125 deletions(-) diff --git a/deps/oblib/src/common/object/ob_object.cpp b/deps/oblib/src/common/object/ob_object.cpp index 3ce8d27a83..8bfc3c94f8 100644 --- a/deps/oblib/src/common/object/ob_object.cpp +++ b/deps/oblib/src/common/object/ob_object.cpp @@ -224,7 +224,7 @@ int ObLobLocator::get_rowid(ObString& rowid) const COMMON_LOG(WARN, "ObLobLocator with compat mode does not support rowid ", K(ret), K(*this)); } else if (payload_offset_ <= 0) { ret = OB_ERR_UNEXPECTED; - COMMON_LOG(WARN, "Unexcepted payload offset to get rowid", K(ret), K(*this)); + COMMON_LOG(WARN, "Unexpected payload offset to get rowid", K(ret), K(*this)); } else { rowid = ObString(payload_offset_, data_); } diff --git a/deps/oblib/src/lib/bloom_filter/ob_bloomfilter.h b/deps/oblib/src/lib/bloom_filter/ob_bloomfilter.h index 0297168009..515609ce1c 100644 --- a/deps/oblib/src/lib/bloom_filter/ob_bloomfilter.h +++ b/deps/oblib/src/lib/bloom_filter/ob_bloomfilter.h @@ -256,7 +256,7 @@ int ObBloomFilter::serialize(char* buf, const int64_t buf_len, int6 if (OB_UNLIKELY(!is_valid())) { ret = OB_ERR_UNEXPECTED; - LIB_LOG(WARN, "Unexcepted invalid bloomfilter to serialize", K_(nhash), K_(nbit), KP_(bits), K(ret)); + LIB_LOG(WARN, "Unexpected invalid bloomfilter to serialize", K_(nhash), K_(nbit), KP_(bits), K(ret)); } else if (OB_UNLIKELY(serialize_size > buf_len - pos)) { ret = OB_SIZE_OVERFLOW; LIB_LOG(WARN, "bloofilter serialize size overflow", K(serialize_size), K(buf_len), K(pos), K(ret)); @@ -309,7 +309,7 @@ int ObBloomFilter::deserialize(const char* buf, const int64_t data_ LIB_LOG(WARN, "Failed to decode bits", K(data_len), K(pos), K(ret)); } else if (nbyte != decode_byte) { ret = OB_ERR_UNEXPECTED; - LIB_LOG(WARN, "Unexcepted bits decode length", K(decode_byte), K(nbyte), K(ret)); + LIB_LOG(WARN, "Unexpected bits decode length", K(decode_byte), K(nbyte), K(ret)); } } } diff --git a/src/archive/ob_archive_pg_mgr.cpp b/src/archive/ob_archive_pg_mgr.cpp index 8de4816104..5e4cd919c8 100644 --- a/src/archive/ob_archive_pg_mgr.cpp +++ b/src/archive/ob_archive_pg_mgr.cpp @@ -756,7 +756,7 @@ int64_t ObArchivePGMgr::thread_index_() } // 1. add pg task if needed -// 2. handle add/delte pg task +// 2. handle add/delete pg task // 3. check if archive round start // 4. delete pg task if needed void ObArchivePGMgr::do_thread_task_() diff --git a/src/election/ob_election.cpp b/src/election/ob_election.cpp index 4295fbcc78..c2c47f599a 100644 --- a/src/election/ob_election.cpp +++ b/src/election/ob_election.cpp @@ -3625,7 +3625,7 @@ int ObElection::post_election_msg_( common::ObAddr server; /**********should removed after a barrier version bigger than 3.1**********/ - insert_pyhsical_condition_into_msg_(msg); + insert_physical_condition_into_msg_(msg); /*************************************************************************************/ if (mlist.get_member_number() <= 0 || !partition.is_valid() || !msg.is_valid()) { ret = OB_INVALID_ARGUMENT; @@ -3658,7 +3658,7 @@ int ObElection::post_election_msg_( const int64_t dst_cluster_id = obrpc::ObRpcNetHandler::CLUSTER_ID; /**********should removed after a barrier version bigger than 3.1**********/ - insert_pyhsical_condition_into_msg_(msg); + insert_physical_condition_into_msg_(msg); /*************************************************************************************/ if (!server.is_valid() || !partition.is_valid() || !msg.is_valid() || self_ == server) { ret = OB_INVALID_ARGUMENT; @@ -3786,7 +3786,7 @@ int64_t ObElection::logic_ts_(int64_t real_ts) const } /**********should removed after a barrier version bigger than 3.1**********/ -void ObElection::insert_pyhsical_condition_into_msg_(const ObElectionMsg& msg) +void ObElection::insert_physical_condition_into_msg_(const ObElectionMsg& msg) { if (OB_SYS_TENANT_ID != extract_tenant_id(partition_.get_table_id())) { int64_t send_timestamp = msg.get_send_timestamp(); diff --git a/src/election/ob_election.h b/src/election/ob_election.h index 1792d9da0f..c2248fdff1 100644 --- a/src/election/ob_election.h +++ b/src/election/ob_election.h @@ -426,7 +426,7 @@ class ObElection : public ObIElection, public ObIElectionTimerP, public ObElecti PhysicalCondition physical_condition_; int64_t temp_election_time_offset_; void register_gt1_with_neccessary_retry_(int64_t next_expect_ts); - void insert_pyhsical_condition_into_msg_(const ObElectionMsg&); + void insert_physical_condition_into_msg_(const ObElectionMsg&); PhysicalCondition fetch_others_condition_(const ObElectionMsg&); bool update_condition_(const ObElectionMsg&, const int64_t); /***************************************************************/ diff --git a/src/election/ob_election_group.cpp b/src/election/ob_election_group.cpp index 373ede3a68..7d64af78e5 100644 --- a/src/election/ob_election_group.cpp +++ b/src/election/ob_election_group.cpp @@ -1841,7 +1841,7 @@ void ObElectionGroup::run_gt1_task(const int64_t expect_ts) } // avoid print error log while election run at start if (cur_ts > start_timestamp_ + (vote_period_ + T_CYCLE_EXTEND_MORE) * T_ELECT2) { - // pirnt error log only if leader group's lease expired + // print error log only if leader group's lease expired if (old_leader == self_ && partition_array_.count() > 0 && !is_all_dropped) { ELECT_ASYNC_LOG_(ERROR, "eg leader lease is expired", K(*this), K(old_leader), K(is_all_dropped)); } else { @@ -1868,7 +1868,7 @@ void ObElectionGroup::run_gt1_task(const int64_t expect_ts) } else if (!is_candidate_(self_)) { FORCE_ELECT_LOG(WARN, "self is not candidate", "self", *this); } else if (is_pre_destroy_state()) { - // must not do reappoint if group if pre-destoryed + // must not do reappoint if group if pre-destroyed ELECT_ASYNC_LOG(INFO, "in pre_destroy_state, give up reappoint", "self", *this); } else if (is_empty_()) { FORCE_ELECT_LOG(WARN, "self is empty, no need to reappoint", K(ret), "self", *this); diff --git a/src/observer/virtual_table/ob_all_virtual_macro_block_marker_status.cpp b/src/observer/virtual_table/ob_all_virtual_macro_block_marker_status.cpp index ba0d4ec3c1..93444e9df5 100644 --- a/src/observer/virtual_table/ob_all_virtual_macro_block_marker_status.cpp +++ b/src/observer/virtual_table/ob_all_virtual_macro_block_marker_status.cpp @@ -115,7 +115,7 @@ int ObAllVirtualMacroBlockMarkerStatus::inner_get_next_row(common::ObNewRow*& ro } case OB_APP_MIN_COLUMN_ID + 10: { // bloomfilter_count_ - cur_row_.cells_[i].set_int(marker_status_.bloomfiter_count_); + cur_row_.cells_[i].set_int(marker_status_.bloomfilter_count_); break; } case OB_APP_MIN_COLUMN_ID + 11: { diff --git a/src/rootserver/ob_root_backup.cpp b/src/rootserver/ob_root_backup.cpp index 234a289052..26536a42ed 100644 --- a/src/rootserver/ob_root_backup.cpp +++ b/src/rootserver/ob_root_backup.cpp @@ -2589,7 +2589,7 @@ int ObTenantBackup::generate_tablegroup_backup_task(const share::ObTenantBackupT if (OB_FAIL(ret)) { } else if (OB_FAIL(ObBackupUtils::retry_get_tenant_schema_guard( task_info.tenant_id_, *schema_service_, backup_schema_version_, schema_guard))) { - LOG_WARN("failed to get tenant schema gaurd", K(ret), K(task_info)); + LOG_WARN("failed to get tenant schema guard", K(ret), K(task_info)); } else if (OB_FAIL(schema_guard.get_tablegroup_ids_in_tenant(task_info.tenant_id_, tablegroup_ids))) { LOG_WARN("fail to get tablegroup ids", K(ret)); } else if (OB_FAIL(find_break_table_id_index(tablegroup_ids, point_info, table_id_index))) { diff --git a/src/share/backup/ob_log_archive_backup_info_mgr.cpp b/src/share/backup/ob_log_archive_backup_info_mgr.cpp index 7f492e8d52..15ccd2a24f 100644 --- a/src/share/backup/ob_log_archive_backup_info_mgr.cpp +++ b/src/share/backup/ob_log_archive_backup_info_mgr.cpp @@ -1091,7 +1091,7 @@ int ObLogArchiveBackupInfoMgr::delete_marked_extern_log_archive_backup_info( if (!cluster_backup_dest.is_valid() || OB_INVALID_ID == tenant_id) { ret = OB_INVALID_ARGUMENT; - LOG_WARN("delte marked extern log archive backup info get invalid argument", + LOG_WARN("delete marked extern log archive backup info get invalid argument", K(ret), K(cluster_backup_dest), K(tenant_id)); diff --git a/src/share/partition_table/ob_partition_table_iterator.cpp b/src/share/partition_table/ob_partition_table_iterator.cpp index 908f94c48c..1d0b227311 100644 --- a/src/share/partition_table/ob_partition_table_iterator.cpp +++ b/src/share/partition_table/ob_partition_table_iterator.cpp @@ -1070,7 +1070,7 @@ int ObPartitionTableIdIterator::get_part_num(const uint64_t table_id, int64_t& p ret = OB_INVALID_ARGUMENT; LOG_WARN("invalid table_id", KT(table_id), K(ret)); } else if (OB_FAIL(schema_service_->get_tenant_schema_guard(tenant_id, guard))) { - LOG_WARN("get_schema_gaurd failed", K(ret)); + LOG_WARN("get_schema_guard failed", K(ret)); } else if (OB_FAIL(guard.get_table_schema(table_id, table))) { LOG_WARN("fail to get table schema", K(ret), K(table_id)); } else if (NULL == table) { @@ -1315,7 +1315,7 @@ int ObFullMetaTableIterator::get_part_num(const uint64_t table_id, int64_t& part ret = OB_INVALID_ARGUMENT; LOG_WARN("invalid table_id", KT(table_id), K(ret)); } else if (OB_FAIL(schema_service_->get_tenant_schema_guard(tenant_id, guard))) { - LOG_WARN("get_schema_gaurd failed", K(ret)); + LOG_WARN("get_schema_guard failed", K(ret)); } else if (OB_FAIL(guard.get_table_schema(table_id, table))) { LOG_WARN("fail to get table schema", K(ret), K(table_id)); } else if (NULL == table) { diff --git a/src/share/schema/ob_table_schema.cpp b/src/share/schema/ob_table_schema.cpp index 0069afecfe..47ab632b58 100644 --- a/src/share/schema/ob_table_schema.cpp +++ b/src/share/schema/ob_table_schema.cpp @@ -1927,7 +1927,7 @@ bool ObTableSchema::is_valid() const if (is_virtual_table(table_id_) && 0 > rowkey_column_num_) { valid_ret = false; LOG_WARN("invalid rowkey_column_num:", K_(table_name), K_(rowkey_column_num)); - // TODO:() confirm to delte it + // TODO:() confirm to delete it } else if (!is_virtual_table(table_id_) && 1 > rowkey_column_num_ && OB_INVALID_ID == dblink_id_) { valid_ret = false; LOG_WARN("no primary key specified:", K_(table_name)); diff --git a/src/storage/backup/ob_partition_base_data_physical_restore_v2.cpp b/src/storage/backup/ob_partition_base_data_physical_restore_v2.cpp index 55095c0f2f..1768cd4229 100644 --- a/src/storage/backup/ob_partition_base_data_physical_restore_v2.cpp +++ b/src/storage/backup/ob_partition_base_data_physical_restore_v2.cpp @@ -426,7 +426,7 @@ int ObPartitionBaseDataMetaRestoreReaderV2::do_filter_tables(ObIArray& STORAGE_LOG(WARN, "not inited", K(ret)); } else if (OB_FAIL(ObBackupUtils::retry_get_tenant_schema_guard( tenant_id, schema_service, schema_version_, schema_guard))) { - STORAGE_LOG(WARN, "failed to get tenant schema gaurd", K(ret), K(pkey_), K(schema_version_)); + STORAGE_LOG(WARN, "failed to get tenant schema guard", K(ret), K(pkey_), K(schema_version_)); } else { bool is_exist = false; for (int i = 0; OB_SUCC(ret) && i < table_ids.count(); ++i) { @@ -1153,7 +1153,7 @@ int ObPartitionGroupMetaRestoreReaderV2::check_backup_partitions_in_pg( // do nothing } else if (OB_FAIL(ObBackupUtils::retry_get_tenant_schema_guard( tenant_id, schema_service, schema_version_, schema_guard))) { - STORAGE_LOG(WARN, "failed to get tenant schema gaurd", K(ret), K(restore_info), K(backup_pg_meta)); + STORAGE_LOG(WARN, "failed to get tenant schema guard", K(ret), K(restore_info), K(backup_pg_meta)); } else if (!restore_info.pg_key_.is_pg()) { if (OB_FAIL(table_ids.push_back(restore_info.pg_key_.get_table_id()))) { STORAGE_LOG(WARN, "failed to push table id into array", K(ret), K(restore_info)); @@ -1329,7 +1329,7 @@ int ObPartitionGroupMetaRestoreReaderV2::do_filter_pg_partitions(const ObPGKey& STORAGE_LOG(WARN, "do filter pg partitions get invalid argument", K(ret), K(pg_key)); } else if (OB_FAIL(ObBackupUtils::retry_get_tenant_schema_guard( pg_key.get_tenant_id(), schema_service, schema_version_, schema_guard))) { - STORAGE_LOG(WARN, "failed to get tenant schema gaurd", K(ret), K(pg_key), K(schema_version_)); + STORAGE_LOG(WARN, "failed to get tenant schema guard", K(ret), K(pg_key), K(schema_version_)); } else { bool is_exist = false; bool filtered = false; @@ -1346,7 +1346,7 @@ int ObPartitionGroupMetaRestoreReaderV2::do_filter_pg_partitions(const ObPGKey& if (OB_FAIL(ret)) { } else if (is_exist) { if (OB_FAIL(exist_partitions.push_back(pkey))) { - STORAGE_LOG(WARN, "pusk back partition failed", K(ret), K(pkey)); + STORAGE_LOG(WARN, "push back partition failed", K(ret), K(pkey)); } } else { filtered = true; @@ -1475,7 +1475,7 @@ int ObPGPartitionBaseDataMetaRestoreReaderV2::check_sstable_table_ids_in_table( STORAGE_LOG(WARN, "failed to create table ids set", K(ret)); } else if (OB_FAIL(ObBackupUtils::retry_get_tenant_schema_guard( tenant_id, schema_service, schema_version_, schema_guard))) { - STORAGE_LOG(WARN, "failed to get tenant schema gaurd", K(ret), K(tenant_id), K(schema_version_)); + STORAGE_LOG(WARN, "failed to get tenant schema guard", K(ret), K(tenant_id), K(schema_version_)); } else if (OB_FAIL(schema_guard.get_index_status(data_table_id, false /*with global index*/, index_stats))) { STORAGE_LOG(WARN, "failed to get index status", K(ret), K(data_table_id)); } else { @@ -1579,10 +1579,10 @@ int ObPhyRestoreMacroIndexStoreV2::init( common::ObPartitionKey pkey; if (is_inited_) { ret = OB_INIT_TWICE; - STORAGE_LOG(WARN, "physcial restore macro index store init twice", K(ret)); + STORAGE_LOG(WARN, "physical restore macro index store init twice", K(ret)); } else if (backup_task_id < 0 || OB_UNLIKELY(!arg.is_valid())) { ret = OB_INVALID_ARGUMENT; - STORAGE_LOG(WARN, "init physcial restore macro index get invalid argument", K(ret), K(backup_task_id), K(arg)); + STORAGE_LOG(WARN, "init physical restore macro index get invalid argument", K(ret), K(backup_task_id), K(arg)); } else if (OB_FAIL(arg.get_backup_base_data_info(path_info))) { STORAGE_LOG(WARN, "get backup base data info fail", K(ret)); } else if (OB_FAIL(arg.get_backup_pgkey(pkey))) { @@ -1701,11 +1701,11 @@ int ObPhyRestoreMacroIndexStoreV2::init(const int64_t backup_task_id, const comm if (is_inited_) { ret = OB_INIT_TWICE; - STORAGE_LOG(WARN, "physcial restore macro index store init twice", K(ret)); + STORAGE_LOG(WARN, "physical restore macro index store init twice", K(ret)); } else if (backup_task_id < 0 || !pkey.is_valid() || OB_UNLIKELY(!arg.is_valid()) || !backup_data_type.is_valid()) { ret = OB_INVALID_ARGUMENT; STORAGE_LOG(WARN, - "init physcial restore macro index get invalid argument", + "init physical restore macro index get invalid argument", K(ret), K(backup_task_id), K(pkey), diff --git a/src/storage/backup/ob_partition_base_data_physical_restore_v2.h b/src/storage/backup/ob_partition_base_data_physical_restore_v2.h index e9de30e4bc..8e864638bb 100644 --- a/src/storage/backup/ob_partition_base_data_physical_restore_v2.h +++ b/src/storage/backup/ob_partition_base_data_physical_restore_v2.h @@ -222,7 +222,7 @@ class ObPartitionGroupMetaRestoreReaderV2 : public ObIPartitionGroupMetaRestoreR bool is_inited_; const ObPhysicalRestoreArg* restore_info_; const ObPhyRestoreMetaIndexStore* meta_indexs_; - ObPGMetaPyhsicalReader reader_; + ObPGMetaPhysicalReader reader_; ObPartitionGroupMeta pg_meta_; common::ObInOutBandwidthThrottle* bandwidth_throttle_; int64_t last_read_size_; diff --git a/src/storage/blocksstable/ob_block_sstable_struct.cpp b/src/storage/blocksstable/ob_block_sstable_struct.cpp index 4586e6e3c8..b455124b37 100644 --- a/src/storage/blocksstable/ob_block_sstable_struct.cpp +++ b/src/storage/blocksstable/ob_block_sstable_struct.cpp @@ -2719,7 +2719,7 @@ void ObMacroBlockMarkerStatus::reuse() lob_data_block_count_ = 0; second_index_count_ = 0; lob_second_index_count_ = 0; - bloomfiter_count_ = 0; + bloomfilter_count_ = 0; hold_count_ = 0; pending_free_count_ = 0; free_count_ = 0; diff --git a/src/storage/blocksstable/ob_block_sstable_struct.h b/src/storage/blocksstable/ob_block_sstable_struct.h index f59da5d8a0..2ce9b939da 100644 --- a/src/storage/blocksstable/ob_block_sstable_struct.h +++ b/src/storage/blocksstable/ob_block_sstable_struct.h @@ -709,10 +709,10 @@ struct ObMacroBlockMeta { // default 0 int32_t row_count_delta_; - int32_t micro_block_mark_deletion_offset_; // micro_block_mark_deletion_size = delte_offset - + int32_t micro_block_mark_deletion_offset_; // micro_block_mark_deletion_size = delete_offset - // micro_block_mark_deletion_offset_ bool macro_block_deletion_flag_; - int32_t micro_block_delta_offset_; // delte_size = occupy_size - micro_block_delta_offset; + int32_t micro_block_delta_offset_; // delta_size = occupy_size - micro_block_delta_offset; int64_t partition_id_; // added since 2.0 int16_t column_checksum_method_; // 0 for unkown, 1 for ObObj::checksum(), 2 for ObObj::checksum_v2() int64_t progressive_merge_round_; @@ -1377,7 +1377,7 @@ struct ObMacroBlockMarkerStatus { int64_t lob_data_block_count_; int64_t second_index_count_; int64_t lob_second_index_count_; - int64_t bloomfiter_count_; + int64_t bloomfilter_count_; int64_t hold_count_; int64_t pending_free_count_; int64_t free_count_; @@ -1757,10 +1757,10 @@ struct ObMacroBlockMetaV2 final { // default 0 int32_t row_count_delta_; - int32_t micro_block_mark_deletion_offset_; // micro_block_mark_deletion_size = delte_offset - + int32_t micro_block_mark_deletion_offset_; // micro_block_mark_deletion_size = delete_offset - // micro_block_mark_deletion_offset_ bool macro_block_deletion_flag_; - int32_t micro_block_delta_offset_; // delte_size = occupy_size - micro_block_delta_offset; + int32_t micro_block_delta_offset_; // delta_size = occupy_size - micro_block_delta_offset; int64_t partition_id_; // added since 2.0 int16_t column_checksum_method_; // 0 for unkown, 1 for ObObj::checksum(), 2 for ObObj::checksum_v2() int64_t progressive_merge_round_; diff --git a/src/storage/blocksstable/ob_bloom_filter_cache.cpp b/src/storage/blocksstable/ob_bloom_filter_cache.cpp index 30154f938e..b46a9d8d0d 100644 --- a/src/storage/blocksstable/ob_bloom_filter_cache.cpp +++ b/src/storage/blocksstable/ob_bloom_filter_cache.cpp @@ -250,14 +250,14 @@ int ObBloomFilterCacheValue::merge_bloom_filter(const ObBloomFilterCacheValue& b if (OB_UNLIKELY(!is_valid())) { ret = OB_NOT_INIT; - STORAGE_LOG(WARN, "Unexcepted invalid bloomfilter to merge", K_(rowkey_column_cnt), K_(is_inited), K(ret)); + STORAGE_LOG(WARN, "Unexpected invalid bloomfilter to merge", K_(rowkey_column_cnt), K_(is_inited), K(ret)); } else if (OB_UNLIKELY(!bf_cache_value.is_valid())) { ret = OB_INVALID_ARGUMENT; STORAGE_LOG(WARN, "Invalid bloomfilter cache to merge", K(ret)); } else if (OB_UNLIKELY(!could_merge_bloom_filter(bf_cache_value))) { ret = OB_ERR_UNEXPECTED; STORAGE_LOG(WARN, - "Unexcepted bloomfitler cache to merge", + "Unexpected bloomfilter cache to merge", K(bf_cache_value), K_(rowkey_column_cnt), K_(bloom_filter), @@ -283,7 +283,7 @@ DEFINE_SERIALIZE(ObBloomFilterCacheValue) if (OB_UNLIKELY(!is_valid())) { ret = OB_NOT_INIT; STORAGE_LOG( - WARN, "Unexcepted invalid bloomfilter cache to serialize", K_(rowkey_column_cnt), K_(is_inited), K(ret)); + WARN, "Unexpected invalid bloomfilter cache to serialize", K_(rowkey_column_cnt), K_(is_inited), K(ret)); } else if (OB_UNLIKELY(serialize_size > buf_len - pos)) { ret = OB_SIZE_OVERFLOW; STORAGE_LOG(WARN, "bloofilter cache serialize size overflow", K(serialize_size), K(buf_len), K(pos), K(ret)); @@ -629,7 +629,7 @@ int ObMacroBloomFilterCacheWriter::append(const storage::ObStoreRow& row) STORAGE_LOG(WARN, "ObBloomFilterDataWriter not init", K(ret)); } else if (OB_UNLIKELY(!row.is_valid() || row.row_val_.count_ < get_rowkey_column_count())) { ret = OB_INVALID_ARGUMENT; - STORAGE_LOG(WARN, "Invalid row to append to bloomfitler", K(row), K_(bf_cache_value), K(ret)); + STORAGE_LOG(WARN, "Invalid row to append to bloomfilter", K(row), K_(bf_cache_value), K(ret)); } else if (get_row_count() >= max_row_count_) { ret = OB_NOT_SUPPORTED; STORAGE_LOG(INFO, "Bloomfilter is full, ", K_(max_row_count), K_(bf_cache_value)); @@ -648,7 +648,7 @@ int ObMacroBloomFilterCacheWriter::append(const ObStoreRowkey& rowkey) STORAGE_LOG(WARN, "ObBloomFilterDataWriter not init", K(ret)); } else if (OB_UNLIKELY(!rowkey.is_valid())) { ret = OB_INVALID_ARGUMENT; - STORAGE_LOG(WARN, "Invalid rowkey to append to bloomfitler", K(rowkey), K(ret)); + STORAGE_LOG(WARN, "Invalid rowkey to append to bloomfilter", K(rowkey), K(ret)); } else if (OB_UNLIKELY(get_rowkey_column_count() != rowkey.get_obj_cnt())) { ret = OB_NOT_SUPPORTED; STORAGE_LOG(WARN, "Rowkey count count is not same, ", K_(bf_cache_value), K(rowkey), K(ret)); @@ -656,7 +656,7 @@ int ObMacroBloomFilterCacheWriter::append(const ObStoreRowkey& rowkey) ret = OB_NOT_SUPPORTED; STORAGE_LOG(INFO, "Too many row for bloomfilter", K_(bf_cache_value)); } else if (OB_FAIL(bf_cache_value_.insert(rowkey))) { - STORAGE_LOG(WARN, "Failed to insert rowkey to bloomfitler cache", K(rowkey), K(ret)); + STORAGE_LOG(WARN, "Failed to insert rowkey to bloomfilter cache", K(rowkey), K(ret)); } return ret; } diff --git a/src/storage/blocksstable/ob_bloom_filter_data_reader.cpp b/src/storage/blocksstable/ob_bloom_filter_data_reader.cpp index 5a859fd384..2cc8f5b89e 100644 --- a/src/storage/blocksstable/ob_bloom_filter_data_reader.cpp +++ b/src/storage/blocksstable/ob_bloom_filter_data_reader.cpp @@ -69,11 +69,11 @@ int ObBloomFilterMacroBlockReader::check_macro_meta(const ObFullMacroBlockMeta& STORAGE_LOG(WARN, "Invalid macro meta", K(macro_meta), K(ret)); } else if (macro_meta->attr_ != ObMacroBlockCommonHeader::BloomFilterData) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted macro meta type", K(macro_meta), K(ret)); + STORAGE_LOG(WARN, "Unexpected macro meta type", K(macro_meta), K(ret)); } else if (macro_meta->column_number_ != 0 || macro_meta->rowkey_column_number_ <= 0 || macro_meta->row_count_ <= 0 || macro_meta->micro_block_count_ != 1 || macro_meta->micro_block_data_offset_ <= 0) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted macro meta for bloomfilter", K(*macro_meta), K(ret)); + STORAGE_LOG(WARN, "Unexpected macro meta for bloomfilter", K(*macro_meta), K(ret)); } return ret; @@ -116,7 +116,7 @@ int ObBloomFilterMacroBlockReader::decompress_micro_block( STORAGE_LOG(WARN, "invalid arguments", K(ret), K(full_meta)); } else if (OB_ISNULL(macro_handle_.get_buffer()) || 0 == macro_meta->micro_block_data_offset_) { ret = OB_INVALID_ARGUMENT; - STORAGE_LOG(WARN, "Unexcepted null data buffer", K(ret)); + STORAGE_LOG(WARN, "Unexpected null data buffer", K(ret)); } else if (FALSE_IT(data_buffer = macro_handle_.get_buffer() + macro_meta->micro_block_data_offset_)) { } else { const int64_t data_size = macro_meta->micro_block_index_offset_ - macro_meta->micro_block_data_offset_; @@ -144,7 +144,7 @@ int ObBloomFilterMacroBlockReader::read_micro_block( const ObBloomFilterMicroBlockHeader* bf_micro_header = reinterpret_cast(buf); if (OB_UNLIKELY(!bf_micro_header->is_valid())) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted bloomfilter micro block header", K(*bf_micro_header), K(ret)); + STORAGE_LOG(WARN, "Unexpected bloomfilter micro block header", K(*bf_micro_header), K(ret)); } else { bf_buf = buf + bf_micro_header->header_size_; bf_size = buf_size - bf_micro_header->header_size_; @@ -180,7 +180,7 @@ int ObBloomFilterDataReader::read_bloom_filter( STORAGE_LOG(WARN, "Failed to deserialize bloomfilter cache", K(ret)); } else if (OB_UNLIKELY(!bf_cache_value.is_valid())) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted invalid bloomfilter cache", K(bf_cache_value), K(ret)); + STORAGE_LOG(WARN, "Unexpected invalid bloomfilter cache", K(bf_cache_value), K(ret)); } bf_macro_reader_.reset(); diff --git a/src/storage/blocksstable/ob_bloom_filter_data_writer.cpp b/src/storage/blocksstable/ob_bloom_filter_data_writer.cpp index cafd7fe84f..151c655df0 100644 --- a/src/storage/blocksstable/ob_bloom_filter_data_writer.cpp +++ b/src/storage/blocksstable/ob_bloom_filter_data_writer.cpp @@ -299,7 +299,7 @@ int ObBloomFilterMacroBlockWriter::init_headers(const int64_t row_count) STORAGE_LOG(WARN, "Invalid argument to init bloomfilter headers", K(row_count), K(ret)); } else if (OB_UNLIKELY(data_buffer_.pos() > 0)) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted init data buffer to init header", K_(data_buffer), K(ret)); + STORAGE_LOG(WARN, "Unexpected init data buffer to init header", K_(data_buffer), K(ret)); } else { int64_t common_header_size = common_header_.get_serialize_size(); int64_t bf_macro_header_size = sizeof(ObBloomFilterMacroBlockHeader); @@ -479,7 +479,7 @@ int ObBloomFilterDataWriter::init(const ObDataStoreDesc& desc) } else if (bf_cache_value_.get_serialize_size() > desc.macro_block_size_) { ret = OB_ERR_UNEXPECTED; STORAGE_LOG( - WARN, "Unexcepted large bloomfilter rowcount or small macro block size", K(desc), K_(bf_cache_value), K(ret)); + WARN, "Unexpected large bloomfilter rowcount or small macro block size", K(desc), K_(bf_cache_value), K(ret)); } else if (OB_FAIL(bf_macro_writer_.init(desc))) { STORAGE_LOG(WARN, "Failed to init bloomfilter macro block writer", K(desc), K(ret)); } else if (OB_FAIL(file_handle_.assign(desc.file_handle_))) { @@ -501,7 +501,7 @@ int ObBloomFilterDataWriter::append(const storage::ObStoreRow& row) STORAGE_LOG(WARN, "ObBloomFilterDataWriter not init", K(ret)); } else if (OB_UNLIKELY(!row.is_valid() || row.row_val_.count_ < rowkey_column_count_)) { ret = OB_INVALID_ARGUMENT; - STORAGE_LOG(WARN, "Invalid row to append to bloomfitler", K(row), K(ret)); + STORAGE_LOG(WARN, "Invalid row to append to bloomfilter", K(row), K(ret)); } else if (get_row_count() >= BLOOM_FILTER_MAX_ROW_COUNT) { ret = OB_NOT_SUPPORTED; STORAGE_LOG(INFO, "Too many row for bloomfilter", K_(bf_cache_value)); @@ -521,15 +521,15 @@ int ObBloomFilterDataWriter::append(const ObStoreRowkey& rowkey) STORAGE_LOG(WARN, "ObBloomFilterDataWriter not init", K(ret)); } else if (OB_UNLIKELY(!rowkey.is_valid())) { ret = OB_INVALID_ARGUMENT; - STORAGE_LOG(WARN, "Invalid rowkey to append to bloomfitler", K(rowkey), K(ret)); + STORAGE_LOG(WARN, "Invalid rowkey to append to bloomfilter", K(rowkey), K(ret)); } else if (OB_UNLIKELY(rowkey_column_count_ != rowkey.get_obj_cnt())) { ret = OB_NOT_SUPPORTED; - STORAGE_LOG(INFO, "Different rowkey count to append to bloomfitler", K_(rowkey_column_count), K(rowkey), K(ret)); + STORAGE_LOG(INFO, "Different rowkey count to append to bloomfilter", K_(rowkey_column_count), K(rowkey), K(ret)); } else if (get_row_count() >= BLOOM_FILTER_MAX_ROW_COUNT) { ret = OB_NOT_SUPPORTED; STORAGE_LOG(INFO, "Too many row for bloomfilter", K_(bf_cache_value)); } else if (OB_FAIL(bf_cache_value_.insert(rowkey))) { - STORAGE_LOG(WARN, "Failed to insert rowkey to bloomfitler cache", K(rowkey), K(ret)); + STORAGE_LOG(WARN, "Failed to insert rowkey to bloomfilter cache", K(rowkey), K(ret)); } return ret; @@ -544,10 +544,10 @@ int ObBloomFilterDataWriter::append(const ObBloomFilterCacheValue& bf_cache_valu STORAGE_LOG(WARN, "ObBloomFilterDataWriter not init", K(ret)); } else if (OB_UNLIKELY(!bf_cache_value.is_valid())) { ret = OB_INVALID_ARGUMENT; - STORAGE_LOG(WARN, "Invalid rowkey to append to bloomfitler", K(bf_cache_value), K(ret)); + STORAGE_LOG(WARN, "Invalid rowkey to append to bloomfilter", K(bf_cache_value), K(ret)); } else if (OB_UNLIKELY(rowkey_column_count_ != bf_cache_value.get_prefix_len())) { ret = OB_NOT_SUPPORTED; - STORAGE_LOG(INFO, "Different rowkey count to append to bloomfitler", K_(rowkey_column_count), K(bf_cache_value)); + STORAGE_LOG(INFO, "Different rowkey count to append to bloomfilter", K_(rowkey_column_count), K(bf_cache_value)); } else if (get_row_count() + bf_cache_value.get_row_count() > BLOOM_FILTER_MAX_ROW_COUNT) { ret = OB_NOT_SUPPORTED; STORAGE_LOG(INFO, "Too many row for bloomfilter", K_(bf_cache_value), K(bf_cache_value)); @@ -570,7 +570,7 @@ int ObBloomFilterDataWriter::flush_bloom_filter() STORAGE_LOG(WARN, "ObBloomFilterDataWriter not init", K(ret)); } else if (OB_UNLIKELY(!bf_cache_value_.is_valid() || bf_cache_value_.is_empty())) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted bloomfitler cache value to flush", K_(bf_cache_value), K(ret)); + STORAGE_LOG(WARN, "Unexpected bloomfilter cache value to flush", K_(bf_cache_value), K(ret)); } else if (OB_FAIL(bf_macro_writer_.write(bf_cache_value_))) { STORAGE_LOG(WARN, "Failed to write bloomfilter cache value to macro block", K(ret)); } else { diff --git a/src/storage/blocksstable/ob_lob_data_reader.cpp b/src/storage/blocksstable/ob_lob_data_reader.cpp index 8e2919b191..fef6a6dbc5 100644 --- a/src/storage/blocksstable/ob_lob_data_reader.cpp +++ b/src/storage/blocksstable/ob_lob_data_reader.cpp @@ -523,7 +523,7 @@ int ObLobDataReader::read_all_direct_index(const ObLobIndex& index, ObIArrayget_meta(block_id, full_meta))) { - LOG_WARN("fail to get meata", K(ret)); + LOG_WARN("fail to get meta", K(ret)); } else if (OB_UNLIKELY(!full_meta.is_valid())) { ret = OB_ERR_SYS; LOG_WARN("ObMacroBlockMeta is not valid", K(ret)); diff --git a/src/storage/blocksstable/ob_lob_merge_writer.cpp b/src/storage/blocksstable/ob_lob_merge_writer.cpp index 1760db1bfd..a4c0acddca 100644 --- a/src/storage/blocksstable/ob_lob_merge_writer.cpp +++ b/src/storage/blocksstable/ob_lob_merge_writer.cpp @@ -160,7 +160,7 @@ int ObLobMergeWriter::find_cand_lob_cols(const ObStoreRow& row, ObIArray 0) { ret = OB_ERR_UNEXPECTED; STORAGE_LOG(WARN, - "Unexcepted row which has no more lob column to reduce row size", + "Unexpected row which has no more lob column to reduce row size", K(row_size), K(overflow_size), K(ret)); @@ -211,7 +211,7 @@ int ObLobMergeWriter::overflow_lob_objs(const ObStoreRow& row, const ObStoreRow* } else if (lob_col_idxs.count() <= 0) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted row which has nomore lob column to reduce row size", K(store_row_length), K(ret)); + STORAGE_LOG(WARN, "Unexpected row which has nomore lob column to reduce row size", K(store_row_length), K(ret)); } else if (OB_FAIL(copy_row_(row))) { LOG_WARN("failed to copy row", K(ret), K(row)); } else { diff --git a/src/storage/blocksstable/ob_macro_block_checker.cpp b/src/storage/blocksstable/ob_macro_block_checker.cpp index 36929ce12e..1d31698958 100644 --- a/src/storage/blocksstable/ob_macro_block_checker.cpp +++ b/src/storage/blocksstable/ob_macro_block_checker.cpp @@ -256,7 +256,7 @@ int ObSSTableMacroBlockChecker::check_lob_block( while (OB_SUCC(ret) && OB_SUCC(micro_index_reader.get_next_index_item(index_item))) { if (meta.meta_->micro_block_data_offset_ + index_item.offset_ + index_item.data_size_ > macro_block_buf_size) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted lob micro block", K(index_item), K(macro_block_buf_size), K(meta), K(ret)); + STORAGE_LOG(WARN, "Unexpected lob micro block", K(index_item), K(macro_block_buf_size), K(meta), K(ret)); } else if (OB_FAIL(record_header.deserialize(data_buf + index_item.offset_, index_item.data_size_, pos))) { STORAGE_LOG(WARN, "fail to deserialize record header", K(ret)); } else if (OB_FAIL(record_header.check_record( @@ -426,7 +426,7 @@ int ObSSTableMacroBlockChecker::check_micro_data( STORAGE_LOG(WARN, "fail to get row", K(ret), K(iter)); } else if (row.row_val_.count_ != meta.meta_->column_number_) { ret = OB_INVALID_DATA; - STORAGE_LOG(WARN, "column numbler not match", K(ret)); + STORAGE_LOG(WARN, "column number not match", K(ret)); } else { for (int64_t i = 0; i < meta.meta_->column_number_; ++i) { if (meta.meta_->column_checksum_method_ == CCM_TYPE_AND_VALUE) { diff --git a/src/storage/blocksstable/ob_macro_block_reader.cpp b/src/storage/blocksstable/ob_macro_block_reader.cpp index 7eb82543cd..9b60f425fb 100644 --- a/src/storage/blocksstable/ob_macro_block_reader.cpp +++ b/src/storage/blocksstable/ob_macro_block_reader.cpp @@ -343,7 +343,7 @@ int ObSSTableDataBlockReader::dump_sstable_data_block() STORAGE_LOG(ERROR, "failed to get micro block data", K(ret)); } else if (OB_UNLIKELY(!micro_data.is_valid())) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted micro data", K(micro_data), K(ret)); + STORAGE_LOG(WARN, "Unexpected micro data", K(micro_data), K(ret)); } else if (OB_FAIL(dump_sstable_micro_header(micro_data.get_buf(), macro_loader.get_micro_index()))) { STORAGE_LOG(ERROR, "Failed to dump sstble micro block header", K(ret)); } else if (OB_FAIL(dump_sstable_micro_data(micro_data))) { @@ -453,7 +453,7 @@ int ObSSTableDataBlockReader::dump_lob_data_block() STORAGE_LOG(WARN, "Failed to decompress lob micro block data", K(ret)); } else if (OB_UNLIKELY(!micro_data.is_valid())) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted micro data", K(micro_data), K(ret)); + STORAGE_LOG(WARN, "Unexpected micro data", K(micro_data), K(ret)); } else { const ObLobMicroBlockHeader* header = reinterpret_cast(micro_data.get_buf()); ObSSTablePrinter::print_lob_micro_header(header); @@ -489,7 +489,7 @@ int ObSSTableDataBlockReader::dump_bloom_filter_data_block() STORAGE_LOG(WARN, "Failed to decompress bloom filter micro block data", K(ret)); } else if (OB_UNLIKELY(!micro_data.is_valid())) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted micro data", K(micro_data), K(ret)); + STORAGE_LOG(WARN, "Unexpected micro data", K(micro_data), K(ret)); } else { const ObBloomFilterMicroBlockHeader* header = reinterpret_cast(micro_data.get_buf()); diff --git a/src/storage/blocksstable/ob_meta_block_reader.cpp b/src/storage/blocksstable/ob_meta_block_reader.cpp index b3629d351d..be6314d6de 100644 --- a/src/storage/blocksstable/ob_meta_block_reader.cpp +++ b/src/storage/blocksstable/ob_meta_block_reader.cpp @@ -157,11 +157,11 @@ int ObMetaBlockReader::get_meta_blocks(const int64_t entry_block) int64_t cur_pos = 0; int64_t block_idx = entry_block; int64_t pos = 0; - ObMacroBlockCommonHeader comon_header; + ObMacroBlockCommonHeader common_header; ObMacroBlockHandleV1 block_handle[2]; ObMacroBlockReadInfo read_info; read_info.offset_ = 0; - read_info.size_ = comon_header.get_serialize_size(); + read_info.size_ = common_header.get_serialize_size(); read_info.io_desc_ = io_desc_; if (block_idx > 0) { @@ -175,19 +175,19 @@ int ObMetaBlockReader::get_meta_blocks(const int64_t entry_block) STORAGE_LOG(WARN, "Fail to async read meta block, ", K(ret), K(block_idx)); } else { do { - comon_header.reset(); + common_header.reset(); pos = 0; if (OB_FAIL(block_handle[cur_pos].wait(io_timeout_ms))) { STORAGE_LOG(WARN, "Fail to wait meta block io, ", K(ret)); } else if (OB_FAIL(macro_blocks_.push_back(macro_block_ctx.get_macro_block_id()))) { STORAGE_LOG(WARN, "Fail to push block index", K(ret), K(block_idx)); - } else if (OB_FAIL(comon_header.deserialize( + } else if (OB_FAIL(common_header.deserialize( block_handle[cur_pos].get_buffer(), block_handle[cur_pos].get_data_size(), pos))) { STORAGE_LOG( - WARN, "Fail to deserialize common header", K(ret), K(pos), K(block_handle[cur_pos]), K(comon_header)); + WARN, "Fail to deserialize common header", K(ret), K(pos), K(block_handle[cur_pos]), K(common_header)); } else { buf_ = block_handle[cur_pos].get_buffer(); - block_idx = comon_header.get_previous_block_index(); + block_idx = common_header.get_previous_block_index(); if (block_idx > 0) { cur_pos = 1 - cur_pos; @@ -199,9 +199,9 @@ int ObMetaBlockReader::get_meta_blocks(const int64_t entry_block) } if (OB_SUCC(ret)) { - if (OB_UNLIKELY(!comon_header.is_valid())) { + if (OB_UNLIKELY(!common_header.is_valid())) { ret = OB_INVALID_DATA; - STORAGE_LOG(WARN, "Invalid data, ", K(ret), K(comon_header)); + STORAGE_LOG(WARN, "Invalid data, ", K(ret), K(common_header)); } } } diff --git a/src/storage/blocksstable/ob_micro_block_index_mgr.cpp b/src/storage/blocksstable/ob_micro_block_index_mgr.cpp index d9b7ea7172..a9ab13458e 100644 --- a/src/storage/blocksstable/ob_micro_block_index_mgr.cpp +++ b/src/storage/blocksstable/ob_micro_block_index_mgr.cpp @@ -318,7 +318,7 @@ int ObMicroBlockIndexMgr::cal_border_row_count(const ObStoreRange& range, const ret = OB_NOT_INIT; STORAGE_LOG(WARN, "ObMicroBlockIndexMgr is not inited", K(ret)); } else if (OB_UNLIKELY(NULL == delta_array_ || NULL == mark_deletion_array_)) { - // this block index does not have row count delta or mark deletion arary + // this block index does not have row count delta or mark deletion array } else if (OB_UNLIKELY(!range.is_valid())) { ret = OB_INVALID_ARGUMENT; STORAGE_LOG(WARN, "range is not valid", K(ret), K(range)); diff --git a/src/storage/blocksstable/ob_micro_block_index_transformer.cpp b/src/storage/blocksstable/ob_micro_block_index_transformer.cpp index 67f8c8c76d..00eeddb33e 100644 --- a/src/storage/blocksstable/ob_micro_block_index_transformer.cpp +++ b/src/storage/blocksstable/ob_micro_block_index_transformer.cpp @@ -141,7 +141,7 @@ int ObMicroBlockIndexTransformer::block_index_to_node_vector() for (int64_t i = 0; OB_SUCC(ret) && i < block_count_; ++i) { if (OB_FAIL(index_reader_.get_end_key(i, rowkey_array[cur_rowkey_array_index]))) { - STORAGE_LOG(WARN, "transformer fail to get next roweky.", K(ret), K(i)); + STORAGE_LOG(WARN, "transformer fail to get next rowkey.", K(ret), K(i)); } if (OB_SUCC(ret)) { @@ -152,7 +152,7 @@ int ObMicroBlockIndexTransformer::block_index_to_node_vector() cur_node.first_child_index_ = 0; cur_node.child_num_ = 0; if (OB_FAIL(add_node_to_vector(cur_node, j))) { - STORAGE_LOG(WARN, "trnasformer fail to add node to vector.", K(ret), K(cur_node), K(j)); + STORAGE_LOG(WARN, "transformer fail to add node to vector.", K(ret), K(cur_node), K(j)); } } } else { @@ -178,7 +178,7 @@ int ObMicroBlockIndexTransformer::block_index_to_node_vector() cur_node.first_child_index_ = 0; cur_node.child_num_ = 0; if (OB_FAIL(add_node_to_vector(cur_node, j))) { - STORAGE_LOG(WARN, "trnasformer fail to add node to vector.", K(ret), K(cur_node), K(j)); + STORAGE_LOG(WARN, "transformer fail to add node to vector.", K(ret), K(cur_node), K(j)); } } } else { diff --git a/src/storage/blocksstable/ob_micro_block_index_writer.cpp b/src/storage/blocksstable/ob_micro_block_index_writer.cpp index 495b3cbc9a..acd3ef13de 100644 --- a/src/storage/blocksstable/ob_micro_block_index_writer.cpp +++ b/src/storage/blocksstable/ob_micro_block_index_writer.cpp @@ -169,7 +169,7 @@ int ObMicroBlockIndexWriter::merge(const int64_t data_end_offset, const ObMicroB K(ret), K(other_mark_buffer.length())); } else if (OB_FAIL(buffer_[DELTA_BUFFER_IDX].write(other_delta_buffer.data(), other_delta_buffer.length()))) { - STORAGE_LOG(WARN, "failed to write delte buffer", K(ret), K(other_delta_buffer.length())); + STORAGE_LOG(WARN, "failed to write delta buffer", K(ret), K(other_delta_buffer.length())); } } return ret; diff --git a/src/storage/blocksstable/ob_raid_file_system.cpp b/src/storage/blocksstable/ob_raid_file_system.cpp index 493f115d2c..fb90b4191a 100644 --- a/src/storage/blocksstable/ob_raid_file_system.cpp +++ b/src/storage/blocksstable/ob_raid_file_system.cpp @@ -1186,7 +1186,7 @@ int ObRaidFileSystem::load_raid_super_block(const common::ObIArrayheader_length_, header->data_size_, pos))) { LOG_WARN("failed to decode disk super block", K(ret), K(buf_size), K(pos), K(disk_idx), K(sstable_file_path)); } else if (!disk_super_block.is_valid()) { - ret = OB_RAID_SUPER_BLOCK_NOT_MACTH; + ret = OB_RAID_SUPER_BLOCK_NOT_MATCH; LOG_WARN("invalid disk super block", K(ret), K(disk_super_block)); } else if (disk_super_block.disk_idx_ != disk_idx) { - ret = OB_RAID_SUPER_BLOCK_NOT_MACTH; + ret = OB_RAID_SUPER_BLOCK_NOT_MATCH; LOG_ERROR("disk id not match", K(ret), K(disk_idx), K(disk_super_block)); } else { FLOG_INFO("succeed to load disk super block", @@ -1302,7 +1302,7 @@ int ObRaidFileSystem::build_raid_status(const ObDiskFileSuperBlock& disk_super_b ObDiskFileStatus& disk_status = raid_status.disk_status_.at(disk_idx); if (ObDiskFileInfo::DROP == disk_status.info_.status_) { - FLOG_ERROR("skip load droped disk", K(ret), K(disk_idx), K(disk_status)); + FLOG_ERROR("skip load dropped disk", K(ret), K(disk_idx), K(disk_status)); } else if (OB_FAIL(databuff_printf(sstable_path, sizeof(sstable_path), "%.*s", @@ -1847,7 +1847,7 @@ int ObRaidFileStatus::get_fd(const ObString& disk_name, ObDiskFd& fd) const ret = OB_NOT_INIT; LOG_WARN("not inited", K(ret), K(disk_name)); } else if (OB_FAIL(get_disk_status(disk_name, disk_status))) { - LOG_WARN("Faield to get disk status", K(ret), K(disk_name)); + LOG_WARN("Failed to get disk status", K(ret), K(disk_name)); } else if (OB_ISNULL(disk_status)) { ret = OB_ERR_SYS; LOG_ERROR("disk status must not null", K(ret), K(disk_name), K(*this)); @@ -2236,7 +2236,7 @@ int ObRaidFileSystem::init_recover_io_master(const ObMacroBlockCtx& macro_block_ if (OB_FAIL(recover_param.recover_index_.push_back(strip_idx))) { LOG_WARN("failed to add fail strip_idx", K(ret)); } else { - LOG_DEBUG("add recover strip idx from recovet_index_set", K(ret), K(strip_idx), K(disk_idx)); + LOG_DEBUG("add recover strip idx from recover_index_set", K(ret), K(strip_idx), K(disk_idx)); } } else { break; diff --git a/src/storage/blocksstable/ob_row_reader.cpp b/src/storage/blocksstable/ob_row_reader.cpp index 246a70662f..328809446d 100644 --- a/src/storage/blocksstable/ob_row_reader.cpp +++ b/src/storage/blocksstable/ob_row_reader.cpp @@ -902,14 +902,14 @@ int ObFlatRowReader::read_obj(const ObObjMeta& src_meta, ObIAllocator& allocator // not support data alteration ObObj ori_obj = obj; int64_t cm_mode = CM_NONE; - ObObjTypeClass ori_type_calss = ori_obj.get_type_class(); - if (ObIntTC == ori_type_calss && ObUIntTC == type_class) { + ObObjTypeClass ori_type_class = ori_obj.get_type_class(); + if (ObIntTC == ori_type_class && ObUIntTC == type_class) { obj.set_uint(src_meta.get_type(), static_cast(ori_obj.get_int())); - } else if (ObIntTC == ori_type_calss && ObBitTC == type_class) { + } else if (ObIntTC == ori_type_class && ObBitTC == type_class) { obj.set_bit(static_cast(ori_obj.get_int())); - } else if (ObIntTC == ori_type_calss && ObEnumType == column_type) { + } else if (ObIntTC == ori_type_class && ObEnumType == column_type) { obj.set_enum(static_cast(ori_obj.get_int())); - } else if (ObIntTC == ori_type_calss && ObSetType == column_type) { + } else if (ObIntTC == ori_type_class && ObSetType == column_type) { obj.set_set(static_cast(ori_obj.get_int())); } else { ObCastCtx cast_ctx(&allocator, NULL, cm_mode, src_meta.get_collation_type()); diff --git a/src/storage/blocksstable/ob_storage_cache_suite.cpp b/src/storage/blocksstable/ob_storage_cache_suite.cpp index 1a0763bb54..c20073cf03 100644 --- a/src/storage/blocksstable/ob_storage_cache_suite.cpp +++ b/src/storage/blocksstable/ob_storage_cache_suite.cpp @@ -67,7 +67,7 @@ int ObStorageCacheSuite::reset_priority(const int64_t index_cache_priority, cons int ret = OB_SUCCESS; if (OB_UNLIKELY(!is_inited_)) { ret = OB_NOT_INIT; - STORAGE_LOG(WARN, "The cashe suite has not been inited, ", K(ret)); + STORAGE_LOG(WARN, "The cache suite has not been inited, ", K(ret)); } else if (OB_FAIL(block_index_cache_.set_priority(index_cache_priority))) { STORAGE_LOG(ERROR, "set priority for block index cache failed, ", K(ret)); } else if (OB_FAIL(user_block_cache_.set_priority(user_block_cache_priority))) { diff --git a/src/storage/blocksstable/ob_store_file.cpp b/src/storage/blocksstable/ob_store_file.cpp index b51e2a7c9a..749ea98158 100644 --- a/src/storage/blocksstable/ob_store_file.cpp +++ b/src/storage/blocksstable/ob_store_file.cpp @@ -833,7 +833,7 @@ int ObStoreFile::get_store_status(ObMacroBlockMarkerStatus& status) status.second_index_count_ = used_macro_cnt_[ObMacroBlockCommonHeader::MacroBlockSecondIndex]; status.lob_data_block_count_ = used_macro_cnt_[ObMacroBlockCommonHeader::LobData]; status.lob_second_index_count_ = used_macro_cnt_[ObMacroBlockCommonHeader::LobIndex]; - status.bloomfiter_count_ = used_macro_cnt_[ObMacroBlockCommonHeader::BloomFilterData]; + status.bloomfilter_count_ = used_macro_cnt_[ObMacroBlockCommonHeader::BloomFilterData]; status.hold_count_ = hold_macro_cnt_; status.pending_free_count_ = 0; status.free_count_ = free_block_cnt_; diff --git a/src/storage/compaction/ob_partition_merge.cpp b/src/storage/compaction/ob_partition_merge.cpp index 99da863093..fa1d8b3675 100644 --- a/src/storage/compaction/ob_partition_merge.cpp +++ b/src/storage/compaction/ob_partition_merge.cpp @@ -130,7 +130,7 @@ int ObIPartitionMergeFuser::check_merge_param(const ObMergeParameter& merge_para ret = OB_INVALID_ARGUMENT; STORAGE_LOG(WARN, "Unexpected merge param with major fuser", K(merge_param), K(ret)); } else if (OB_FAIL(inner_check_merge_param(merge_param))) { - STORAGE_LOG(WARN, "Unexcepted merge param to init merge fuser", K(merge_param), K(ret)); + STORAGE_LOG(WARN, "Unexpected merge param to init merge fuser", K(merge_param), K(ret)); } return ret; @@ -404,7 +404,7 @@ int ObMajorPartitionMergeFuser::inner_init(const ObMergeParameter& merge_param) K(ret)); } else if (OB_ISNULL(expr)) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted null generated expr", KP(expr), K(ret)); + STORAGE_LOG(WARN, "Unexpected null generated expr", KP(expr), K(ret)); } else if (OB_FAIL(dependent_exprs_.push_back(expr))) { STORAGE_LOG(WARN, "push back error", K(ret)); } else { @@ -808,7 +808,7 @@ int ObIncrementMajorPartitionMergeFuser::calc_column_checksum(const bool rewrite STORAGE_LOG(WARN, "ObMajorPartitionMergeFuser is not inited", K_(is_inited), K(ret)); } else if (OB_ISNULL(checksum_calculator_)) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted null checksum calculator", K(ret)); + STORAGE_LOG(WARN, "Unexpected null checksum calculator", K(ret)); } else if (!row_changed_) { // skip not changed row } else if (OB_FAIL(checksum_calculator_->calc_column_checksum( @@ -901,10 +901,10 @@ int ObMinorPartitionMergeFuser::inner_init(const ObMergeParameter& merge_param) STORAGE_LOG(WARN, "Failed to generate multi version row info", K(ret)); } else if (OB_ISNULL(multi_version_row_info_)) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted null multi version row info", K(ret)); + STORAGE_LOG(WARN, "Unexpected null multi version row info", K(ret)); } else if (OB_ISNULL(out_cols_project_ = multi_version_col_desc_gen_.get_out_cols_project())) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted null out cols project", K(ret)); + STORAGE_LOG(WARN, "Unexpected null out cols project", K(ret)); } else { column_cnt_ = multi_version_row_info_->column_cnt_; cur_first_dml_ = T_DML_UNKNOWN; diff --git a/src/storage/compaction/ob_partition_merge_builder.cpp b/src/storage/compaction/ob_partition_merge_builder.cpp index 6f6c4a7697..3506a14fed 100644 --- a/src/storage/compaction/ob_partition_merge_builder.cpp +++ b/src/storage/compaction/ob_partition_merge_builder.cpp @@ -91,7 +91,7 @@ int ObMacroBlockBuilder::open(storage::ObSSTableMergeCtx& ctx, const int64_t idx if (desc_.need_prebuild_bloomfilter_) { ObIPartitionGroup* pg = ctx.pg_guard_.get_partition_group(); if (OB_ISNULL(pg)) { - STORAGE_LOG(WARN, "Unexcepted null partition group", K(ctx)); + STORAGE_LOG(WARN, "Unexpected null partition group", K(ctx)); desc_.need_prebuild_bloomfilter_ = false; } else if (is_follower_state(pg->get_partition_state())) { desc_.need_prebuild_bloomfilter_ = false; @@ -263,7 +263,7 @@ int ObMacroBlockBuilder::init_bloomfilter_if_need(storage::ObSSTableMergeCtx& ct for (int64_t i = 0; OB_SUCC(ret) && need_build_bloom_filter_ && i < ctx.tables_handle_.get_tables().count(); i++) { if (OB_ISNULL(table = ctx.tables_handle_.get_tables().at(i))) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted null table", KP(table), K(ret)); + STORAGE_LOG(WARN, "Unexpected null table", KP(table), K(ret)); } else if (!table->is_sstable()) { break; } else if (FALSE_IT(sstable = reinterpret_cast(table))) { @@ -425,7 +425,7 @@ int ObMacroBlockBuilder::check_flat_row_columns(const ObStoreRow& row) if (ObActionFlag::OP_ROW_EXIST != row.flag_) { } else if (row.row_val_.count_ != desc_.row_column_count_) { ret = OB_ERR_UNEXPECTED; - LOG_ERROR("Unexcepte column count of store row", K(row), K_(desc), K(ret)); + LOG_ERROR("Unexpected column count of store row", K(row), K_(desc), K(ret)); } else { const int64_t interval = 4; int64_t i = 0; @@ -460,7 +460,7 @@ OB_INLINE int ObMacroBlockBuilder::check_row_column(const storage::ObStoreRow& r // pass } else if (obj.get_type() != desc_.column_types_[idx].get_type()) { ret = OB_ERR_UNEXPECTED; - LOG_ERROR("Unexcepte column type of store row", + LOG_ERROR("Unexpected column type of store row", K(ret), K(idx), K(obj), @@ -482,7 +482,7 @@ OB_INLINE int ObMacroBlockBuilder::check_sparse_row_column(const ObObj& obj, con // pass } else if (obj.get_type() != desc_.column_types_[idx].get_type()) { ret = OB_ERR_UNEXPECTED; - LOG_ERROR("Unexcepte column type of store row", + LOG_ERROR("Unexpected column type of store row", K(ret), K(idx), K(obj), @@ -511,7 +511,7 @@ int ObMacroBlockBuilder::append_bloom_filter(const ObStoreRow& row) LOG_WARN("Major merge should not build bloomfilter for sstable", K(ret)); } else if (OB_UNLIKELY(!need_build_bloom_filter_)) { ret = OB_ERR_UNEXPECTED; - LOG_WARN("Unexcepted status for append bloomfilter", K_(need_build_bloom_filter), K(ret)); + LOG_WARN("Unexpected status for append bloomfilter", K_(need_build_bloom_filter), K(ret)); } else if (OB_FAIL(bf_macro_writer_.append(row))) { if (OB_NOT_SUPPORTED == ret) { ret = OB_SUCCESS; @@ -604,7 +604,7 @@ int ObMacroBlockBuilder::close() STORAGE_LOG(WARN, "Failed to flush bloomfilter macro block", K(ret)); } else if (OB_UNLIKELY(bf_macro_writer_.get_block_write_ctx().is_empty())) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted macro block write ctx", K(ret)); + STORAGE_LOG(WARN, "Unexpected macro block write ctx", K(ret)); } else if (OB_FAIL(ObStorageCacheSuite::get_instance().get_bf_cache().put_bloom_filter(desc_.table_id_, bf_macro_writer_.get_block_write_ctx().macro_block_list_.at(0), merge_context_->get_file_id(), diff --git a/src/storage/compaction/ob_partition_merge_util.cpp b/src/storage/compaction/ob_partition_merge_util.cpp index c52758a108..3eeade9109 100644 --- a/src/storage/compaction/ob_partition_merge_util.cpp +++ b/src/storage/compaction/ob_partition_merge_util.cpp @@ -1541,7 +1541,7 @@ int ObPartitionMergeUtil::merge_partition(memtable::ObIMemtableCtxFactory* memct STORAGE_LOG(WARN, "Failed to init partition fuser", K(merge_param), K(ret)); } else if (OB_ISNULL(partition_fuser)) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted null partition fuser", K(ret)); + STORAGE_LOG(WARN, "Unexpected null partition fuser", K(ret)); } else if (OB_FAIL(ctx.get_merge_range(idx, merge_range, allocator))) { STORAGE_LOG(WARN, "Failed to get merge range from merge context", K(ret)); } else { @@ -2243,10 +2243,10 @@ int ObPartitionMergeUtil::rewrite_macro_block(ObIPartitionMergeFuser::MERGE_ITER ObMacroRowIterator* iter = static_cast(minimum_iters.at(0)); if (OB_ISNULL(partition_fuser)) { ret = OB_ERR_UNEXPECTED; - LOG_WARN("Unexcepted NULL partition fuser", K(partition_fuser), K(ret)); + LOG_WARN("Unexpected NULL partition fuser", K(partition_fuser), K(ret)); } else if (!partition_fuser->is_valid()) { ret = OB_ERR_UNEXPECTED; - LOG_WARN("Unexcepted partition fuser", K(*partition_fuser), K(ret)); + LOG_WARN("Unexpected partition fuser", K(*partition_fuser), K(ret)); } else if (OB_FAIL(iter->open_curr_macro_block())) { LOG_WARN("Fail to open the curr macro block", K(ret)); } else { diff --git a/src/storage/ob_ms_row_iterator.cpp b/src/storage/ob_ms_row_iterator.cpp index cd94deeeed..b4567dc816 100644 --- a/src/storage/ob_ms_row_iterator.cpp +++ b/src/storage/ob_ms_row_iterator.cpp @@ -179,7 +179,7 @@ int ObMSRowIterator::get_next_row(const ObStoreRow*& store_row) } } else if (OB_ISNULL(store_row = partition_fuser_->get_result_row())) { ret = OB_ERR_UNEXPECTED; - STORAGE_LOG(WARN, "Unexcepted null store row", KP(store_row), K(ret)); + STORAGE_LOG(WARN, "Unexpected null store row", KP(store_row), K(ret)); } else if (!store_row->is_valid()) { ret = OB_ERR_SYS; STORAGE_LOG(ERROR, "Invalid store row", K(ret), K(*store_row)); diff --git a/src/storage/ob_old_sstable.cpp b/src/storage/ob_old_sstable.cpp index 6f50dc0119..d41f0c422d 100644 --- a/src/storage/ob_old_sstable.cpp +++ b/src/storage/ob_old_sstable.cpp @@ -394,7 +394,7 @@ int ObOldSSTable::append_bf_macro_blocks(ObMacroBlocksWriteCtx& macro_block_writ // pass } else if (macro_block_write_ctx.get_macro_block_count() > 1) { ret = OB_ERR_UNEXPECTED; - LOG_WARN("Unexcepted macro block write ctx count", K(macro_block_write_ctx), K(ret)); + LOG_WARN("Unexpected macro block write ctx count", K(macro_block_write_ctx), K(ret)); } else if (OB_FAIL(add_macro_block_meta(macro_block_write_ctx.macro_block_list_.at(0)))) { LOG_WARN("Failed to add macro block meta", K(macro_block_write_ctx.macro_block_list_.at(0)), K(ret)); } else { @@ -404,7 +404,7 @@ int ObOldSSTable::append_bf_macro_blocks(ObMacroBlocksWriteCtx& macro_block_writ if (macro_block_write_ctx.file_ctx_.file_list_.count() <= 0 || macro_block_write_ctx.file_ctx_.file_list_.count() > 1) { ret = OB_ERR_UNEXPECTED; - LOG_WARN("Unexcepted macro block file ctx count", K(macro_block_write_ctx.file_ctx_), K(ret)); + LOG_WARN("Unexpected macro block file ctx count", K(macro_block_write_ctx.file_ctx_), K(ret)); } else if (OB_FAIL(meta_.bloom_filter_file_ctx_.file_list_.push_back( macro_block_write_ctx.file_ctx_.file_list_.at(0)))) { LOG_ERROR("failed to add file list, fatal error", K(ret)); diff --git a/src/storage/ob_partition_base_data_physical_restore.cpp b/src/storage/ob_partition_base_data_physical_restore.cpp index 33c4a03d34..255a967690 100644 --- a/src/storage/ob_partition_base_data_physical_restore.cpp +++ b/src/storage/ob_partition_base_data_physical_restore.cpp @@ -1399,23 +1399,23 @@ int ObPartitionMetaPhysicalReader::read_table_keys_by_table_id( return ret; } -/************************ObPGMetaPyhsicalReader************************/ -ObPGMetaPyhsicalReader::ObPGMetaPyhsicalReader() : is_inited_(false), data_size_(0), arg_(NULL), meta_indexs_(NULL) +/************************ObPGMetaPhysicalReader************************/ +ObPGMetaPhysicalReader::ObPGMetaPhysicalReader() : is_inited_(false), data_size_(0), arg_(NULL), meta_indexs_(NULL) {} -ObPGMetaPyhsicalReader::~ObPGMetaPyhsicalReader() +ObPGMetaPhysicalReader::~ObPGMetaPhysicalReader() { reset(); } -void ObPGMetaPyhsicalReader::reset() +void ObPGMetaPhysicalReader::reset() { arg_ = NULL; meta_indexs_ = NULL; is_inited_ = false; } -int ObPGMetaPyhsicalReader::init(const share::ObPhysicalRestoreArg& arg, const ObPhyRestoreMetaIndexStore& meta_indexs) +int ObPGMetaPhysicalReader::init(const share::ObPhysicalRestoreArg& arg, const ObPhyRestoreMetaIndexStore& meta_indexs) { int ret = OB_SUCCESS; @@ -1433,7 +1433,7 @@ int ObPGMetaPyhsicalReader::init(const share::ObPhysicalRestoreArg& arg, const O return ret; } -int ObPGMetaPyhsicalReader::read_partition_group_meta(ObPartitionGroupMeta& pg_meta) +int ObPGMetaPhysicalReader::read_partition_group_meta(ObPartitionGroupMeta& pg_meta) { int ret = OB_SUCCESS; @@ -1465,7 +1465,7 @@ int ObPGMetaPyhsicalReader::read_partition_group_meta(ObPartitionGroupMeta& pg_m return ret; } -int ObPGMetaPyhsicalReader::read_backup_pg_meta_info(ObBackupPGMetaInfo& backup_pg_meta_info) +int ObPGMetaPhysicalReader::read_backup_pg_meta_info(ObBackupPGMetaInfo& backup_pg_meta_info) { int ret = OB_SUCCESS; @@ -2370,7 +2370,7 @@ int ObPartitionGroupMetaRestoreReaderV1::check_backup_partitions_in_pg( STORAGE_LOG(WARN, "failed to get base data restore schema version", K(ret), K(tenant_id), K(restore_info)); } else if (OB_FAIL(ObBackupUtils::retry_get_tenant_schema_guard( tenant_id, schema_service, tenant_schema_version, schema_guard))) { - STORAGE_LOG(WARN, "failed to get tenant schema gaurd", K(ret), K(restore_info), K(backup_pg_meta)); + STORAGE_LOG(WARN, "failed to get tenant schema guard", K(ret), K(restore_info), K(backup_pg_meta)); } else if (!restore_info.pg_key_.is_pg()) { if (OB_FAIL(table_ids.push_back(restore_info.pg_key_.get_table_id()))) { STORAGE_LOG(WARN, "failed to push table id into array", K(ret), K(restore_info)); @@ -2559,7 +2559,7 @@ int ObPGPartitionBaseDataMetaRestoreReaderV1::check_sstable_table_ids_in_table( STORAGE_LOG(WARN, "failed to create table ids set", K(ret)); } else if (OB_FAIL(ObBackupUtils::retry_get_tenant_schema_guard( tenant_id, schema_service, schema_version_, schema_guard))) { - STORAGE_LOG(WARN, "failed to get tenant schema gaurd", K(ret), K(tenant_id), K(schema_version_)); + STORAGE_LOG(WARN, "failed to get tenant schema guard", K(ret), K(tenant_id), K(schema_version_)); } else if (OB_FAIL(schema_guard.get_index_status(data_table_id, false /*with global index*/, index_stats))) { STORAGE_LOG(WARN, "failed to get index status", K(ret), K(data_table_id)); } else { diff --git a/src/storage/ob_partition_base_data_physical_restore.h b/src/storage/ob_partition_base_data_physical_restore.h index a34df03ca3..a794133726 100644 --- a/src/storage/ob_partition_base_data_physical_restore.h +++ b/src/storage/ob_partition_base_data_physical_restore.h @@ -173,10 +173,10 @@ class ObPartitionMetaPhysicalReader final { DISALLOW_COPY_AND_ASSIGN(ObPartitionMetaPhysicalReader); }; -class ObPGMetaPyhsicalReader final { +class ObPGMetaPhysicalReader final { public: - ObPGMetaPyhsicalReader(); - virtual ~ObPGMetaPyhsicalReader(); + ObPGMetaPhysicalReader(); + virtual ~ObPGMetaPhysicalReader(); void reset(); int init(const share::ObPhysicalRestoreArg& arg, const ObPhyRestoreMetaIndexStore& meta_indexs); int read_partition_group_meta(ObPartitionGroupMeta& pg_meta); @@ -197,7 +197,7 @@ class ObPGMetaPyhsicalReader final { int64_t data_size_; const share::ObPhysicalRestoreArg* arg_; const ObPhyRestoreMetaIndexStore* meta_indexs_; - DISALLOW_COPY_AND_ASSIGN(ObPGMetaPyhsicalReader); + DISALLOW_COPY_AND_ASSIGN(ObPGMetaPhysicalReader); }; class ObPartitionBaseDataMetaRestoreReaderV1 { @@ -336,7 +336,7 @@ class ObPartitionGroupMetaRestoreReaderV1 : public ObIPartitionGroupMetaRestoreR bool is_inited_; const ObPhysicalRestoreArg* restore_info_; const ObPhyRestoreMetaIndexStore* meta_indexs_; - ObPGMetaPyhsicalReader reader_; + ObPGMetaPhysicalReader reader_; ObPartitionGroupMeta pg_meta_; common::ObInOutBandwidthThrottle* bandwidth_throttle_; int64_t last_read_size_; diff --git a/src/storage/ob_partition_merge_task.cpp b/src/storage/ob_partition_merge_task.cpp index 6a4e51f766..0a913af572 100644 --- a/src/storage/ob_partition_merge_task.cpp +++ b/src/storage/ob_partition_merge_task.cpp @@ -1046,7 +1046,7 @@ int ObSSTableMergePrepareTask::process() } else if (ctx->param_.is_multi_version_minor_merge()) { if (ctx->log_ts_range_.is_empty()) { ret = OB_ERR_UNEXPECTED; - LOG_ERROR("Unexcepted empty log ts range in minor merge", K(ret), K(ctx->log_ts_range_)); + LOG_ERROR("Unexpected empty log ts range in minor merge", K(ret), K(ctx->log_ts_range_)); } else { ctx->merge_log_ts_ = ctx->log_ts_range_.end_log_ts_; } diff --git a/src/storage/ob_sstable.cpp b/src/storage/ob_sstable.cpp index 0da1e8eea5..ef965b9bc5 100644 --- a/src/storage/ob_sstable.cpp +++ b/src/storage/ob_sstable.cpp @@ -754,7 +754,7 @@ int ObSSTable::append_bf_macro_blocks(ObMacroBlocksWriteCtx& macro_block_write_c // pass } else if (macro_block_write_ctx.get_macro_block_count() > 1) { ret = OB_ERR_UNEXPECTED; - LOG_WARN("Unexcepted macro block write ctx count", K(macro_block_write_ctx), K(ret)); + LOG_WARN("Unexpected macro block write ctx count", K(macro_block_write_ctx), K(ret)); } else if (OB_FAIL(add_macro_block_meta( macro_block_write_ctx.macro_block_list_.at(0), macro_block_write_ctx.macro_block_meta_list_.at(0)))) { LOG_WARN("Failed to add macro block meta", K(macro_block_write_ctx.macro_block_list_.at(0)), K(ret)); @@ -765,7 +765,7 @@ int ObSSTable::append_bf_macro_blocks(ObMacroBlocksWriteCtx& macro_block_write_c if (macro_block_write_ctx.file_ctx_.file_list_.count() <= 0 || macro_block_write_ctx.file_ctx_.file_list_.count() > 1) { ret = OB_ERR_UNEXPECTED; - LOG_WARN("Unexcepted macro block file ctx count", K(macro_block_write_ctx.file_ctx_), K(ret)); + LOG_WARN("Unexpected macro block file ctx count", K(macro_block_write_ctx.file_ctx_), K(ret)); } else if (OB_FAIL(meta_.bloom_filter_file_ctx_.file_list_.push_back( macro_block_write_ctx.file_ctx_.file_list_.at(0)))) { LOG_ERROR("failed to add file list, fatal error", K(ret)); diff --git a/src/storage/ob_sstable_rowkey_helper.cpp b/src/storage/ob_sstable_rowkey_helper.cpp index 212ce97660..b6b7a543f8 100644 --- a/src/storage/ob_sstable_rowkey_helper.cpp +++ b/src/storage/ob_sstable_rowkey_helper.cpp @@ -269,7 +269,7 @@ int ObSSTableRowkeyHelper::get_macro_block_meta( } else if (OB_UNLIKELY(macro_meta.meta_->rowkey_column_number_ < schema_rowkey_column_cnt)) { ret = OB_ERR_UNEXPECTED; STORAGE_LOG(WARN, - "Unexcepted mis matched rowkey column number", + "Unexpected mis matched rowkey column number", K(macro_meta.meta_->rowkey_column_number_), K(schema_rowkey_column_cnt), K(ret)); diff --git a/src/storage/ob_storage_struct.cpp b/src/storage/ob_storage_struct.cpp index 9d5c204ef0..d12765171c 100644 --- a/src/storage/ob_storage_struct.cpp +++ b/src/storage/ob_storage_struct.cpp @@ -911,7 +911,7 @@ int ObRecoveryPointSchemaFilter::init(const int64_t tenant_id, const int64_t ten if (OB_FAIL(ObBackupUtils::retry_get_tenant_schema_guard( tenant_id, schema_service, tenant_recovery_point_schema_version, recovery_point_schema_guard_))) { STORAGE_LOG(WARN, - "failed to get tenant backup schema gaurd", + "failed to get tenant backup schema guard", K(ret), K(tenant_id), K(tenant_recovery_point_schema_version)); diff --git a/src/storage/ob_table_store.cpp b/src/storage/ob_table_store.cpp index 734587f3a6..35a0876100 100644 --- a/src/storage/ob_table_store.cpp +++ b/src/storage/ob_table_store.cpp @@ -1844,7 +1844,7 @@ int ObTableStore::refine_mini_merge_result_in_reboot_phase(ObITable& last_table, if (result.version_range_.snapshot_version_ > last_snapshot_version) { ret = OB_ERR_UNEXPECTED; LOG_ERROR( - "Unexcepted chaos snapshot_version and log_ts", K(ret), K(result), K(last_end_log_ts), K(PRETTY_TS(*this))); + "Unexpected chaos snapshot_version and log_ts", K(ret), K(result), K(last_end_log_ts), K(PRETTY_TS(*this))); } else { ret = OB_NEED_REMOVE_UNNEED_TABLE; LOG_WARN("No need mini merge memtable which is covered by existing sstable", @@ -1856,7 +1856,7 @@ int ObTableStore::refine_mini_merge_result_in_reboot_phase(ObITable& last_table, } else if (result.version_range_.snapshot_version_ <= last_snapshot_version) { ret = OB_ERR_UNEXPECTED; LOG_ERROR( - "Unexcepted chaos snapshot_version and log_ts", K(ret), K(result), K(last_end_log_ts), K(PRETTY_TS(*this))); + "Unexpected chaos snapshot_version and log_ts", K(ret), K(result), K(last_end_log_ts), K(PRETTY_TS(*this))); } else { // fix start_log_ts to make log_ts_range continuous result.log_ts_range_.start_log_ts_ = MAX(last_end_log_ts, result.log_ts_range_.start_log_ts_);