patch 4.0

This commit is contained in:
wangzelin.wzl
2022-10-24 10:34:53 +08:00
parent 4ad6e00ec3
commit 93a1074b0c
10533 changed files with 2588271 additions and 2299373 deletions

View File

@ -157,7 +157,7 @@ __all_virtual_data_type CREATE TABLE `__all_virtual_data_type` (
`data_type_str` varchar(128) NOT NULL,
`data_type_class` bigint(20) NOT NULL,
PRIMARY KEY (`data_type`)
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10 TABLEGROUP = 'oceanbase'
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10
desc __all_virtual_data_type;
Field Type Null Key Default Extra
data_type bigint(20) NO PRI NULL

View File

@ -104,7 +104,7 @@ __all_virtual_data_type_class CREATE TABLE `__all_virtual_data_type_class` (
`data_type_class` bigint(20) NOT NULL,
`data_type_class_str` varchar(128) NOT NULL,
PRIMARY KEY (`data_type_class`)
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10 TABLEGROUP = 'oceanbase'
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10
desc __all_virtual_data_type_class;
Field Type Null Key Default Extra
data_type_class bigint(20) NO PRI NULL

View File

@ -1,6 +1,6 @@
use oceanbase;
select * from __all_virtual_engine;
Engine Support Comment Transactions XA Savepoints
ENGINE SUPPORT COMMENT TRANSACTIONS XA SAVEPOINTS
OceanBase YES Supports transactions YES NO NO
select Engine, Support, Comment, Transactions, XA, Savepoints from __all_virtual_engine;
Engine Support Comment Transactions XA Savepoints
@ -8,18 +8,18 @@ OceanBase YES Supports transactions YES NO NO
show create table __all_virtual_engine;
Table Create Table
__all_virtual_engine CREATE TABLE `__all_virtual_engine` (
`Engine` varchar(64) NOT NULL,
`Support` varchar(4) NOT NULL,
`Comment` varchar(2048) NOT NULL,
`Transactions` varchar(4) NOT NULL,
`ENGINE` varchar(64) NOT NULL,
`SUPPORT` varchar(4) NOT NULL,
`COMMENT` varchar(2048) NOT NULL,
`TRANSACTIONS` varchar(4) NOT NULL,
`XA` varchar(4) NOT NULL,
`Savepoints` varchar(4) NOT NULL
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10 TABLEGROUP = 'oceanbase'
`SAVEPOINTS` varchar(4) NOT NULL
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10
desc __all_virtual_engine;
Field Type Null Key Default Extra
Engine varchar(64) NO NULL
Support varchar(4) NO NULL
Comment varchar(2048) NO NULL
Transactions varchar(4) NO NULL
ENGINE varchar(64) NO NULL
SUPPORT varchar(4) NO NULL
COMMENT varchar(2048) NO NULL
TRANSACTIONS varchar(4) NO NULL
XA varchar(4) NO NULL
Savepoints varchar(4) NO NULL
SAVEPOINTS varchar(4) NO NULL

View File

@ -1,12 +0,0 @@
select * from oceanbase.__tenant_virtual_interm_result where svr_ip = '0.0.0.0' and svr_port = 0;
job_id task_id slice_id execution_id svr_ip svr_port expire_time row_count scanner_count used_memory_size used_disk_size partition_ip partition_port
select * from oceanbase.__tenant_virtual_interm_result;
select * from oceanbase.__tenant_virtual_interm_result where svr_port > 0;
select * from oceanbase.__tenant_virtual_interm_result where scanner_count > 0;
select * from oceanbase.__tenant_virtual_interm_result where expire_time > 0;
select * from oceanbase.__tenant_virtual_interm_result where used_memory_size > 0;
select * from oceanbase.__tenant_virtual_interm_result where is_serving_tenant(svr_ip, svr_port, 1);
select * from oceanbase.__tenant_virtual_interm_result where is_serving_tenant(svr_ip, svr_port, 1001);
select is_serving_tenant(svr_ip, svr_port, 1), is_serving_tenant(svr_ip, svr_port, 1001) from oceanbase.__tenant_virtual_interm_result where is_serving_tenant(svr_ip, svr_port, 1);
select svr_ip, svr_port from oceanbase.__tenant_virtual_interm_result group by svr_ip, svr_port having is_serving_tenant(svr_ip, svr_port, 1);
select t1.svr_ip, t1.svr_port, t2.svr_ip, t2.svr_port from oceanbase.__tenant_virtual_interm_result t1 join oceanbase.__tenant_virtual_interm_result t2 on is_serving_tenant(t1.svr_ip, t2.svr_port, 1);

View File

@ -1,56 +0,0 @@
desc oceanbase.__all_virtual_pg_partition_info;
Field Type Null Key Default Extra
svr_ip varchar(46) NO NULL
svr_port bigint(20) NO NULL
tenant_id bigint(20) NO NULL
table_id bigint(20) NO NULL
partition_idx bigint(20) NO NULL
tg_id bigint(20) NO NULL
pg_idx bigint(20) NO NULL
max_decided_trans_version bigint(20) NO NULL
max_passed_trans_ts bigint(20) NO NULL
freeze_ts bigint(20) NO NULL
allow_gc tinyint(4) NO NULL
partition_state varchar(128) NO NULL
min_log_service_ts bigint(20) NO -1
min_trans_service_ts bigint(20) NO -1
min_replay_engine_ts bigint(20) NO -1
is_pg tinyint(4) NO NULL
weak_read_timestamp bigint(20) NO -1
replica_type bigint(20) NO 0
use test;
create tablegroup tg1 binding true;
create table test1 (id1 int, id2 int) tablegroup tg1;
create table test2 (id1 int, id2 int) tablegroup tg1;
create table test3 (id1 int, id2 int);
create table test4 (id1 int, id2 int);
select count(1) from oceanbase.__all_virtual_pg_partition_info
where table_id in (select table_id from oceanbase.__all_virtual_table where table_name = 'test1') and partition_state = 'L_WORKING';
count(1)
1
select count(1) from oceanbase.__all_virtual_pg_partition_info
where table_id in (select table_id from oceanbase.__all_virtual_table where table_name = 'test2') and partition_state = 'L_WORKING';
count(1)
1
select count(1) from oceanbase.__all_virtual_pg_partition_info
where table_id in (select table_id from oceanbase.__all_virtual_table where table_name = 'test3') and partition_state = 'L_WORKING';
count(1)
1
select count(1) from oceanbase.__all_virtual_pg_partition_info
where table_id in (select table_id from oceanbase.__all_virtual_table where table_name = 'test4') and partition_state = 'L_WORKING';
count(1)
1
select count(1) from oceanbase.__all_virtual_pg_partition_info
where tg_id in (select tablegroup_id as tg_id from oceanbase.__all_virtual_tablegroup where tablegroup_name = 'tg1') and partition_state = 'L_WORKING';
count(1)
2
select pg_partition_count from oceanbase.__all_virtual_partition_info
where table_id in (select tablegroup_id as table_id from oceanbase.__all_virtual_tablegroup where tablegroup_name = 'tg1') and partition_state = 'L_WORKING';
pg_partition_count
2
drop table if exists test1;
drop table if exists test2;
drop table if exists test3;
drop table if exists test4;
purge recyclebin;
drop tablegroup tg1;

View File

@ -21,179 +21,126 @@ source varchar(64) NO NULL
edit_level varchar(128) NO NULL
select name from __all_virtual_sys_parameter_stat where name not like "module_test_%" group by name order by name;
name
all_cluster_list
all_server_list
audit_sys_operations
audit_trail
autoinc_cache_refresh_interval
auto_broadcast_location_cache_rate_limit
auto_delete_expired_backup
auto_leader_switch_interval
auto_refresh_location_cache_rate_limit
backup_backup_dest
backup_backup_dest_option
backup_concurrency
backup_dest
backup_dest_option
backup_log_archive_option
backup_net_limit
backup_recovery_window
backup_region
backup_zone
balancer_emergency_percentage
backup_data_file_size
balancer_idle_time
balancer_log_interval
balancer_task_timeout
balancer_timeout_check_interval
balancer_tolerance_percentage
balance_blacklist_failure_threshold
balance_blacklist_retry_interval
bf_cache_miss_count_threshold
bf_cache_priority
builtin_db_data_verify_cycle
cache_wash_threshold
clog_cache_priority
clog_disk_usage_limit_percentage
clog_disk_utilization_threshold
clog_max_unconfirmed_log_count
clog_sync_time_warn_threshold
cluster
cluster_id
compaction_high_thread_score
compaction_low_thread_score
compaction_mid_thread_score
config_additional_dir
connection_control_failed_connections_threshold
connection_control_max_connection_delay
connection_control_min_connection_delay
cpu_count
cpu_quota_concurrency
cpu_reserved
datafile_disk_percentage
datafile_maxsize
datafile_next
datafile_size
data_copy_concurrency
data_dir
data_disk_usage_limit_percentage
data_storage_error_tolerance_time
data_storage_warning_tolerance_time
dead_socket_detection_timeout
debug_sync_timeout
default_auto_increment_mode
default_compress
default_compress_func
default_enable_extended_rowid
default_progressive_merge_num
default_row_format
devname
disk_io_thread_count
dtl_buffer_size
election_blacklist_interval
election_cpu_quota
enable_async_syslog
enable_auto_leader_switch
enable_auto_refresh_location_cache
enable_ddl
enable_early_lock_release
enable_election_group
enable_global_freeze_trigger
enable_kv_ttl
enable_log_archive
enable_major_freeze
enable_manual_merge
enable_merge_by_turn
enable_monotonic_weak_read
enable_one_phase_commit
enable_ob_ratelimit
enable_perf_event
enable_rebalance
enable_record_trace_id
enable_record_trace_log
enable_rereplication
enable_rich_error_msg
enable_rootservice_standalone
enable_separate_sys_clog
enable_smooth_leader_switch
enable_sql_audit
enable_sql_extension
enable_sql_operator_dump
enable_syslog_file_compress
enable_syslog_recycle
enable_syslog_wf
enable_sys_table_ddl
enable_sys_unit_standalone
enable_tcp_keepalive
enable_unit_balance_resource_weight
enable_upgrade_mode
fast_recovery_concurrency
flush_log_at_trx_commit
force_refresh_location_cache_interval
force_refresh_location_cache_threshold
external_kms_info
freeze_trigger_percentage
fuse_row_cache_priority
gc_wait_archive
get_leader_candidate_rpc_timeout
global_index_build_single_replica_timeout
global_major_freeze_residual_memory
global_write_halt_residual_memory
gts_refresh_interval
ha_high_thread_score
ha_low_thread_score
ha_mid_thread_score
high_priority_net_thread_count
ignore_replay_checksum_error
ignore_replica_checksum_error
ilog_index_expire_time
index_cache_priority
index_clog_cache_priority
index_info_block_cache_priority
index_block_cache_priority
internal_sql_execute_timeout
kv_ttl_duty_duration
kv_ttl_history_recycle_interval
io_category_config
job_queue_processes
large_query_threshold
large_query_worker_percentage
leak_mod_to_check
lease_time
location_cache_cpu_quota
location_cache_expire_time
location_cache_priority
location_cache_refresh_min_interval
location_cache_refresh_rpc_timeout
location_cache_refresh_sql_timeout
location_fetch_concurrency
location_refresh_thread_count
log_archive_batch_buffer_limit
log_archive_checkpoint_interval
log_archive_concurrency
log_disk_percentage
log_disk_size
log_restore_concurrency
log_disk_utilization_limit_threshold
log_disk_utilization_threshold
ls_meta_table_check_interval
major_compact_trigger
major_freeze_duty_time
max_kept_major_version_number
max_px_worker_count
max_stale_time_for_weak_consistency
max_string_print_length
max_syslog_file_count
max_syslog_file_time
memory_chunk_cache_size
memory_limit
memory_limit_percentage
memory_reserved
memstore_limit_percentage
merger_check_interval
merger_completion_percentage
merger_switch_leader_duration_time
merger_warm_up_duration_time
merge_stat_sampling_ratio
merge_thread_count
meta_table_read_write_mode
micro_block_merge_verify_level
migrate_concurrency
migration_disable_time
minor_compact_trigger
minor_deferred_gc_time
minor_freeze_times
minor_merge_concurrency
minor_warm_up_duration_time
min_observer_version
multiblock_read_gap_size
multiblock_read_size
mysql_port
net_thread_count
obconfig_url
ob_compaction_schedule_interval
ob_enable_batched_multi_statement
ob_event_history_recycle_interval
ob_proxy_readonly_transaction_routing_policy
ob_query_switch_leader_retry_timeout
ob_ratelimit_stat_period
ob_ssl_invited_common_names
open_cursors
partition_table_check_interval
partition_table_scan_batch_count
opt_tab_stat_cache_priority
plan_cache_evict_interval
plan_cache_high_watermark
plan_cache_low_watermark
@ -208,12 +155,10 @@ px_workers_per_cpu_quota
query_response_time_flush
query_response_time_range_base
query_response_time_stats
rebuild_replica_data_lag_threshold
rdma_io_thread_count
recyclebin_object_expire_time
redundancy_level
replica_safe_remove_time
resource_hard_limit
resource_soft_limit
restore_concurrency
rootservice_async_task_queue_size
rootservice_async_task_thread_count
@ -221,7 +166,6 @@ rootservice_list
rootservice_memory_limit
rootservice_ready_check_interval
row_compaction_update_limit
row_purge_thread_count
rpc_port
rpc_timeout
schema_history_expire_time
@ -232,152 +176,142 @@ server_balance_disk_tolerance_percent
server_check_interval
server_cpu_quota_max
server_cpu_quota_min
server_data_copy_in_concurrency
server_data_copy_out_concurrency
server_permanent_offline_time
server_temporary_offline_time
sql_audit_memory_limit
sql_audit_queue_size
sql_login_thread_count
sql_work_area
ssl_client_authentication
ssl_external_kms_info
stack_size
switchover_process_thread_count
syslog_io_bandwidth_limit
syslog_level
system_cpu_quota
system_memory
system_trace_level
sys_bkgd_io_high_percentage
sys_bkgd_io_low_percentage
sys_bkgd_migration_change_member_list_timeout
sys_bkgd_migration_retry_num
sys_bkgd_net_percentage
sys_cpu_limit_trigger
tableapi_transport_compress_func
tablet_ls_cache_priority
tablet_meta_table_check_interval
tablet_meta_table_scan_batch_count
tablet_size
tcp_keepcnt
tcp_keepidle
tcp_keepintvl
tde_method
tenant_cpu_variation_per_server
tenant_groups
tenant_task_queue_size
token_reserved_percentage
trace_log_sampling_interval
trace_log_slow_query_watermark
trx_2pc_retry_interval
trx_force_kill_threshold
trx_try_wait_lock_timeout
unit_balance_resource_weight
undo_retention
user_block_cache_priority
user_iort_up_percentage
user_row_cache_priority
user_tab_col_stat_cache_priority
use_ipv6
use_large_pages
virtual_table_location_cache_expire_time
wait_leader_batch_count
weak_read_version_refresh_interval
workarea_size_policy
workers_per_cpu_quota
writing_throttling_maximum_duration
writing_throttling_trigger_percentage
zone
zone_merge_concurrency
zone_merge_order
zone_merge_timeout
_alter_column_mode
_auto_drop_tenant_if_restore_failed
_auto_update_reserved_backup_timestamp
_advance_checkpoint_timeout
_audit_mode
_backup_idle_time
_backup_retry_timeout
_backup_task_keep_alive_interval
_backup_task_keep_alive_timeout
_bloom_filter_enabled
_bloom_filter_ratio
_cache_wash_interval
_chunk_row_store_mem_limit
_clog_aggregation_buffer_amount
_create_table_partition_distribution_strategy
_datafile_usage_lower_bound_percentage
_datafile_usage_upper_bound_percentage
_ctx_memory_limit
_data_storage_io_timeout
_enable_block_file_punch_hole
_enable_compaction_diagnose
_enable_convert_real_to_decimal
_enable_defensive_check
_enable_dist_data_access_service
_enable_easy_keepalive
_enable_fast_commit
_enable_filter_push_down_storage
_enable_fulltext_index
_enable_hash_join_hasher
_enable_hash_join_processor
_enable_ha_gts_full_service
_enable_newsort
_enable_new_sql_nio
_enable_oracle_priv_check
_enable_parallel_minor_merge
_enable_partition_level_retry
_enable_plan_cache_mem_diagnosis
_enable_sparse_row
_enable_static_typing_engine
_enable_trans_ctx_size_limit
_flush_clog_aggregation_buffer_timeout
_follower_replica_merge_level
_enable_px_batch_rescan
_enable_px_bloom_filter_sync
_enable_px_ordered_coord
_enable_resource_limit_spec
_enable_trace_session_leak
_fast_commit_callback_count
_follower_snapshot_read_retry_duration
_force_hash_groupby_dump
_force_hash_join_spill
_gts_core_num
_force_skip_encoding_partition_id
_hash_area_size
_ignore_system_memory_over_limit_error
_io_callback_thread_count
_large_query_io_percentage
_lcl_op_interval
_max_elr_dependent_trx_count
_max_partition_cnt_per_server
_max_schema_slot_num
_max_trx_size
_migrate_block_verify_level
_mini_merge_concurrency
_minor_compaction_amplification_factor
_minor_compaction_interval
_minor_deferred_gc_level
_ob_clog_disk_buffer_cnt
_ob_clog_timeout_to_force_switch_leader
_ob_ddl_timeout
_ob_elr_fast_freeze_threshold
_ob_enable_fast_freeze
_ob_enable_log_replica_strict_recycle_mode
_ob_enable_fast_parser
_ob_enable_prepared_statement
_ob_enable_px_for_inner_sql
_ob_get_gts_ahead_interval
_ob_minor_merge_schedule_interval
_ob_max_thread_num
_ob_obj_dep_maint_task_interval
_ob_plan_cache_gc_strategy
_ob_query_rate_limit
_ob_ssl_invited_nodes
_ob_sys_high_load_per_cpu_threshold
_ob_trans_rpc_timeout
_parallel_max_active_sessions
_parallel_min_message_pool
_parallel_server_sleep_time
_partition_balance_strategy
_print_sample_ppm
_private_buffer_size
_pushdown_storage_level
_px_bloom_filter_group_size
_px_chunklist_count_ratio
_px_max_message_pool_pct
_px_max_pipeline_depth
_px_message_compression
_px_object_sampling
_recyclebin_object_purge_frequency
_resource_limit_spec
_restore_idle_time
_rowsets_enabled
_rowsets_max_rows
_rowsets_target_maxsize
_rpc_checksum
_single_zone_deployment_on
_send_bloom_filter_size
_session_context_size
_sort_area_size
_sqlexec_disable_hash_based_distagg_tiv
_storage_meta_memory_limit_percentage
_temporary_file_io_area_size
_trx_commit_retry_interval
_trace_control_info
_upgrade_stage
_xa_gc_interval
_xa_gc_timeout
__balance_controller
__easy_memory_limit
__easy_memory_reserved_percentage
__enable_identical_partition_distribution
__enable_small_tenant
__min_full_resource_pool_memory
__schema_split_mode
select section,info from oceanbase.__all_virtual_sys_parameter_stat where name like '%major%' group by name;
section info
DAILY_MERGE the maximum number of kept major versions. Range: [1, 16] in integer
DAILY_MERGE the start time of system daily merge procedure. Range: [00:00, 24:00)
OBSERVER post global major freeze when observer memstore free memory(plus memory held by frozen memstore and blockcache) reach this limit. Rang:(0, 100)limit calc by (memory_limit - system_memory) * global_major_freeze_residual_memory/100
ROOT_SERVICE specifies whether major_freeze function is turned on. Value: True:turned on; False: turned off
TENANT major_compact_trigger alias to minor_freeze_times, Range: [0,65535] in integer
TENANT specifies how many minor freeze should be triggered between two major freeze, Range: [0,65535] in integer
show parameters;
show parameters like '%log%';

View File

@ -8,7 +8,4 @@ zone_check succeed
sys_stat_check succeed
sys_param_check succeed
sys_table_schema_check succeed
STATISTIC_PRIMARY_ZONE_ENTITY_COUNT succeed
SCHEMA_SPLIT_V2 succeed
SCHEMA_REVISE succeed
all_check succeed

View File

@ -3,14 +3,23 @@ select * from character_sets;
CHARACTER_SET_NAME DEFAULT_COLLATE_NAME DESCRIPTION MAXLEN
binary binary Binary pseudo charset 1
utf8mb4 utf8mb4_general_ci UTF-8 Unicode 4
gbk gbk_chinese_ci GBK charset 2
utf16 utf16_general_ci UTF-16 Unicode 2
gb18030 gb18030_chinese_ci GB18030 charset 4
select character_set_name, default_collate_name, description, maxlen from character_sets;
character_set_name default_collate_name description maxlen
binary binary Binary pseudo charset 1
utf8mb4 utf8mb4_general_ci UTF-8 Unicode 4
gbk gbk_chinese_ci GBK charset 2
utf16 utf16_general_ci UTF-16 Unicode 2
gb18030 gb18030_chinese_ci GB18030 charset 4
select maxlen from character_sets;
maxlen
1
4
2
2
4
select * from character_sets where character_set_name like '%binary%';
CHARACTER_SET_NAME DEFAULT_COLLATE_NAME DESCRIPTION MAXLEN
binary binary Binary pseudo charset 1

View File

@ -1,28 +0,0 @@
use information_schema;
select * from collation_character_set_applicability;
COLLATION_NAME CHARACTER_SET_NAME
utf8mb4_general_ci utf8mb4
utf8mb4_bin utf8mb4
binary binary
select COLLATION_NAME, CHARACTER_SET_NAME from collation_character_set_applicability;
COLLATION_NAME CHARACTER_SET_NAME
utf8mb4_general_ci utf8mb4
utf8mb4_bin utf8mb4
binary binary
select COLLATION_NAME from collation_character_set_applicability;
COLLATION_NAME
utf8mb4_general_ci
utf8mb4_bin
binary
select CHARACTER_SET_NAME from collation_character_set_applicability;
CHARACTER_SET_NAME
utf8mb4
utf8mb4
binary
select * from collation_character_set_applicability where COLLATION_NAME = 'utf8mb4_bin';
COLLATION_NAME CHARACTER_SET_NAME
utf8mb4_bin utf8mb4
desc collation_character_set_applicability;
Field Type Null Key Default Extra
COLLATION_NAME varchar(128) NO
CHARACTER_SET_NAME varchar(128) NO

View File

@ -4,15 +4,32 @@ COLLATION_NAME CHARACTER_SET_NAME ID IS_DEFAULT IS_COMPILED SORTLEN
utf8mb4_general_ci utf8mb4 45 Yes Yes 1
utf8mb4_bin utf8mb4 46 Yes 1
binary binary 63 Yes Yes 1
gbk_chinese_ci gbk 28 Yes Yes 1
gbk_bin gbk 87 Yes 1
utf16_general_ci utf16 54 Yes Yes 1
utf16_bin utf16 55 Yes 1
utf8mb4_unicode_ci utf8mb4 224 Yes 1
utf16_unicode_ci utf16 101 Yes 1
gb18030_chinese_ci gb18030 248 Yes Yes 1
gb18030_bin gb18030 249 Yes 1
select collation_name, character_set_name, id, is_default, is_compiled, sortlen from collations;
collation_name character_set_name id is_default is_compiled sortlen
utf8mb4_general_ci utf8mb4 45 Yes Yes 1
utf8mb4_bin utf8mb4 46 Yes 1
binary binary 63 Yes Yes 1
gbk_chinese_ci gbk 28 Yes Yes 1
gbk_bin gbk 87 Yes 1
utf16_general_ci utf16 54 Yes Yes 1
utf16_bin utf16 55 Yes 1
utf8mb4_unicode_ci utf8mb4 224 Yes 1
utf16_unicode_ci utf16 101 Yes 1
gb18030_chinese_ci gb18030 248 Yes Yes 1
gb18030_bin gb18030 249 Yes 1
select * from collations where collation_name like '%utf8%';
COLLATION_NAME CHARACTER_SET_NAME ID IS_DEFAULT IS_COMPILED SORTLEN
utf8mb4_general_ci utf8mb4 45 Yes Yes 1
utf8mb4_bin utf8mb4 46 Yes 1
utf8mb4_unicode_ci utf8mb4 224 Yes 1
show create table collations;
View Create View character_set_client collation_connection
COLLATIONS CREATE VIEW `COLLATIONS` AS select collation as COLLATION_NAME, charset as CHARACTER_SET_NAME, id as ID, `is_default` as IS_DEFAULT, is_compiled as IS_COMPILED, sortlen as SORTLEN from oceanbase.__tenant_virtual_collation utf8mb4 utf8mb4_general_ci

View File

@ -7,7 +7,7 @@ Table Create Table
GLOBAL_STATUS CREATE TABLE `GLOBAL_STATUS` (
`VARIABLE_NAME` varchar(128) NOT NULL DEFAULT '',
`VARIABLE_VALUE` varchar(1024) DEFAULT NULL
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10 TABLEGROUP = 'oceanbase'
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10
desc global_status;
Field Type Null Key Default Extra
VARIABLE_NAME varchar(128) NO

View File

@ -2,9 +2,9 @@ drop table if exists pt1;
create table pt1 (c1 int primary key, c2 int) partition by key(c1) partitions 3;
select * from information_schema.partitions where table_name = 'pt1';
TABLE_CATALOG TABLE_SCHEMA TABLE_NAME PARTITION_NAME SUBPARTITION_NAME PARTITION_ORDINAL_POSITION SUBPARTITION_ORDINAL_POSITION PARTITION_METHOD SUBPARTITION_METHOD PARTITION_EXPRESSION SUBPARTITION_EXPRESSION PARTITION_DESCRIPTION TABLE_ROWS AVG_ROW_LENGTH DATA_LENGTH MAX_DATA_LENGTH INDEX_LENGTH DATA_FREE CREATE_TIME UPDATE_TIME CHECK_TIME CHECKSUM PARTITION_COMMENT NODEGROUP TABLESPACE_NAME
def test pt1 p0 NULL 0 0 KEY NULL c1 NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL default
def test pt1 p1 NULL 1 0 KEY NULL c1 NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL default
def test pt1 p2 NULL 2 0 KEY NULL c1 NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL default
def test pt1 p0 NULL 1 NULL KEY NULL c1 NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL default NULL
def test pt1 p1 NULL 2 NULL KEY NULL c1 NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL default NULL
def test pt1 p2 NULL 3 NULL KEY NULL c1 NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL NULL default NULL
select table_schema, table_name from information_schema.partitions where table_name = 'pt1';
table_schema table_name
test pt1

View File

@ -4,7 +4,7 @@ CATALOG_NAME SCHEMA_NAME DEFAULT_CHARACTER_SET_NAME DEFAULT_COLLATION_NAME SQL_P
select schema_name from schemata;
show create view schemata;
View Create View character_set_client collation_connection
SCHEMATA CREATE VIEW `SCHEMATA` AS SELECT 'def' AS CATALOG_NAME, DATABASE_NAME AS SCHEMA_NAME, 'utf8mb4' AS DEFAULT_CHARACTER_SET_NAME, 'utf8mb4_general_ci' AS DEFAULT_COLLATION_NAME, NULL AS SQL_PATH, 'NO' as DEFAULT_ENCRYPTION FROM oceanbase.__all_virtual_database a WHERE a.tenant_id = effective_tenant_id() and in_recyclebin = 0 and database_name != '__recyclebin' utf8mb4 utf8mb4_general_ci
SCHEMATA CREATE VIEW `SCHEMATA` AS SELECT 'def' AS CATALOG_NAME, DATABASE_NAME AS SCHEMA_NAME, 'utf8mb4' AS DEFAULT_CHARACTER_SET_NAME, 'utf8mb4_general_ci' AS DEFAULT_COLLATION_NAME, NULL AS SQL_PATH, 'NO' as DEFAULT_ENCRYPTION FROM oceanbase.__all_database a WHERE a.tenant_id = 0 and in_recyclebin = 0 and database_name != '__recyclebin' utf8mb4 utf8mb4_general_ci
desc schemata;
Field Type Null Key Default Extra
CATALOG_NAME varchar(3) NO

View File

@ -7,7 +7,7 @@ Table Create Table
GLOBAL_STATUS CREATE TABLE `GLOBAL_STATUS` (
`VARIABLE_NAME` varchar(128) NOT NULL DEFAULT '',
`VARIABLE_VALUE` varchar(1024) DEFAULT NULL
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10 TABLEGROUP = 'oceanbase'
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10
desc global_status;
Field Type Null Key Default Extra
VARIABLE_NAME varchar(128) NO

View File

@ -17,7 +17,7 @@ Table Create Table
SESSION_VARIABLES CREATE TABLE `SESSION_VARIABLES` (
`VARIABLE_NAME` varchar(128) NOT NULL DEFAULT '',
`VARIABLE_VALUE` varchar(1024) DEFAULT NULL
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10 TABLEGROUP = 'oceanbase'
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10
desc session_variables;
Field Type Null Key Default Extra
VARIABLE_NAME varchar(128) NO

View File

@ -7,13 +7,13 @@ create table t2(c1 int unique, c2 int, c3 varchar(10), c4 varchar(10), constrain
constraint test_for_table_constraints_fk_name_1 foreign key (c1) references t1(c1),
constraint test_for_table_constraints_fk_name_2 foreign key (c2) references t2(c1));
select * from information_schema.table_constraints where CONSTRAINT_SCHEMA = 'xiaofeng_db';
+--------------------+-------------------+---------------------------------------+--------------+------------+-----------------+
| CONSTRAINT_CATALOG | CONSTRAINT_SCHEMA | CONSTRAINT_NAME | TABLE_SCHEMA | TABLE_NAME | CONSTRAINT_TYPE |
+--------------------+-------------------+---------------------------------------+--------------+------------+-----------------+
| def | xiaofeng_db | PRIMARY | xiaofeng_db | t1 | PRIMARY KEY |
| def | xiaofeng_db | c1 | xiaofeng_db | t2 | UNIQUE |
| def | xiaofeng_db | test_for_table_constraints_check_name | xiaofeng_db | t2 | CHECK |
| def | xiaofeng_db | test_for_table_constraints_fk_name_2 | xiaofeng_db | t2 | FOREIGN KEY |
| def | xiaofeng_db | test_for_table_constraints_fk_name_1 | xiaofeng_db | t2 | FOREIGN KEY |
+--------------------+-------------------+---------------------------------------+--------------+------------+-----------------+
+--------------------+-------------------+---------------------------------------+--------------+------------+-----------------+----------+
| CONSTRAINT_CATALOG | CONSTRAINT_SCHEMA | CONSTRAINT_NAME | TABLE_SCHEMA | TABLE_NAME | CONSTRAINT_TYPE | ENFORCED |
+--------------------+-------------------+---------------------------------------+--------------+------------+-----------------+----------+
| def | xiaofeng_db | PRIMARY | xiaofeng_db | t1 | PRIMARY KEY | YES |
| def | xiaofeng_db | c1 | xiaofeng_db | t2 | UNIQUE | YES |
| def | xiaofeng_db | test_for_table_constraints_check_name | xiaofeng_db | t2 | CHECK | YES |
| def | xiaofeng_db | test_for_table_constraints_fk_name_2 | xiaofeng_db | t2 | FOREIGN KEY | YES |
| def | xiaofeng_db | test_for_table_constraints_fk_name_1 | xiaofeng_db | t2 | FOREIGN KEY | YES |
+--------------------+-------------------+---------------------------------------+--------------+------------+-----------------+----------+
drop database xiaofeng_db;

View File

@ -11,7 +11,7 @@ TABLE_PRIVILEGES CREATE TABLE `TABLE_PRIVILEGES` (
`TABLE_NAME` varchar(64) NOT NULL DEFAULT '',
`PRIVILEGE_TYPE` varchar(64) NOT NULL DEFAULT '',
`IS_GRANTABLE` varchar(3) NOT NULL DEFAULT ''
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10 TABLEGROUP = 'oceanbase'
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10
desc information_schema.table_privileges;
Field Type Null Key Default Extra
GRANTEE varchar(81) NO

View File

@ -1,28 +0,0 @@
use oceanbase;
desc __tenant_virtual_event_name;
Field Type Null Key Default Extra
tenant_id bigint(20) NO NULL
event_id bigint(20) NO NULL
event# bigint(20) NO NULL
name varchar(64) NO NULL
display_name varchar(64) NO NULL
parameter1 varchar(64) NO NULL
parameter2 varchar(64) NO NULL
parameter3 varchar(64) NO NULL
wait_class_id bigint(20) NO NULL
wait_class# bigint(20) NO NULL
wait_class varchar(64) NO NULL
desc v$event_name;
Field Type Null Key Default Extra
CON_ID bigint(20) NO NULL
EVENT_ID bigint(20) NO NULL
EVENT# bigint(20) NO NULL
NAME varchar(64) NO NULL
DISPLAY_NAME varchar(64) NO NULL
PARAMETER1 varchar(64) NO NULL
PARAMETER2 varchar(64) NO NULL
PARAMETER3 varchar(64) NO NULL
WAIT_CLASS_ID bigint(20) NO NULL
WAIT_CLASS# bigint(20) NO NULL
WAIT_CLASS varchar(64) NO NULL
succeed

View File

@ -1,8 +0,0 @@
desc oceanbase.__tenant_virtual_partition_stat;
Field Type Null Key Default Extra
table_id bigint(20) NO NULL
partition_id bigint(20) NO NULL
partition_cnt bigint(20) NO NULL
row_count bigint(20) NO NULL
diff_percentage bigint(20) NO NULL
pass

View File

@ -5,7 +5,7 @@ USER_PRIVILEGES CREATE TABLE `USER_PRIVILEGES` (
`TABLE_CATALOG` varchar(4096) NOT NULL DEFAULT '',
`PRIVILEGE_TYPE` varchar(64) NOT NULL DEFAULT '',
`IS_GRANTABLE` varchar(3) NOT NULL DEFAULT ''
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10 TABLEGROUP = 'oceanbase'
) DEFAULT CHARSET = utf8mb4 COMPRESSION = 'none' REPLICA_NUM = NUM BLOCK_SIZE = SIZE USE_BLOOM_FILTER = FALSE TABLET_SIZE = SIZE PCTFREE = 10
desc information_schema.user_privileges;
Field Type Null Key Default Extra
GRANTEE varchar(81) NO
@ -63,6 +63,8 @@ GRANTEE TABLE_CATALOG PRIVILEGE_TYPE IS_GRANTABLE
'root'@'%' def ALTER SYSTEM YES
'root'@'%' def CREATE RESOURCE POOL YES
'root'@'%' def CREATE RESOURCE UNIT YES
'root'@'%' def REPLICATION SLAVE YES
'root'@'%' def REPLICATION CLIENT YES
'admin'@'%' def ALTER YES
'admin'@'%' def CREATE YES
'admin'@'%' def CREATE USER YES
@ -83,3 +85,5 @@ GRANTEE TABLE_CATALOG PRIVILEGE_TYPE IS_GRANTABLE
'admin'@'%' def ALTER SYSTEM YES
'admin'@'%' def CREATE RESOURCE POOL YES
'admin'@'%' def CREATE RESOURCE UNIT YES
'admin'@'%' def REPLICATION SLAVE YES
'admin'@'%' def REPLICATION CLIENT YES

File diff suppressed because one or more lines are too long

View File

@ -1,22 +0,0 @@
--disable_query_log
set @@session.explicit_defaults_for_timestamp=off;
--enable_query_log
# owner: yuchen.wyc
# owner group: SQL1
# description: 虚拟表__tenant_virtual_interm_result的简单测试
select * from oceanbase.__tenant_virtual_interm_result where svr_ip = '0.0.0.0' and svr_port = 0;
--disable_result_log
select * from oceanbase.__tenant_virtual_interm_result;
select * from oceanbase.__tenant_virtual_interm_result where svr_port > 0;
select * from oceanbase.__tenant_virtual_interm_result where scanner_count > 0;
select * from oceanbase.__tenant_virtual_interm_result where expire_time > 0;
select * from oceanbase.__tenant_virtual_interm_result where used_memory_size > 0;
select * from oceanbase.__tenant_virtual_interm_result where is_serving_tenant(svr_ip, svr_port, 1);
select * from oceanbase.__tenant_virtual_interm_result where is_serving_tenant(svr_ip, svr_port, 1001);
select is_serving_tenant(svr_ip, svr_port, 1), is_serving_tenant(svr_ip, svr_port, 1001) from oceanbase.__tenant_virtual_interm_result where is_serving_tenant(svr_ip, svr_port, 1);
--sorted_result
select svr_ip, svr_port from oceanbase.__tenant_virtual_interm_result group by svr_ip, svr_port having is_serving_tenant(svr_ip, svr_port, 1);
select t1.svr_ip, t1.svr_port, t2.svr_ip, t2.svr_port from oceanbase.__tenant_virtual_interm_result t1 join oceanbase.__tenant_virtual_interm_result t2 on is_serving_tenant(t1.svr_ip, t2.svr_port, 1);
--enable_result_log

View File

@ -1,54 +0,0 @@
--disable_query_log
set @@session.explicit_defaults_for_timestamp=off;
--enable_query_log
#owner : shanyan.g
#owner group : transaction
#description : 测试虚拟表__all_virtual_pg_partition_info
--disable_abort_on_error
--disable_warnings
connect (conn_admin,$OBMYSQL_MS0,admin@sys,admin,*NO-ONE*,$OBMYSQL_PORT);
## case:检查表结构
desc oceanbase.__all_virtual_pg_partition_info;
#测试PG内的表
use test;
create tablegroup tg1 binding true;
create table test1 (id1 int, id2 int) tablegroup tg1;
create table test2 (id1 int, id2 int) tablegroup tg1;
#创建非PG的表
create table test3 (id1 int, id2 int);
create table test4 (id1 int, id2 int);
sleep 5;
#预期记录有1条
select count(1) from oceanbase.__all_virtual_pg_partition_info
where table_id in (select table_id from oceanbase.__all_virtual_table where table_name = 'test1') and partition_state = 'L_WORKING';
select count(1) from oceanbase.__all_virtual_pg_partition_info
where table_id in (select table_id from oceanbase.__all_virtual_table where table_name = 'test2') and partition_state = 'L_WORKING';
select count(1) from oceanbase.__all_virtual_pg_partition_info
where table_id in (select table_id from oceanbase.__all_virtual_table where table_name = 'test3') and partition_state = 'L_WORKING';
select count(1) from oceanbase.__all_virtual_pg_partition_info
where table_id in (select table_id from oceanbase.__all_virtual_table where table_name = 'test4') and partition_state = 'L_WORKING';
#预期记录有2条
select count(1) from oceanbase.__all_virtual_pg_partition_info
where tg_id in (select tablegroup_id as tg_id from oceanbase.__all_virtual_tablegroup where tablegroup_name = 'tg1') and partition_state = 'L_WORKING';
#根据all_virtual_partition_info来查询pg下的count数量,预期为2
select pg_partition_count from oceanbase.__all_virtual_partition_info
where table_id in (select tablegroup_id as table_id from oceanbase.__all_virtual_tablegroup where tablegroup_name = 'tg1') and partition_state = 'L_WORKING';
--disable_warnings
drop table if exists test1;
drop table if exists test2;
drop table if exists test3;
drop table if exists test4;
purge recyclebin;
drop tablegroup tg1;
--enable_warnings
--enable_abort_on_error
--enable_warnings

View File

@ -1,7 +1,7 @@
--disable_query_log
set @@session.explicit_defaults_for_timestamp=off;
--enable_query_log
# owner: guoping.wgp
# owner: link.zt
# owner group: SQL1
# description: 测试虚拟表__all_virtual_sys_parameter_stat
#tags : parameter

View File

@ -1,18 +0,0 @@
--disable_query_log
set @@session.explicit_defaults_for_timestamp=off;
--enable_query_log
#owner : xiaofeng.lby
#owner group : sql2
#desription : test collation_character_set_applicability
use information_schema;
select * from collation_character_set_applicability;
select COLLATION_NAME, CHARACTER_SET_NAME from collation_character_set_applicability;
select COLLATION_NAME from collation_character_set_applicability;
select CHARACTER_SET_NAME from collation_character_set_applicability;
select * from collation_character_set_applicability where COLLATION_NAME = 'utf8mb4_bin';
desc collation_character_set_applicability;

View File

@ -18,31 +18,31 @@ connect (obsys1,$OBMYSQL_MS0,admin,$OBMYSQL_PWD,test,$OBMYSQL_PORT);
connection obsys1;
use oceanbase;
set @@ob_query_timeout = 10000000000;
set @@ob_query_timeout = 100000000;
set @@ob_log_level = 'WARN';
##overall check
select 0xffffffffff & table_id, table_name, table_type, database_id, part_num from oceanbase.__all_virtual_table where table_type in (0,1,2) order by 1,2;
select 0xffffffffff & table_id, table_name, table_type, database_id, part_num from oceanbase.__all_virtual_table where tenant_id = 1 and table_type in (0,1,2) order by 1,2;
##check count and table_id range (0, 10000] for inner sys table
let $sys_table_count = query_get_value(select count(table_id) from __all_virtual_table where table_type=0, count(table_id), 1);
let $sys_table_count_with_tid = query_get_value(select count(table_id) from __all_virtual_table where table_type=0 and (0xffffffffff & table_id) <= 10000, count(table_id), 1);
let $sys_table_count = query_get_value(select count(table_id) from __all_virtual_table where tenant_id = 1 and table_type=0, count(table_id), 1);
let $sys_table_count_with_tid = query_get_value(select count(table_id) from __all_virtual_table where tenant_id = 1 and table_type=0 and (0xffffffffff & table_id) <= 10000, count(table_id), 1);
if ($sys_table_count == $sys_table_count_with_tid)
{
--echo check sys table count and table_id range success
}
##check count and table_id range (10000, 20000] for inner virtual table
let $virtual_table_count = query_get_value(select count(table_id) from __all_virtual_table where table_type=2, count(table_id), 1);
let $virtual_table_count_with_tid = query_get_value(select count(table_id) from __all_virtual_table where table_type=2 and (0xffffffffff & table_id) > 10000 and (0xffffffffff & table_id) <= 20000, count(table_id), 1);
let $virtual_table_count = query_get_value(select count(table_id) from __all_virtual_table where tenant_id = 1 and table_type=2, count(table_id), 1);
let $virtual_table_count_with_tid = query_get_value(select count(table_id) from __all_virtual_table where tenant_id = 1 and table_type=2 and (0xffffffffff & table_id) > 10000 and (0xffffffffff & table_id) <= 20000, count(table_id), 1);
if ($virtual_table_count == $virtual_table_count_with_tid)
{
--echo check count and table_id range for virtual table success
}
##check count and table_id range (10000, 20000] for inner view
let $view_count = query_get_value(select count(table_id) from __all_virtual_table where table_type=1, count(table_id), 1);
let $view_count_with_tid = query_get_value(select count(table_id) from __all_virtual_table where table_type=1 and (0xffffffffff & table_id) > 20000 and (0xffffffffff & table_id) <= 30000, count(table_id), 1);
let $view_count = query_get_value(select count(table_id) from __all_virtual_table where tenant_id = 1 and table_type=1, count(table_id), 1);
let $view_count_with_tid = query_get_value(select count(table_id) from __all_virtual_table where tenant_id = 1 and table_type=1 and (0xffffffffff & table_id) > 20000 and (0xffffffffff & table_id) <= 30000, count(table_id), 1);
if ($view_table_count == $view_count_with_tid)
{
--echo check count and table_id range for view success
@ -52,315 +52,19 @@ if ($view_table_count == $view_count_with_tid)
## Check all sys tables created before 2018-11-15, new table added after this date should
## add it's own case, can not depends on this hot point any more.
##
## table list are selected by: select concat(a, ".", b) from (select d.database_name a, t.table_name b from __all_virtual_database d, __all_virtual_table t where t.database_id = d.database_id and t.table_type in (0, 1, 2) and t.table_name not in ('__tenant_virtual_all_table','__tenant_virtual_current_tenant','__tenant_virtual_show_create_table','__tenant_virtual_show_create_database','__tenant_virtual_table_column','__all_virtual_proxy_schema', '__all_virtual_proxy_partition_info', '__all_virtual_proxy_partition', '__all_virtual_proxy_sub_partition', '__all_virtual_proxy_route','__tenant_virtual_show_create_procedure', '__all_virtual_partition_location', '__tenant_virtual_show_tables', '__tenant_virtual_show_create_tablegroup') order by 1,2) x;
## table list are selected by: select concat(a, ".", b) from (select d.database_name a, t.table_name b from __all_virtual_database d, __all_virtual_table t where t.database_id = d.database_id and t.table_type in (0, 1, 2) and t.table_name not in ('__tenant_virtual_all_table','__tenant_virtual_current_tenant','__tenant_virtual_show_create_table','__tenant_virtual_show_create_database','__tenant_virtual_table_column','__all_virtual_proxy_schema', '__all_virtual_proxy_partition_info', '__all_virtual_proxy_partition', '__all_virtual_proxy_sub_partition', '__tenant_virtual_show_create_procedure', '__all_virtual_partition_location', '__tenant_virtual_show_tables', '__tenant_virtual_show_create_tablegroup') order by 1,2) x;
#
desc information_schema.CHARACTER_SETS;
desc information_schema.COLLATIONS;
desc information_schema.COLLATION_CHARACTER_SET_APPLICABILITY;
desc information_schema.COLUMNS;
desc information_schema.DBA_OUTLINES;
desc information_schema.ENGINES;
desc information_schema.GLOBAL_STATUS;
desc information_schema.GLOBAL_VARIABLES;
desc information_schema.KEY_COLUMN_USAGE;
desc information_schema.PARAMETERS;
desc information_schema.PARTITIONS;
desc information_schema.PROCESSLIST;
desc information_schema.ROUTINES;
desc information_schema.SCHEMATA;
desc information_schema.SCHEMA_PRIVILEGES;
desc information_schema.SESSION_STATUS;
desc information_schema.SESSION_VARIABLES;
desc information_schema.STATISTICS;
desc information_schema.TABLES;
desc information_schema.TABLE_CONSTRAINTS;
desc information_schema.TABLE_PRIVILEGES;
desc information_schema.USER_PRIVILEGES;
desc information_schema.USER_RECYCLEBIN;
desc information_schema.VIEWS;
desc information_schema.TRIGGERS;
desc mysql.db;
desc mysql.proc;
desc mysql.time_zone;
desc mysql.time_zone_name;
desc mysql.time_zone_transition;
desc mysql.time_zone_transition_type;
desc mysql.user;
desc oceanbase.gv$concurrent_limit_sql;
desc oceanbase.gv$database;
desc oceanbase.gv$latch;
desc oceanbase.gv$lock_wait_stat;
desc oceanbase.gv$memory;
desc oceanbase.gv$memstore;
desc oceanbase.gv$memstore_info;
desc oceanbase.gv$obrpc_incoming;
desc oceanbase.gv$obrpc_outgoing;
desc oceanbase.gv$outline;
desc oceanbase.gv$partition;
desc oceanbase.gv$plan_cache_plan_explain;
desc oceanbase.gv$plan_cache_plan_stat;
desc oceanbase.gv$plan_cache_stat;
desc oceanbase.gv$server_memstore;
desc oceanbase.gv$session_event;
desc oceanbase.gv$session_longops;
desc oceanbase.gv$session_wait;
desc oceanbase.gv$session_wait_history;
desc oceanbase.gv$sql;
desc oceanbase.gv$sql_audit;
desc oceanbase.gv$sql_monitor;
desc oceanbase.gv$sql_plan_monitor;
desc oceanbase.gv$sql_plan_statistics;
desc oceanbase.gv$sysstat;
desc oceanbase.gv$system_event;
desc oceanbase.gv$table;
desc oceanbase.gv$tenant;
desc oceanbase.gv$tenant_memstore_allocator_info;
desc oceanbase.gv$tenant_sequence_object;
desc oceanbase.gv$unit;
desc oceanbase.gv$unit_load_balance_event_history;
desc oceanbase.v$event_name;
desc oceanbase.v$latch;
desc oceanbase.v$lock_wait_stat;
desc oceanbase.v$memory;
desc oceanbase.v$memstore;
desc oceanbase.v$memstore_info;
desc oceanbase.v$obrpc_incoming;
desc oceanbase.v$obrpc_outgoing;
desc oceanbase.v$partition;
desc oceanbase.v$plan_cache_plan_explain;
desc oceanbase.v$plan_cache_plan_stat;
desc oceanbase.v$plan_cache_stat;
desc oceanbase.v$session_event;
desc oceanbase.v$session_longops;
desc oceanbase.v$session_wait;
desc oceanbase.v$session_wait_history;
desc oceanbase.v$sql;
desc oceanbase.v$sql_audit;
desc oceanbase.v$sql_monitor;
desc oceanbase.v$sql_plan_monitor;
desc oceanbase.v$sql_plan_statistics;
desc oceanbase.v$statname;
desc oceanbase.v$sysstat;
desc oceanbase.v$system_event;
desc oceanbase.v$tenant_memstore_allocator_info;
desc oceanbase.v$unit;
desc oceanbase.gv$tenant_px_worker_stat;
desc oceanbase.v$tenant_px_worker_stat;
desc oceanbase.__all_acquired_snapshot;
desc oceanbase.__all_build_index_param;
desc oceanbase.__all_charset;
desc oceanbase.__all_clog_history_info;
desc oceanbase.__all_clog_history_info_v2;
desc oceanbase.__all_collation;
desc oceanbase.__all_column_history;
desc oceanbase.__all_column_stat;
desc oceanbase.__all_column_statistic;
desc oceanbase.__all_constraint;
desc oceanbase.__all_constraint_history;
desc oceanbase.__all_database;
desc oceanbase.__all_database_history;
desc oceanbase.__all_database_privilege;
desc oceanbase.__all_database_privilege_history;
desc oceanbase.__all_ddl_id;
desc oceanbase.__all_def_sub_part;
desc oceanbase.__all_def_sub_part_history;
desc oceanbase.__all_dummy;
desc oceanbase.__all_election_event_history;
desc oceanbase.__all_foreign_key;
desc oceanbase.__all_foreign_key_column;
desc oceanbase.__all_foreign_key_column_history;
desc oceanbase.__all_foreign_key_history;
desc oceanbase.__all_frozen_map;
desc oceanbase.__all_func;
desc oceanbase.__all_func_history;
desc oceanbase.__all_global_index_data_src;
desc oceanbase.__all_histogram_stat;
desc oceanbase.__all_immediate_effect_index_sstable;
desc oceanbase.__all_index_build_stat;
desc oceanbase.__all_index_checksum;
desc oceanbase.__all_index_schedule_task;
desc oceanbase.__all_index_wait_transaction_status;
desc oceanbase.__all_local_index_status;
desc oceanbase.__all_meta_table;
desc oceanbase.__all_ori_schema_version;
desc oceanbase.__all_outline;
desc oceanbase.__all_outline_history;
desc oceanbase.__all_package;
desc oceanbase.__all_package_history;
desc oceanbase.__all_part;
desc oceanbase.__all_part_history;
desc oceanbase.__all_part_info;
desc oceanbase.__all_part_info_history;
desc oceanbase.__all_privilege;
desc oceanbase.__all_recyclebin;
desc oceanbase.__all_resource_pool;
desc oceanbase.__all_restore_job;
desc oceanbase.__all_restore_job_history;
desc oceanbase.__all_restore_task;
desc oceanbase.__all_rootservice_event_history;
desc oceanbase.__all_rootservice_job;
desc oceanbase.__all_routine;
desc oceanbase.__all_routine_history;
desc oceanbase.__all_routine_param;
desc oceanbase.__all_routine_param_history;
desc oceanbase.__all_sequence;
desc oceanbase.__all_sequence_object;
desc oceanbase.__all_sequence_object_history;
desc oceanbase.__all_sequence_v2;
desc oceanbase.__all_sequence_value;
desc oceanbase.__all_server;
desc oceanbase.__all_server_event_history;
desc oceanbase.__all_sql_execute_task;
desc oceanbase.__all_sstable_checksum;
desc oceanbase.__all_sstable_column_checksum;
desc oceanbase.__all_sub_part;
desc oceanbase.__all_sub_part_history;
desc oceanbase.__all_synonym;
desc oceanbase.__all_synonym_history;
desc oceanbase.__all_sys_parameter;
desc oceanbase.__all_sys_stat;
desc oceanbase.__all_sys_variable;
desc oceanbase.__all_sys_variable_history;
desc oceanbase.__all_tablegroup;
desc oceanbase.__all_tablegroup_history;
desc oceanbase.__all_table_history;
desc oceanbase.__all_table_privilege;
desc oceanbase.__all_table_privilege_history;
desc oceanbase.__all_table_stat;
desc oceanbase.__all_temp_table;
desc oceanbase.__all_tenant;
desc oceanbase.__all_tenant_gc_partition_info;
desc oceanbase.__all_tenant_history;
desc oceanbase.__all_tenant_meta_table;
desc oceanbase.__all_tenant_resource_usage;
desc oceanbase.__all_time_zone;
desc oceanbase.__all_time_zone_name;
desc oceanbase.__all_time_zone_transition;
desc oceanbase.__all_time_zone_transition_type;
desc oceanbase.__all_unit;
desc oceanbase.__all_unit_config;
desc oceanbase.__all_unit_load_history;
desc oceanbase.__all_user;
desc oceanbase.__all_user_history;
desc oceanbase.__all_virtual_bad_block_table;
desc oceanbase.__all_virtual_clog_stat;
desc oceanbase.__all_virtual_concurrency_object_pool;
desc oceanbase.__all_virtual_core_all_table;
desc oceanbase.__all_virtual_core_column_table;
desc oceanbase.__all_virtual_core_meta_table;
desc oceanbase.__all_virtual_core_root_table;
desc oceanbase.__all_virtual_data_type;
desc oceanbase.__all_virtual_data_type_class;
desc oceanbase.__all_virtual_disk_stat;
desc oceanbase.__all_virtual_election_group_info;
desc oceanbase.__all_virtual_election_info;
desc oceanbase.__all_virtual_election_mem_stat;
desc oceanbase.__all_virtual_election_priority;
desc oceanbase.__all_virtual_engine;
desc oceanbase.__all_virtual_freeze_info;
desc oceanbase.__all_virtual_io_stat;
desc oceanbase.__all_virtual_kvcache_info;
desc oceanbase.__all_virtual_latch;
desc oceanbase.__all_virtual_leader_stat;
desc oceanbase.__all_virtual_lock_wait_stat;
desc oceanbase.__all_virtual_long_ops_status;
desc oceanbase.__all_virtual_macro_block_marker_status;
desc oceanbase.__all_virtual_memory_info;
desc oceanbase.__all_virtual_memstore_info;
desc oceanbase.__all_virtual_mem_leak_checker_info;
desc oceanbase.__all_virtual_meta_table;
desc oceanbase.__all_virtual_obrpc_stat;
desc oceanbase.__all_virtual_partition_amplification_stat;
desc oceanbase.__all_virtual_partition_info;
desc oceanbase.__all_virtual_partition_item;
desc oceanbase.__all_virtual_partition_migration_status;
desc oceanbase.__all_virtual_partition_replay_status;
desc oceanbase.__all_virtual_partition_split_info;
desc oceanbase.__all_virtual_partition_sstable_image_info;
desc oceanbase.__all_virtual_partition_sstable_macro_info;
desc oceanbase.__all_virtual_partition_sstable_merge_info;
desc oceanbase.__all_virtual_partition_store_info;
desc oceanbase.__all_virtual_partition_table;
desc oceanbase.__all_virtual_partition_table_store_stat;
desc oceanbase.__all_virtual_plan_cache_plan_explain;
desc oceanbase.__all_virtual_plan_cache_stat;
desc oceanbase.__all_virtual_plan_stat;
desc oceanbase.__all_virtual_processlist;
desc oceanbase.__all_virtual_proxy_server_stat;
desc oceanbase.__all_virtual_proxy_sys_variable;
desc oceanbase.__all_virtual_px_worker_stat;
desc oceanbase.__all_virtual_rebalance_map_item_stat;
desc oceanbase.__all_virtual_rebalance_map_stat;
desc oceanbase.__all_virtual_rebalance_replica_stat;
desc oceanbase.__all_virtual_rebalance_task_stat;
desc oceanbase.__all_virtual_rebalance_tenant_stat;
desc oceanbase.__all_virtual_rebalance_unit_distribution_stat;
desc oceanbase.__all_virtual_rebalance_unit_migrate_stat;
desc oceanbase.__all_virtual_rebalance_unit_stat;
desc oceanbase.__all_virtual_replica_task;
desc oceanbase.__all_virtual_rootservice_stat;
desc oceanbase.__all_virtual_sequence_v2;
desc oceanbase.__all_virtual_server_blacklist;
desc oceanbase.__all_virtual_server_clog_stat;
desc oceanbase.__all_virtual_server_memory_info;
desc oceanbase.__all_virtual_server_object_pool;
desc oceanbase.__all_virtual_server_stat;
desc oceanbase.__all_virtual_session_event;
desc oceanbase.__all_virtual_session_wait;
desc oceanbase.__all_virtual_session_wait_history;
desc oceanbase.__all_virtual_sesstat;
desc oceanbase.__all_virtual_sql_audit;
desc oceanbase.__all_virtual_sql_monitor;
desc oceanbase.__all_virtual_sql_plan_monitor;
desc oceanbase.__all_virtual_sql_plan_statistics;
desc oceanbase.__all_virtual_storage_stat;
desc oceanbase.__all_virtual_sysstat;
desc oceanbase.__all_virtual_system_event;
desc oceanbase.__all_virtual_sys_parameter_stat;
desc oceanbase.__all_virtual_sys_task_status;
desc oceanbase.__all_virtual_table_mgr;
desc oceanbase.__all_virtual_tenant_disk_stat;
desc oceanbase.__all_virtual_tenant_memstore_allocator_info;
desc oceanbase.__all_virtual_tenant_memstore_info;
desc oceanbase.__all_virtual_tenant_stat;
desc oceanbase.__all_virtual_trace_log;
desc oceanbase.__all_virtual_trans_audit;
desc oceanbase.__all_virtual_trans_lock_stat;
desc oceanbase.__all_virtual_trans_mem_stat;
desc oceanbase.__all_virtual_trans_mgr_stat;
desc oceanbase.__all_virtual_trans_result_info_stat;
desc oceanbase.__all_virtual_trans_sql_audit;
desc oceanbase.__all_virtual_trans_stat;
desc oceanbase.__all_virtual_upgrade_inspection;
desc oceanbase.__all_virtual_zone_stat;
desc oceanbase.__all_zone;
desc oceanbase.__tenant_virtual_charset;
desc oceanbase.__tenant_virtual_collation;
desc oceanbase.__tenant_virtual_concurrent_limit_sql;
desc oceanbase.__tenant_virtual_database_status;
desc oceanbase.__tenant_virtual_event_name;
desc oceanbase.__tenant_virtual_global_variable;
desc oceanbase.__tenant_virtual_interm_result;
desc oceanbase.__tenant_virtual_outline;
desc oceanbase.__tenant_virtual_partition_stat;
desc oceanbase.__tenant_virtual_privilege_grant;
desc oceanbase.__tenant_virtual_session_variable;
desc oceanbase.__tenant_virtual_statname;
desc oceanbase.__tenant_virtual_table_index;
desc oceanbase.__tenant_virtual_tenant_status;
desc oceanbase.__tenant_virtual_warning;
--disable_result_log
select * from information_schema.CHARACTER_SETS limit 1;
select * from information_schema.COLLATIONS limit 1;
select * from information_schema.COLLATION_CHARACTER_SET_APPLICABILITY limit 1;
select * from information_schema.COLUMNS limit 1;
select * from information_schema.DBA_OUTLINES limit 1;
select * from oceanbase.DBA_OB_OUTLINES limit 1;
select * from information_schema.ENGINES limit 1;
select * from information_schema.GLOBAL_STATUS limit 1;
select * from information_schema.GLOBAL_VARIABLES limit 1;
select * from information_schema.KEY_COLUMN_USAGE limit 1;
select/*+no_rewrite*/ * from information_schema.KEY_COLUMN_USAGE limit 1;
select * from information_schema.PARAMETERS limit 1;
select * from information_schema.PARTITIONS limit 1;
select * from information_schema.PROCESSLIST limit 1;
@ -374,84 +78,65 @@ select * from information_schema.TABLES limit 1;
select * from information_schema.TABLE_CONSTRAINTS limit 1;
select * from information_schema.TABLE_PRIVILEGES limit 1;
select * from information_schema.USER_PRIVILEGES limit 1;
select * from information_schema.USER_RECYCLEBIN limit 1;
select * from oceanbase.DBA_RECYCLEBIN limit 1;
select * from information_schema.VIEWS limit 1;
select * from information_schema.TRIGGERS limit 1;
select * from mysql.db limit 1;
select * from mysql.help_category limit 1;
select * from mysql.help_keyword limit 1;
select * from mysql.help_relation limit 1;
select * from mysql.help_topic limit 1;
select * from mysql.proc limit 1;
select * from mysql.time_zone limit 1;
select * from mysql.time_zone_name limit 1;
select * from mysql.time_zone_transition limit 1;
select * from mysql.time_zone_transition_type limit 1;
select * from mysql.user limit 1;
select * from oceanbase.gv$concurrent_limit_sql limit 1;
select * from oceanbase.gv$database limit 1;
select * from oceanbase.DBA_OB_CONCURRENT_LIMIT_SQL limit 1;
select * from oceanbase.gv$latch limit 1;
select * from oceanbase.gv$lock_wait_stat limit 1;
select * from oceanbase.gv$memory limit 1;
select * from oceanbase.gv$memstore limit 1;
select * from oceanbase.gv$memstore_info limit 1;
select * from oceanbase.gv$obrpc_incoming limit 1;
select * from oceanbase.gv$obrpc_outgoing limit 1;
select * from oceanbase.gv$outline limit 1;
select * from oceanbase.gv$partition limit 1;
select * from oceanbase.gv$plan_cache_plan_explain limit 1;
select * from oceanbase.gv$plan_cache_plan_stat limit 1;
select * from oceanbase.gv$plan_cache_stat limit 1;
select * from oceanbase.gv$server_memstore limit 1;
select * from oceanbase.GV$OB_MEMORY limit 1;
select * from oceanbase.gv$ob_memstore limit 1;
#select * from oceanbase.GV$OB_RPC_INCOMING limit 1;
#select * from oceanbase.GV$OB_RPC_OUTGOING limit 1;
select * from oceanbase.DBA_OB_OUTLINES limit 1;
select * from oceanbase.GV$OB_PLAN_CACHE_PLAN_EXPLAIN limit 1;
select * from oceanbase.GV$OB_PLAN_CACHE_PLAN_STAT limit 1;
select * from oceanbase.GV$OB_PLAN_CACHE_STAT limit 1;
select * from oceanbase.gv$session_event limit 1;
select * from oceanbase.gv$session_longops limit 1;
select * from oceanbase.gv$session_wait limit 1;
select * from oceanbase.gv$session_wait_history limit 1;
select * from oceanbase.gv$sql limit 1;
select * from oceanbase.gv$sql_audit limit 1;
select * from oceanbase.gv$sql_monitor limit 1;
select * from oceanbase.GV$OB_SQL_AUDIT limit 1;
#select * from oceanbase.gv$sql_monitor limit 1;
select * from oceanbase.gv$sql_plan_monitor limit 1;
select * from oceanbase.gv$sql_plan_statistics limit 1;
#select * from oceanbase.gv$sql_plan_statistics limit 1;
select * from oceanbase.gv$sysstat limit 1;
select * from oceanbase.gv$system_event limit 1;
select * from oceanbase.gv$table limit 1;
select * from oceanbase.gv$tenant limit 1;
select * from oceanbase.gv$tenant_memstore_allocator_info limit 1;
select * from oceanbase.gv$tenant_sequence_object limit 1;
select * from oceanbase.gv$unit limit 1;
select * from oceanbase.gv$unit_load_balance_event_history limit 1;
select * from oceanbase.gv$tenant_px_worker_stat limit 1;
select * from oceanbase.v$tenant_px_worker_stat limit 1;
select * from oceanbase.DBA_OB_SEQUENCE_OBJECTS limit 1;
select * from oceanbase.GV$OB_PX_WORKER_STAT limit 1;
select * from oceanbase.V$OB_PX_WORKER_STAT limit 1;
select * from oceanbase.v$event_name limit 1;
select * from oceanbase.v$latch limit 1;
select * from oceanbase.v$lock_wait_stat limit 1;
select * from oceanbase.v$memory limit 1;
select * from oceanbase.v$memstore limit 1;
select * from oceanbase.v$memstore_info limit 1;
select * from oceanbase.v$obrpc_incoming limit 1;
select * from oceanbase.v$obrpc_outgoing limit 1;
select * from oceanbase.v$partition limit 1;
select * from oceanbase.v$plan_cache_plan_explain limit 1;
select * from oceanbase.v$plan_cache_plan_stat limit 1;
select * from oceanbase.v$plan_cache_stat limit 1;
select * from oceanbase.V$OB_MEMORY limit 1;
select * from oceanbase.v$ob_memstore limit 1;
#select * from oceanbase.v$obrpc_incoming limit 1;
#select * from oceanbase.V$OB_RPC_OUTGOING limit 1;
select * from oceanbase.V$OB_PLAN_CACHE_PLAN_EXPLAIN limit 1;
select * from oceanbase.V$OB_PLAN_CACHE_PLAN_STAT limit 1;
select * from oceanbase.V$OB_PLAN_CACHE_STAT limit 1;
select * from oceanbase.v$session_longops limit 1;
select * from oceanbase.v$session_wait limit 1;
select * from oceanbase.v$session_wait_history limit 1;
select * from oceanbase.v$sql limit 1;
select * from oceanbase.v$sql_audit limit 1;
select * from oceanbase.v$sql_monitor limit 1;
select * from oceanbase.V$OB_SQL_AUDIT limit 1;
#select * from oceanbase.v$sql_monitor limit 1;
select * from oceanbase.v$sql_plan_monitor limit 1;
select * from oceanbase.v$sql_plan_statistics limit 1;
#select * from oceanbase.v$sql_plan_statistics limit 1;
select * from oceanbase.v$statname limit 1;
select * from oceanbase.v$sysstat limit 1;
select * from oceanbase.v$system_event limit 1;
select * from oceanbase.v$tenant_memstore_allocator_info limit 1;
select * from oceanbase.v$unit limit 1;
select * from oceanbase.__all_acquired_snapshot limit 1;
select * from oceanbase.__all_build_index_param limit 1;
select * from oceanbase.__all_charset limit 1;
select * from oceanbase.__all_clog_history_info limit 1;
select * from oceanbase.__all_clog_history_info_v2 limit 1;
select * from oceanbase.__all_collation limit 1;
select * from oceanbase.__all_virtual_column_history limit 1;
select * from oceanbase.__all_virtual_column_stat limit 1;
select * from oceanbase.__all_virtual_column_statistic limit 1;
select * from oceanbase.__all_virtual_constraint limit 1;
select * from oceanbase.__all_virtual_constraint_history limit 1;
select * from oceanbase.__all_virtual_database limit 1;
@ -462,23 +147,12 @@ select * from oceanbase.__all_ddl_id limit 1;
select * from oceanbase.__all_virtual_def_sub_part limit 1;
select * from oceanbase.__all_virtual_def_sub_part_history limit 1;
select * from oceanbase.__all_dummy limit 1;
select * from oceanbase.__all_election_event_history limit 1;
select * from oceanbase.__all_virtual_foreign_key limit 1;
select * from oceanbase.__all_virtual_foreign_key_column limit 1;
select * from oceanbase.__all_virtual_foreign_key_column_history limit 1;
select * from oceanbase.__all_virtual_foreign_key_history limit 1;
select * from oceanbase.__all_frozen_map limit 1;
select * from oceanbase.__all_virtual_func limit 1;
select * from oceanbase.__all_virtual_func_history limit 1;
select * from oceanbase.__all_global_index_data_src limit 1;
select * from oceanbase.__all_virtual_histogram_stat limit 1;
select * from oceanbase.__all_immediate_effect_index_sstable limit 1;
select * from oceanbase.__all_index_build_stat limit 1;
select * from oceanbase.__all_index_checksum limit 1;
select * from oceanbase.__all_index_schedule_task limit 1;
select * from oceanbase.__all_index_wait_transaction_status limit 1;
select * from oceanbase.__all_local_index_status limit 1;
select * from oceanbase.__all_meta_table limit 1;
select * from oceanbase.__all_virtual_ori_schema_version limit 1;
select * from oceanbase.__all_virtual_outline limit 1;
select * from oceanbase.__all_virtual_outline_history limit 1;
@ -493,23 +167,19 @@ select * from oceanbase.__all_virtual_recyclebin limit 1;
select * from oceanbase.__all_resource_pool limit 1;
select * from oceanbase.__all_restore_job limit 1;
select * from oceanbase.__all_restore_job_history limit 1;
select * from oceanbase.__all_restore_task limit 1;
#select * from oceanbase.__all_restore_task limit 1;
select * from oceanbase.__all_rootservice_event_history limit 1;
select * from oceanbase.__all_rootservice_job limit 1;
select * from oceanbase.__all_virtual_routine limit 1;
select * from oceanbase.__all_virtual_routine_history limit 1;
select * from oceanbase.__all_virtual_routine_param limit 1;
select * from oceanbase.__all_virtual_routine_param_history limit 1;
select * from oceanbase.__all_sequence limit 1;
select * from oceanbase.__all_virtual_sequence_object limit 1;
select * from oceanbase.__all_virtual_sequence_object_history limit 1;
select * from oceanbase.__all_sequence_v2 limit 1;
select * from oceanbase.__all_auto_increment limit 1;
select * from oceanbase.__all_virtual_sequence_value limit 1;
select * from oceanbase.__all_server limit 1;
select * from oceanbase.__all_server_event_history limit 1;
select * from oceanbase.__all_sql_execute_task limit 1;
select * from oceanbase.__all_sstable_checksum limit 1;
select * from oceanbase.__all_sstable_column_checksum limit 1;
select * from oceanbase.__all_virtual_sub_part limit 1;
select * from oceanbase.__all_virtual_sub_part_history limit 1;
select * from oceanbase.__all_virtual_synonym limit 1;
@ -523,114 +193,64 @@ select * from oceanbase.__all_virtual_tablegroup_history limit 1;
select * from oceanbase.__all_virtual_table_history limit 1;
select * from oceanbase.__all_virtual_table_privilege limit 1;
select * from oceanbase.__all_virtual_table_privilege_history limit 1;
select * from oceanbase.__all_virtual_table_stat limit 1;
select * from oceanbase.__all_virtual_temp_table limit 1;
select * from oceanbase.__all_tenant limit 1;
select * from oceanbase.__all_tenant_gc_partition_info limit 1;
select * from oceanbase.__all_tenant_history limit 1;
select * from oceanbase.__all_tenant_meta_table limit 1;
select * from oceanbase.__all_tenant_resource_usage limit 1;
select * from oceanbase.__all_time_zone limit 1;
select * from oceanbase.__all_time_zone_name limit 1;
select * from oceanbase.__all_time_zone_transition limit 1;
select * from oceanbase.__all_time_zone_transition_type limit 1;
select * from oceanbase.__all_unit limit 1;
select * from oceanbase.__all_unit_config limit 1;
select * from oceanbase.__all_unit_load_history limit 1;
select * from oceanbase.__all_virtual_user limit 1;
select * from oceanbase.__all_virtual_user_history limit 1;
select * from oceanbase.__all_virtual_bad_block_table limit 1;
select * from oceanbase.__all_virtual_clog_stat limit 1;
select * from oceanbase.__all_virtual_concurrency_object_pool limit 1;
select * from oceanbase.__all_virtual_core_all_table limit 1;
select * from oceanbase.__all_virtual_core_column_table limit 1;
select * from oceanbase.__all_virtual_core_meta_table limit 1;
select * from oceanbase.__all_virtual_core_root_table limit 1;
select * from oceanbase.__all_virtual_data_type limit 1;
select * from oceanbase.__all_virtual_data_type_class limit 1;
select * from oceanbase.__all_virtual_disk_stat limit 1;
select * from oceanbase.__all_virtual_election_group_info limit 1;
select * from oceanbase.__all_virtual_election_info limit 1;
select * from oceanbase.__all_virtual_election_mem_stat limit 1;
select * from oceanbase.__all_virtual_election_priority limit 1;
select * from oceanbase.__all_virtual_engine limit 1;
select * from oceanbase.__all_virtual_freeze_info limit 1;
select * from oceanbase.__all_virtual_io_stat limit 1;
select * from oceanbase.__all_virtual_kvcache_info limit 1;
select * from oceanbase.__all_virtual_latch limit 1;
select * from oceanbase.__all_virtual_leader_stat limit 1;
select * from oceanbase.__all_virtual_lock_wait_stat limit 1;
select * from oceanbase.__all_virtual_long_ops_status limit 1;
select * from oceanbase.__all_virtual_macro_block_marker_status limit 1;
select * from oceanbase.__all_virtual_memory_info limit 1;
select * from oceanbase.__all_virtual_memstore_info limit 1;
select * from oceanbase.__all_virtual_mem_leak_checker_info limit 1;
select * from oceanbase.__all_virtual_meta_table limit 1;
select * from oceanbase.__all_virtual_obrpc_stat limit 1;
select * from oceanbase.__all_virtual_partition_amplification_stat limit 1;
select * from oceanbase.__all_virtual_partition_info limit 1;
select * from oceanbase.__all_virtual_partition_item limit 1;
select * from oceanbase.__all_virtual_partition_migration_status limit 1;
select * from oceanbase.__all_virtual_partition_replay_status limit 1;
select * from oceanbase.__all_virtual_partition_split_info limit 1;
select * from oceanbase.__all_virtual_partition_sstable_image_info limit 1;
select * from oceanbase.__all_virtual_partition_sstable_macro_info limit 1;
select * from oceanbase.__all_virtual_partition_sstable_merge_info limit 1;
select * from oceanbase.__all_virtual_partition_store_info limit 1;
select * from oceanbase.__all_virtual_partition_table limit 1;
select * from oceanbase.__all_virtual_partition_table_store_stat limit 1;
#select * from oceanbase.__all_virtual_obrpc_stat limit 1;
select * from oceanbase.__all_virtual_plan_cache_plan_explain limit 1;
select * from oceanbase.__all_virtual_plan_cache_stat limit 1;
select * from oceanbase.__all_virtual_plan_stat limit 1;
select * from oceanbase.__all_virtual_processlist limit 1;
select * from oceanbase.__all_virtual_proxy_server_stat limit 1;
select * from oceanbase.__all_virtual_proxy_sys_variable limit 1;
select * from oceanbase.__all_virtual_px_worker_stat limit 1;
select * from oceanbase.__all_virtual_rebalance_map_item_stat limit 1;
select * from oceanbase.__all_virtual_rebalance_map_stat limit 1;
select * from oceanbase.__all_virtual_rebalance_replica_stat limit 1;
select * from oceanbase.__all_virtual_rebalance_task_stat limit 1;
select * from oceanbase.__all_virtual_rebalance_tenant_stat limit 1;
select * from oceanbase.__all_virtual_rebalance_unit_distribution_stat limit 1;
select * from oceanbase.__all_virtual_rebalance_unit_migrate_stat limit 1;
select * from oceanbase.__all_virtual_rebalance_unit_stat limit 1;
select * from oceanbase.__all_virtual_replica_task limit 1;
select * from oceanbase.__all_virtual_rootservice_stat limit 1;
select * from oceanbase.__all_sequence_v2 limit 1;
select * from oceanbase.__all_virtual_server_blacklist limit 1;
select * from oceanbase.__all_virtual_server_clog_stat limit 1;
select * from oceanbase.__all_virtual_server_memory_info limit 1;
select * from oceanbase.__all_auto_increment limit 1;
#select * from oceanbase.__all_virtual_server_blacklist limit 1;
#select * from oceanbase.__all_virtual_server_clog_stat limit 1;
select * from oceanbase.__all_virtual_server_object_pool limit 1;
select * from oceanbase.__all_virtual_server_stat limit 1;
select * from oceanbase.__all_virtual_session_event limit 1;
select * from oceanbase.__all_virtual_session_wait limit 1;
select * from oceanbase.__all_virtual_session_wait_history limit 1;
select * from oceanbase.__all_virtual_sesstat limit 1;
select * from oceanbase.__all_virtual_sql_audit limit 1;
select * from oceanbase.__all_virtual_sql_monitor limit 1;
#select * from oceanbase.__all_virtual_sql_monitor limit 1;
select * from oceanbase.__all_virtual_sql_plan_monitor limit 1;
select * from oceanbase.__all_virtual_sql_plan_statistics limit 1;
select * from oceanbase.__all_virtual_storage_stat limit 1;
#select * from oceanbase.__all_virtual_sql_plan_statistics limit 1;
#select * from oceanbase.__all_virtual_storage_stat limit 1;
select * from oceanbase.__all_virtual_sysstat limit 1;
select * from oceanbase.__all_virtual_system_event limit 1;
select * from oceanbase.__all_virtual_sys_parameter_stat limit 1;
select * from oceanbase.__all_virtual_sys_task_status limit 1;
select * from oceanbase.__all_virtual_table_mgr limit 1;
select * from oceanbase.__all_virtual_tenant_disk_stat limit 1;
select * from oceanbase.__all_virtual_tenant_memstore_allocator_info limit 1;
select * from oceanbase.__all_virtual_tenant_memstore_info limit 1;
select * from oceanbase.__all_virtual_tenant_stat limit 1;
#select * from oceanbase.__all_virtual_tenant_stat limit 1;
#bug: https://work.aone.alibaba-inc.com/issue/27146409
#select * from oceanbase.__all_virtual_trace_log limit 1;
select * from oceanbase.__all_virtual_trans_audit limit 1;
select * from oceanbase.__all_virtual_trans_lock_stat limit 1;
select * from oceanbase.__all_virtual_trans_mem_stat limit 1;
select * from oceanbase.__all_virtual_trans_mgr_stat limit 1;
select * from oceanbase.__all_virtual_trans_result_info_stat limit 1;
select * from oceanbase.__all_virtual_trans_sql_audit limit 1;
select * from oceanbase.__all_virtual_trans_stat limit 1;
select * from oceanbase.__all_virtual_upgrade_inspection limit 1;
select * from oceanbase.__all_virtual_zone_stat limit 1;
select * from oceanbase.__all_zone limit 1;
select * from oceanbase.__tenant_virtual_charset limit 1;
select * from oceanbase.__tenant_virtual_collation limit 1;
@ -638,15 +258,58 @@ select * from oceanbase.__tenant_virtual_concurrent_limit_sql limit 1;
select * from oceanbase.__tenant_virtual_database_status limit 1;
select * from oceanbase.__tenant_virtual_event_name limit 1;
select * from oceanbase.__tenant_virtual_global_variable limit 1;
select * from oceanbase.__tenant_virtual_interm_result limit 1;
select * from oceanbase.__tenant_virtual_outline limit 1;
select * from oceanbase.__tenant_virtual_partition_stat limit 1;
#select * from oceanbase.__tenant_virtual_partition_stat limit 1;
select * from oceanbase.__tenant_virtual_privilege_grant limit 1;
select * from oceanbase.__tenant_virtual_session_variable limit 1;
select * from oceanbase.__tenant_virtual_statname limit 1;
select * from oceanbase.__tenant_virtual_table_index limit 1;
select * from oceanbase.__tenant_virtual_tenant_status limit 1;
select * from oceanbase.__tenant_virtual_warning limit 1;
select * from oceanbase.__all_ls_recovery_stat limit 1;
select * from oceanbase.__all_ls_log_archive_progress limit 1;
select * from oceanbase.__all_log_archive_progress limit 1;
select * from oceanbase.__all_log_archive_history limit 1;
select * from oceanbase.__all_log_archive_piece_files limit 1;
select * from oceanbase.__all_virtual_tablet_info limit 1;
select * from oceanbase.__all_virtual_tablet_ddl_kv_info limit 1;
#select * from oceanbase.__all_virtual_cluster limit 1;
select * from oceanbase.__all_virtual_id_service limit 1;
select * from oceanbase.__all_virtual_log_stat limit 1;
select * from oceanbase.__all_virtual_apply_stat limit 1;
select * from oceanbase.__all_virtual_archive_stat limit 1;
select * from oceanbase.__all_virtual_replay_stat limit 1;
select * from oceanbase.__all_virtual_ls_info limit 1;
select * from oceanbase.__all_virtual_tx_data_table limit 1;
select * from oceanbase.__all_virtual_transaction_freeze_checkpoint limit 1;
select * from oceanbase.__all_virtual_transaction_checkpoint limit 1;
select * from oceanbase.__all_virtual_checkpoint limit 1;
select * from oceanbase.__all_virtual_tablet_compaction_history limit 1;
select * from oceanbase.__all_virtual_tablet_compaction_progress limit 1;
select * from oceanbase.__all_virtual_server_compaction_progress limit 1;
select * from oceanbase.__all_virtual_server_compaction_event_history limit 1;
select * from oceanbase.__all_freeze_info limit 1;
select * from oceanbase.__all_zone_merge_info limit 1;
select * from oceanbase.__all_merge_info limit 1;
select * from oceanbase.__all_ddl_task_status limit 1;
select * from oceanbase.__all_tablet_meta_table limit 1;
select * from oceanbase.__all_tablet_replica_checksum limit 1;
select * from oceanbase.__all_tablet_checksum limit 1;
select * from oceanbase.__all_weak_read_service limit 1;
#select * from oceanbase.__all_virtual_reserved_table_mgr limit 1;
select * from oceanbase.__all_virtual_obj_lock limit 1;
select * from oceanbase.__all_virtual_tablet_sstable_macro_info limit 1;
select * from oceanbase.V$OB_MEMSTORE_INFO limit 1;
select * from oceanbase.GV$OB_MEMSTORE_INFO limit 1;
select * from oceanbase.V$OB_SSTABLES limit 1;
select * from oceanbase.GV$OB_SSTABLES limit 1;
select * from oceanbase.DBA_OB_ZONE_MAJOR_COMPACTION limit 1;
select * from oceanbase.DBA_OB_MAJOR_COMPACTION limit 1;
select * from oceanbase.CDB_OB_ZONE_MAJOR_COMPACTION limit 1;
select * from oceanbase.CDB_OB_MAJOR_COMPACTION limit 1;
select * from oceanbase.DBA_OB_TABLET_REPLICAS limit 1;
--enable_result_log
## Test all performance built-in views
@ -658,7 +321,7 @@ select * from oceanbase.__tenant_virtual_warning limit 1;
#let $memory = 1073741824;
#let $min_memory = 1073741824;
#let $disk = 536870912;
#let $iops = 128;
#let $iops = 100000;
#let $session = 64;
#let $zone_name=query_get_value(select zone from oceanbase.__all_zone where zone != '' limit 1, zone, 1);
@ -699,14 +362,12 @@ select * from oceanbase.__tenant_virtual_warning limit 1;
#################################
## expect all '0'
#set ob_query_timeout = 100000000;
#select count(*) from oceanbase.gv$memory where tenant_id != effective_tenant_id();
#select count(*) from oceanbase.GV$OB_MEMORY where tenant_id != effective_tenant_id();
#select count(*) from oceanbase.gv$memstore where tenant_id != effective_tenant_id();
#select count(*) from oceanbase.gv$memstore_info where tenant_id != effective_tenant_id();
#select count(*) from oceanbase.gv$sql where CON_ID != effective_tenant_id();
#select count(*) from oceanbase.gv$plan_cache_stat where tenant_id != effective_tenant_id();
#select count(*) from oceanbase.gv$sysstat where con_id != effective_tenant_id();
#select count(*) from oceanbase.gv$system_event where con_id != effective_tenant_id();
#select count(*) from oceanbase.v$memory where tenant_id != effective_tenant_id();
#select count(*) from oceanbase.V$OB_MEMORY where tenant_id != effective_tenant_id();
#select count(*) from oceanbase.v$memstore where tenant_id != effective_tenant_id();
#select count(*) from oceanbase.v$memstore_info where tenant_id != effective_tenant_id();
#select count(*) from oceanbase.v$sysstat where con_id != effective_tenant_id();
@ -721,15 +382,13 @@ select * from oceanbase.__tenant_virtual_warning limit 1;
## expect all '1'
#connect (conn2,$OBMYSQL_MS0,root@sys,,*NO-ONE*,$OBMYSQL_PORT);
#set ob_query_timeout = 100000000;
#select count(*) > 0 from oceanbase.gv$memory where tenant_id != effective_tenant_id();
#select count(*) > 0 from oceanbase.gv$memory where tenant_id != effective_tenant_id();
#select count(*) > 0 from oceanbase.GV$OB_MEMORY where tenant_id != effective_tenant_id();
#select count(*) > 0 from oceanbase.GV$OB_MEMORY where tenant_id != effective_tenant_id();
#select count(*) > 0 from oceanbase.gv$memstore where tenant_id != effective_tenant_id();
#select count(*) > 0 from oceanbase.gv$memstore_info where tenant_id != effective_tenant_id();
#select count(*) > 0 from oceanbase.gv$sql where CON_ID != effective_tenant_id();
#select count(*) > 0 from oceanbase.gv$plan_cache_stat where tenant_id != effective_tenant_id();
#select count(*) > 0 from oceanbase.gv$sysstat where con_id != effective_tenant_id();
#select count(*) > 0 from oceanbase.gv$system_event where con_id != effective_tenant_id();
#select count(*) > 0 from oceanbase.v$memory where tenant_id != effective_tenant_id();
#select count(*) > 0 from oceanbase.V$OB_MEMORY where tenant_id != effective_tenant_id();
#################################
## check dictionary table

View File

@ -1,24 +0,0 @@
--disable_query_log
set @@session.explicit_defaults_for_timestamp=off;
--enable_query_log
#owner: xiaoyi.xy
#owner group : storage
#description : __tenant_virtual_event_name
--disable_abort_on_error
--disable_warnings
use oceanbase;
desc __tenant_virtual_event_name;
desc v$event_name;
--disable_result_log
let $idx1 = query_get_value(select count(*) from oceanbase.__tenant_virtual_event_name,count(*),1);
--enable_result_log
if($idx1)
{
--echo succeed
}
--enable_abort_on_error
--enable_warnings

View File

@ -1,22 +0,0 @@
--disable_query_log
set @@session.explicit_defaults_for_timestamp=off;
--enable_query_log
#owner : zhenjiang.xzj
#owner group : STORAGE
#description : 测试虚拟表__tenant_virtual_partition_stat
--disable_abort_on_error
--disable_warnings
#检查表结构
desc oceanbase.__tenant_virtual_partition_stat;
--disable_result_log
#login into the sys tenant
connect (conn_admin,$OBMYSQL_MS0,admin@sys,admin,*NO-ONE*,$OBMYSQL_PORT);
let $cnt = query_get_value(select count(*) from oceanbase.__tenant_virtual_partition_stat, count(*), 1);
if ($cnt != 0)
{
echo pass;
}