Remove warning configurations
This commit is contained in:
committed by
wangzelin.wzl
parent
62c4fec8b5
commit
a331dec52c
@ -126,7 +126,7 @@ public:
|
||||
const storage::ObSSTable* sstable) override;
|
||||
virtual int open(const MacroBlockId& macro_id, const ObFullMacroBlockMeta& macro_meta,
|
||||
const ObMicroBlockData& block_data, const bool is_left_border, const bool is_right_border) override;
|
||||
void reset();
|
||||
void reset() override;
|
||||
|
||||
protected:
|
||||
virtual int inner_get_next_row(const storage::ObStoreRow*& row) override;
|
||||
@ -195,7 +195,7 @@ public:
|
||||
const storage::ObSSTable* sstable) override;
|
||||
virtual int open(const MacroBlockId& macro_id, const ObFullMacroBlockMeta& macro_meta,
|
||||
const ObMicroBlockData& block_data, const bool is_left_border, const bool is_right_border) override;
|
||||
void reset();
|
||||
void reset() override;
|
||||
void rescan() override;
|
||||
|
||||
protected:
|
||||
@ -248,7 +248,7 @@ public:
|
||||
const storage::ObSSTable* sstable) override;
|
||||
virtual int open(const MacroBlockId& macro_id, const ObFullMacroBlockMeta& macro_meta,
|
||||
const ObMicroBlockData& block_data, const bool is_left_border, const bool is_right_border) override;
|
||||
void reset();
|
||||
void reset() override;
|
||||
void rescan() override
|
||||
{
|
||||
reset();
|
||||
|
||||
@ -136,7 +136,7 @@ public:
|
||||
KP_(table_schema), K_(need_fuse_generate));
|
||||
|
||||
protected:
|
||||
virtual int inner_check_merge_param(const storage::ObMergeParameter& merge_param);
|
||||
virtual int inner_check_merge_param(const storage::ObMergeParameter& merge_param) override;
|
||||
virtual int inner_init(const storage::ObMergeParameter& merge_param) override;
|
||||
virtual int fuse_generate_exprs();
|
||||
virtual int fuse_old_row(ObMacroRowIterator* row_iter, storage::ObStoreRow* row);
|
||||
@ -205,9 +205,9 @@ public:
|
||||
virtual ~ObMinorPartitionMergeFuser();
|
||||
virtual void reset() override;
|
||||
virtual bool is_valid() const override;
|
||||
virtual int fuse_row(MERGE_ITER_ARRAY& macro_row_iters) = 0;
|
||||
virtual int fuse_row(MERGE_ITER_ARRAY& macro_row_iters) override = 0;
|
||||
virtual int find_minimum_iters(const MERGE_ITER_ARRAY& macro_row_iters, MERGE_ITER_ARRAY& minimum_iters) override;
|
||||
virtual inline const common::ObIArray<share::schema::ObColDesc>& get_column_ids() const
|
||||
virtual inline const common::ObIArray<share::schema::ObColDesc>& get_column_ids() const override
|
||||
{
|
||||
return column_ids_;
|
||||
}
|
||||
@ -230,8 +230,8 @@ protected:
|
||||
int set_multi_version_row_flag(const MERGE_ITER_ARRAY& macro_row_iters, storage::ObStoreRow& store_row);
|
||||
void set_dml(const MERGE_ITER_ARRAY& macro_row_iters, storage::ObStoreRow& store_row);
|
||||
virtual int fuse_delete_row(
|
||||
ObMacroRowIterator* row_iter, storage::ObStoreRow* row, const int64_t rowkey_column_cnt) = 0;
|
||||
virtual int malloc_row(int64_t column_count, storage::ObStoreRow*& row) = 0;
|
||||
ObMacroRowIterator* row_iter, storage::ObStoreRow* row, const int64_t rowkey_column_cnt) override = 0;
|
||||
virtual int malloc_row(int64_t column_count, storage::ObStoreRow*& row) override = 0;
|
||||
bool is_committed_row_(const storage::ObStoreRow& row) const;
|
||||
|
||||
protected:
|
||||
|
||||
@ -75,16 +75,16 @@ public:
|
||||
const ObIArray<share::schema::ObColDesc>& column_ids,
|
||||
const ObIArray<blocksstable::ObMacroBlockInfoPair>* lob_blocks = NULL) override;
|
||||
virtual int init_bloomfilter_if_need(storage::ObSSTableMergeCtx& ctx);
|
||||
virtual int process(const blocksstable::ObMacroBlockCtx& macro_block_ctx);
|
||||
virtual int process(const blocksstable::ObMicroBlock& micro_block);
|
||||
virtual int process(const storage::ObStoreRow& row, const ObCompactRowType::ObCompactRowTypeEnum type);
|
||||
virtual int close();
|
||||
virtual void reset();
|
||||
virtual const blocksstable::ObDataStoreDesc* get_data_store_desc() const
|
||||
virtual int process(const blocksstable::ObMacroBlockCtx& macro_block_ctx) override;
|
||||
virtual int process(const blocksstable::ObMicroBlock& micro_block) override;
|
||||
virtual int process(const storage::ObStoreRow& row, const ObCompactRowType::ObCompactRowTypeEnum type) override;
|
||||
virtual int close() override;
|
||||
virtual void reset() override;
|
||||
virtual const blocksstable::ObDataStoreDesc* get_data_store_desc() const override
|
||||
{
|
||||
return &desc_;
|
||||
}
|
||||
virtual void set_purged_count(const int64_t count);
|
||||
virtual void set_purged_count(const int64_t count) override;
|
||||
TO_STRING_KV(K_(desc), K_(sstable_merge_info), K_(writer));
|
||||
|
||||
protected:
|
||||
@ -125,20 +125,20 @@ public:
|
||||
virtual int open(storage::ObSSTableMergeCtx& ctx, const int64_t idx, const bool iter_complement,
|
||||
const ObIArray<share::schema::ObColDesc>& column_ids,
|
||||
const ObIArray<blocksstable::ObMacroBlockInfoPair>* lob_blocks = NULL) override;
|
||||
virtual int process(const blocksstable::ObMacroBlockCtx& macro_block_ctx);
|
||||
virtual int process(const blocksstable::ObMicroBlock& micro_block);
|
||||
virtual int process(const storage::ObStoreRow& row, const ObCompactRowType::ObCompactRowTypeEnum type);
|
||||
virtual int close();
|
||||
virtual void reset();
|
||||
virtual int process(const blocksstable::ObMacroBlockCtx& macro_block_ctx) override;
|
||||
virtual int process(const blocksstable::ObMicroBlock& micro_block) override;
|
||||
virtual int process(const storage::ObStoreRow& row, const ObCompactRowType::ObCompactRowTypeEnum type) override;
|
||||
virtual int close() override;
|
||||
virtual void reset() override;
|
||||
OB_INLINE void set_component(ObIStoreRowProcessor* component)
|
||||
{
|
||||
component_ = component;
|
||||
}
|
||||
virtual const blocksstable::ObDataStoreDesc* get_data_store_desc() const
|
||||
virtual const blocksstable::ObDataStoreDesc* get_data_store_desc() const override
|
||||
{
|
||||
return is_opened_ ? component_->get_data_store_desc() : NULL;
|
||||
}
|
||||
virtual void set_purged_count(const int64_t count);
|
||||
virtual void set_purged_count(const int64_t count) override;
|
||||
TO_STRING_KV(KP(component_));
|
||||
|
||||
private:
|
||||
|
||||
@ -108,7 +108,7 @@ struct ObCreateIndexKey : public ObILongOpsKey {
|
||||
virtual ~ObCreateIndexKey()
|
||||
{}
|
||||
virtual int to_key_string() override;
|
||||
bool is_valid() const
|
||||
bool is_valid() const override
|
||||
{
|
||||
return common::OB_INVALID_ID != index_table_id_ && common::OB_INVALID_ID != partition_id_;
|
||||
}
|
||||
|
||||
@ -110,7 +110,7 @@ public:
|
||||
virtual int open(const ObCreateSSTableParam& param);
|
||||
virtual int open(const blocksstable::ObSSTableBaseMeta& meta);
|
||||
virtual int close();
|
||||
virtual void destroy();
|
||||
virtual void destroy() override;
|
||||
|
||||
// if set success, src ObMacroBlocksWriteCtx will be clear
|
||||
// if set failed, dest sstable macro blocks will be clear
|
||||
@ -264,9 +264,9 @@ public:
|
||||
const int64_t type, uint64_t* macros_count, const int64_t* total_task_count,
|
||||
common::ObIArray<common::ObStoreRange>* splitted_ranges, common::ObIArray<int64_t>* split_index);
|
||||
int exist(const ObStoreCtx& ctx, const uint64_t table_id, const common::ObStoreRowkey& rowkey,
|
||||
const common::ObIArray<share::schema::ObColDesc>& column_ids, bool& is_exist, bool& has_found);
|
||||
virtual int prefix_exist(storage::ObRowsInfo& rows_info, bool& may_exist);
|
||||
int exist(ObRowsInfo& rows_info, bool& is_exist, bool& all_rows_found);
|
||||
const common::ObIArray<share::schema::ObColDesc>& column_ids, bool& is_exist, bool& has_found) override;
|
||||
virtual int prefix_exist(storage::ObRowsInfo& rows_info, bool& may_exist) override;
|
||||
int exist(ObRowsInfo& rows_info, bool& is_exist, bool& all_rows_found) override;
|
||||
int64_t get_occupy_size() const
|
||||
{
|
||||
return meta_.occupy_size_;
|
||||
|
||||
@ -320,7 +320,7 @@ public:
|
||||
VIRTUAL_FOR_UNITTEST int start();
|
||||
VIRTUAL_FOR_UNITTEST int stop();
|
||||
VIRTUAL_FOR_UNITTEST int wait();
|
||||
VIRTUAL_FOR_UNITTEST int destroy();
|
||||
VIRTUAL_FOR_UNITTEST int destroy() override;
|
||||
|
||||
VIRTUAL_FOR_UNITTEST int wait_start_finish();
|
||||
|
||||
@ -691,10 +691,10 @@ public:
|
||||
common::ObIArray<int64_t>* split_index) override;
|
||||
|
||||
virtual int get_multi_ranges_cost(
|
||||
const common::ObPartitionKey& pkey, const common::ObIArray<common::ObStoreRange>& ranges, int64_t& total_size);
|
||||
const common::ObPartitionKey& pkey, const common::ObIArray<common::ObStoreRange>& ranges, int64_t& total_size) override;
|
||||
virtual int split_multi_ranges(const common::ObPartitionKey& pkey,
|
||||
const common::ObIArray<common::ObStoreRange>& ranges, const int64_t expected_task_count,
|
||||
common::ObIAllocator& allocator, common::ObArrayArray<common::ObStoreRange>& multi_range_split_array);
|
||||
common::ObIAllocator& allocator, common::ObArrayArray<common::ObStoreRange>& multi_range_split_array) override;
|
||||
VIRTUAL_FOR_UNITTEST int is_log_sync(
|
||||
const common::ObPartitionKey& key, bool& is_sync, uint64_t& max_confirmed_log_id);
|
||||
VIRTUAL_FOR_UNITTEST int set_region(const ObPartitionKey& key, clog::ObIPartitionLogService* pls);
|
||||
@ -796,8 +796,8 @@ public:
|
||||
int check_physical_flashback_succ(
|
||||
const obrpc::ObCheckPhysicalFlashbackArg& arg, obrpc::ObPhysicalFlashbackResultArg& result);
|
||||
int nonblock_renew_loc_cache(const common::ObPartitionKey& pkey);
|
||||
int submit_pt_update_task(const ObPartitionKey& pkey);
|
||||
int submit_pt_update_role_task(const ObPartitionKey& pkey);
|
||||
int submit_pt_update_task(const ObPartitionKey& pkey) override;
|
||||
int submit_pt_update_role_task(const ObPartitionKey& pkey) override;
|
||||
int start_physical_flashback();
|
||||
int check_can_physical_flashback();
|
||||
int try_freeze_aggre_buffer(const common::ObPartitionKey& pkey);
|
||||
|
||||
@ -355,8 +355,8 @@ public:
|
||||
|
||||
virtual int lock(const ObStoreCtx& ctx) override;
|
||||
|
||||
virtual void set_merge_status(bool merge_success);
|
||||
virtual bool can_schedule_merge();
|
||||
virtual void set_merge_status(bool merge_success) override;
|
||||
virtual bool can_schedule_merge() override;
|
||||
|
||||
// write ssstore objects @version tree to data file, used by write_check_point
|
||||
virtual int serialize(ObArenaAllocator& allocator, char*& new_buf, int64_t& serialize_size);
|
||||
@ -364,27 +364,27 @@ public:
|
||||
virtual int deserialize(const ObReplicaType replica_type, const char* buf, const int64_t buf_len,
|
||||
ObIPartitionGroup* pg, int64_t& pos, bool& is_old_meta, ObPartitionStoreMeta& old_meta);
|
||||
|
||||
virtual bool has_memstore();
|
||||
virtual bool has_memstore() override;
|
||||
|
||||
// freeze actions
|
||||
virtual int get_replayed_table_version(int64_t& table_version);
|
||||
virtual int get_partition_ss_store_info(common::ObArray<PartitionSSStoreInfo>& partition_ss_store_info_list);
|
||||
virtual int get_all_tables(ObTablesHandle& tables_handle);
|
||||
virtual int retire_warmup_store(const bool is_disk_full);
|
||||
virtual int halt_prewarm();
|
||||
virtual int get_replayed_table_version(int64_t& table_version) override;
|
||||
virtual int get_partition_ss_store_info(common::ObArray<PartitionSSStoreInfo>& partition_ss_store_info_list) override;
|
||||
virtual int get_all_tables(ObTablesHandle& tables_handle) override;
|
||||
virtual int retire_warmup_store(const bool is_disk_full) override;
|
||||
virtual int halt_prewarm() override;
|
||||
|
||||
virtual common::ObReplicaType get_replica_type()
|
||||
virtual common::ObReplicaType get_replica_type() override
|
||||
{
|
||||
return store_.get_replica_type();
|
||||
}
|
||||
virtual int query_range_to_macros(common::ObIAllocator& allocator,
|
||||
const common::ObIArray<common::ObStoreRange>& ranges, const int64_t type, uint64_t* macros_count,
|
||||
const int64_t* total_task_count, common::ObIArray<common::ObStoreRange>* splitted_ranges,
|
||||
common::ObIArray<int64_t>* split_index);
|
||||
virtual int get_multi_ranges_cost(const common::ObIArray<common::ObStoreRange>& ranges, int64_t& total_size);
|
||||
common::ObIArray<int64_t>* split_index) override;
|
||||
virtual int get_multi_ranges_cost(const common::ObIArray<common::ObStoreRange>& ranges, int64_t& total_size) override;
|
||||
virtual int split_multi_ranges(const common::ObIArray<common::ObStoreRange>& ranges,
|
||||
const int64_t expected_task_count, common::ObIAllocator& allocator,
|
||||
common::ObArrayArray<common::ObStoreRange>& multi_range_split_array);
|
||||
common::ObArrayArray<common::ObStoreRange>& multi_range_split_array) override;
|
||||
virtual int append_local_sort_data(const share::ObBuildIndexAppendLocalDataParam& param,
|
||||
const common::ObPGKey& pg_key, const blocksstable::ObStorageFileHandle& file_handle,
|
||||
common::ObNewRowIterator& iter) override;
|
||||
@ -418,12 +418,12 @@ public:
|
||||
{
|
||||
return store_;
|
||||
}
|
||||
int do_warm_up_request(const ObIWarmUpRequest* request);
|
||||
int check_index_need_build(const share::schema::ObTableSchema& index_schema, bool& need_build);
|
||||
int get_build_index_context(const compaction::ObBuildIndexParam& param, compaction::ObBuildIndexContext& context);
|
||||
int do_warm_up_request(const ObIWarmUpRequest* request) override;
|
||||
int check_index_need_build(const share::schema::ObTableSchema& index_schema, bool& need_build) override;
|
||||
int get_build_index_context(const compaction::ObBuildIndexParam& param, compaction::ObBuildIndexContext& context) override;
|
||||
|
||||
int local_sort_index_by_range(
|
||||
const int64_t idx, const compaction::ObBuildIndexParam& param, const compaction::ObBuildIndexContext& context);
|
||||
const int64_t idx, const compaction::ObBuildIndexParam& param, const compaction::ObBuildIndexContext& context) override;
|
||||
|
||||
int get_build_index_param(const uint64_t index_id, const int64_t schema_version, ObIPartitionReport* report,
|
||||
compaction::ObBuildIndexParam& param) override;
|
||||
|
||||
@ -32,9 +32,9 @@ public:
|
||||
}
|
||||
int init(storage::ObPartitionService* ps);
|
||||
void destroy();
|
||||
int start();
|
||||
void stop();
|
||||
void wait();
|
||||
int start() override;
|
||||
void stop() override;
|
||||
void wait() override;
|
||||
|
||||
public:
|
||||
virtual void run1() override;
|
||||
|
||||
@ -30,9 +30,9 @@ public:
|
||||
}
|
||||
int init(storage::ObPartitionService* ps);
|
||||
void destroy();
|
||||
int start();
|
||||
void stop();
|
||||
void wait();
|
||||
int start() override;
|
||||
void stop() override;
|
||||
void wait() override;
|
||||
virtual void run1() override;
|
||||
|
||||
private:
|
||||
|
||||
@ -439,7 +439,7 @@ public:
|
||||
{}
|
||||
|
||||
int init(const common::ObPartitionKey pkey, ObTransService* trans_service);
|
||||
void reset();
|
||||
void reset() override;
|
||||
|
||||
public:
|
||||
virtual void runTimerTask() override;
|
||||
|
||||
@ -264,7 +264,7 @@ public:
|
||||
int init();
|
||||
|
||||
public:
|
||||
uint64_t get_tenant_id() const
|
||||
uint64_t get_tenant_id() const override
|
||||
{
|
||||
return tenant_id_;
|
||||
}
|
||||
@ -304,7 +304,7 @@ public:
|
||||
{
|
||||
return can_elr_;
|
||||
}
|
||||
bool is_valid() const;
|
||||
bool is_valid() const override;
|
||||
virtual int replace_tenant_id(const uint64_t new_tenant_id) override;
|
||||
void set_last()
|
||||
{
|
||||
@ -445,7 +445,7 @@ public:
|
||||
{}
|
||||
|
||||
public:
|
||||
uint64_t get_tenant_id() const
|
||||
uint64_t get_tenant_id() const override
|
||||
{
|
||||
return tenant_id_;
|
||||
}
|
||||
@ -506,7 +506,7 @@ public:
|
||||
{
|
||||
return xid_;
|
||||
}
|
||||
bool is_valid() const;
|
||||
bool is_valid() const override;
|
||||
virtual int replace_tenant_id(const uint64_t new_tenant_id) override;
|
||||
|
||||
TO_STRING_KV(K_(log_type), K_(partition), K_(trans_id), K_(tenant_id), K_(scheduler), K_(coordinator),
|
||||
@ -580,7 +580,7 @@ public:
|
||||
{
|
||||
return split_info_;
|
||||
}
|
||||
bool is_valid() const;
|
||||
bool is_valid() const override;
|
||||
virtual int replace_tenant_id(const uint64_t new_tenant_id) override;
|
||||
TO_STRING_KV(K_(log_type), K_(partition), K_(trans_id), K_(partition_log_info_arr), K_(global_trans_version),
|
||||
K_(checksum), K_(cluster_id));
|
||||
@ -609,7 +609,7 @@ public:
|
||||
{
|
||||
return publish_version_;
|
||||
}
|
||||
bool is_valid() const;
|
||||
bool is_valid() const override;
|
||||
virtual int replace_tenant_id(const uint64_t new_tenant_id) override;
|
||||
|
||||
public:
|
||||
@ -629,7 +629,7 @@ public:
|
||||
{}
|
||||
int init(const int64_t log_type, const common::ObPartitionKey& partition, const ObTransID& trans_id,
|
||||
const PartitionLogInfoArray& partition_log_info_arr, const uint64_t cluster_id);
|
||||
bool is_valid() const;
|
||||
bool is_valid() const override;
|
||||
virtual int replace_tenant_id(const uint64_t new_tenant_id) override;
|
||||
const ObTransSplitInfo& get_split_info() const
|
||||
{
|
||||
@ -661,7 +661,7 @@ private:
|
||||
DISALLOW_COPY_AND_ASSIGN(ObTransClearLog);
|
||||
|
||||
public:
|
||||
bool is_valid() const;
|
||||
bool is_valid() const override;
|
||||
};
|
||||
|
||||
class ObSpTransRedoLog : public ObTransLog {
|
||||
@ -685,7 +685,7 @@ public:
|
||||
const ObElrTransInfoArray& prev_trans_arr, const bool can_elr);
|
||||
|
||||
public:
|
||||
uint64_t get_tenant_id() const
|
||||
uint64_t get_tenant_id() const override
|
||||
{
|
||||
return tenant_id_;
|
||||
}
|
||||
@ -719,7 +719,7 @@ public:
|
||||
{
|
||||
return can_elr_;
|
||||
}
|
||||
bool is_valid() const;
|
||||
bool is_valid() const override;
|
||||
virtual int replace_tenant_id(const uint64_t new_tenant_id) override;
|
||||
|
||||
VIRTUAL_TO_STRING_KV(K_(log_type), K_(partition), K_(trans_id), K_(tenant_id), K_(log_no), K_(trans_param),
|
||||
@ -789,7 +789,7 @@ public:
|
||||
{
|
||||
return prev_trans_arr_;
|
||||
}
|
||||
bool is_valid() const;
|
||||
bool is_valid() const override;
|
||||
virtual int replace_tenant_id(const uint64_t new_tenant_id) override;
|
||||
TO_STRING_KV(K_(log_type), K_(partition), K_(trans_id), K_(tenant_id), K_(log_no), K_(trans_param), K_(cluster_id),
|
||||
K_(active_memstore_version), K_(checksum), K_(prev_redo_log_ids), K_(app_trace_id_str), K_(checkpoint),
|
||||
@ -826,7 +826,7 @@ public:
|
||||
const uint64_t cluster_id);
|
||||
|
||||
public:
|
||||
bool is_valid() const;
|
||||
bool is_valid() const override;
|
||||
virtual int replace_tenant_id(const uint64_t new_tenant_id) override;
|
||||
TO_STRING_KV(K_(log_type), K_(partition), K_(trans_id), K_(cluster_id));
|
||||
|
||||
@ -892,7 +892,7 @@ public:
|
||||
{
|
||||
return create_ts_;
|
||||
}
|
||||
uint64_t get_tenant_id() const
|
||||
uint64_t get_tenant_id() const override
|
||||
{
|
||||
return tenant_id_;
|
||||
}
|
||||
@ -974,7 +974,7 @@ public:
|
||||
}
|
||||
|
||||
public:
|
||||
bool is_valid() const
|
||||
bool is_valid() const override
|
||||
{
|
||||
return true;
|
||||
}
|
||||
@ -1036,7 +1036,7 @@ public:
|
||||
{}
|
||||
|
||||
public:
|
||||
uint64_t get_tenant_id() const
|
||||
uint64_t get_tenant_id() const override
|
||||
{
|
||||
return tenant_id_;
|
||||
}
|
||||
|
||||
@ -153,9 +153,9 @@ public:
|
||||
int init(const ObAddr& self, ObITransRpc* rpc, ObILocationAdapter* location_adapter, ObIClogAdapter* clog_adapter,
|
||||
storage::ObPartitionService* partition_service, share::schema::ObMultiVersionSchemaService* schema_service,
|
||||
ObITsMgr* ts_mgr);
|
||||
int start();
|
||||
void stop();
|
||||
void wait();
|
||||
int start() override;
|
||||
void stop() override;
|
||||
void wait() override;
|
||||
void destroy();
|
||||
int push(void* task);
|
||||
virtual void handle(void* task) override;
|
||||
|
||||
@ -30,9 +30,9 @@ public:
|
||||
destroy();
|
||||
}
|
||||
int init(ObTransService* txs);
|
||||
int start();
|
||||
void stop();
|
||||
void wait();
|
||||
int start() override;
|
||||
void stop() override;
|
||||
void wait() override;
|
||||
void destroy();
|
||||
|
||||
public:
|
||||
@ -48,4 +48,4 @@ private:
|
||||
|
||||
} // namespace oceanbase
|
||||
|
||||
#endif
|
||||
#endif
|
||||
|
||||
@ -29,9 +29,9 @@ public:
|
||||
destroy();
|
||||
}
|
||||
int init(ObTransService* trans_service);
|
||||
int start();
|
||||
void stop();
|
||||
void wait();
|
||||
int start() override;
|
||||
void stop() override;
|
||||
void wait() override;
|
||||
void destroy();
|
||||
|
||||
public:
|
||||
|
||||
Reference in New Issue
Block a user