This topic lists OceanBase Database cluster-level and tenant-level parameters based on their functions.
Cluster-level parameters
Security-related
| Parameter | Description |
|---|---|
| mysql_port | The port number for the SQL service protocol. |
| rpc_port | The port number for remote access. |
| sql_protocol_min_tls_version | The minimum SSL/TLS version for SSL connections for SQL statements. |
| ssl_client_authentication | Specifies whether to enable the SSL connection feature. |
| ssl_external_kms_info | Records information on which OceanBase Database's SSL feature depends. The information is recorded in a JSON string, which contains at least the ssl_mode field. |
| enable_sql_audit | Specifies whether to enable the SQL audit feature. |
Backup and restore related
| Parameter | Description |
|---|---|
| backup_backup_dest | Specifies the destination for backup data. |
| backup_backup_dest_option | Controls the backup backup-related parameters. |
| backup_dest_option | Controls the backup-related parameters. |
| backup_concurrency | Specifies the number of concurrent writes to the file system during backup. |
| backup_dest | Specifies the path for baseline backups and log archiving. |
| backup_log_archive_option | Defines the archiving options for backup logs. |
| backup_net_limit | Specifies the total bandwidth for cluster backup. |
| backup_recovery_window | Specifies the time window for restoring backup data. |
| backup_region | Specifies the region where backup is executed. |
| backup_zone | Specifies the zone where backup is executed. |
| log_archive_batch_buffer_limit | Controls the maximum memory usage for log archiving on a single node. |
| log_archive_checkpoint_interval | Specifies the time interval for cold data log archiving checkpoints. |
| restore_concurrency | Specifies the maximum concurrency for restoring tenant data from backup. |
cgroup related
| Parameter | Description |
|---|---|
| enable_cgroup | Controls whether to enable the cgroup feature on the OBServer node. |
CPU-related parameters
| Parameter | Description |
|---|---|
| cpu_count | Specifies the total number of CPU cores in the system. If set to 0, the system automatically detects the number of CPU cores. |
| server_balance_cpu_mem_tolerance_percent | Specifies the tolerance for CPU and memory resource imbalance in the node load balancing strategy. |
| server_cpu_quota_max | Specifies the maximum CPU quota available to the system. |
| server_cpu_quota_min | Specifies the minimum CPU quota available to the system. The system automatically reserves the remaining CPU cores. |
| token_reserved_percentage | Specifies the percentage of idle tokens to be reserved for tenants in the control tenant CPU scheduling strategy. |
| workers_per_cpu_quota | Specifies the number of worker threads allocated to each CPU quota. |
| cpu_reserved | Specifies the number of CPU cores to be reserved for the system. The remaining CPU cores are exclusively used by OceanBase Database. |
| sys_cpu_limit_trigger | Specifies the CPU utilization threshold. When the CPU utilization exceeds this threshold, the execution of system background tasks is paused. |
| system_cpu_quota | Specifies the CPU quota available to the system tenant. |
| tenant_cpu_variation_per_server | Specifies the allowable deviation in CPU quota scheduling among multiple units of a tenant. |
Read and write/Query-related
| Parameter name | Description |
|---|---|
| weak_read_version_refresh_interval | The interval for refreshing the weak-consistency read version, which affects the latency of weak-consistency read data. |
| large_query_worker_percentage | The percentage of worker threads reserved for processing large queries. |
| large_query_threshold | The threshold for query execution time. |
| trace_log_slow_query_watermark | The execution time threshold for queries. If a query's execution time exceeds this threshold, it is considered a slow query, and its trace logs are printed to the system logs. |
Load balancing
| Configuration item | Description |
|---|---|
| balancer_log_interval | Specifies the interval at which the thread of a disaster recovery task prints statistics. |
| balancer_task_timeout | Specifies the timeout period for load balancing and other background tasks. |
| balancer_tolerance_percentage | Specifies the tolerance for disk imbalance among units in a load balancing strategy. If the disk imbalance is within the mean ± tolerance, no balancing action is triggered. |
| server_balance_critical_disk_waterlevel | Specifies the water level for disk space load balancing. |
| server_balance_disk_tolerance_percent | Specifies the tolerance for disk load balancing among nodes. |
| resource_hard_limit | Specifies the overcommit ratio of CPU resources. |
| enable_sys_unit_standalone | Specifies whether the units of the sys tenant are dedicated. |
| balancer_emergency_percentage | Specifies the unit load threshold. If the unit load exceeds this threshold, replicas can be migrated to the outside, even during major compactions. |
| balancer_timeout_check_interval | Specifies the interval at which the timeout period for load balancing and other background tasks is checked. |
| data_copy_concurrency | Specifies the maximum number of concurrent data migration and replication tasks allowed in the system. |
| tenant_groups | Specifies the tenant groups used in the load balancing strategy. |
| unit_balance_resource_weight | Specifies the resource weight used in the unit balancing strategy. Generally, this parameter does not need to be manually configured. |
| resource_soft_limit | Specifies whether to enable unit balancing. |
Replica-related parameters
| Parameter | Description |
|---|---|
| unit_gc_wait_time | Specifies the maximum wait time for a unit GC operation. If the operation exceeds the specified wait time, a GC is forcibly triggered. |
| enable_rereplication | Specifies whether to enable the automatic replica creation feature. |
| ls_meta_table_check_interval | Specifies the inspection interval for the background inspection thread of the DBA_OB_LS_LOCATIONS/CDB_OB_LS_LOCATIONS view. |
| sys_bkgd_migration_change_member_list_timeout | Specifies the timeout period for changing the Paxos member group during replica migration. |
| sys_bkgd_migration_retry_num | Specifies the maximum number of retries for failed replica migration. |
| balance_blacklist_failure_threshold | Specifies the threshold for the number of consecutive failures of background tasks such as replica migration. If this threshold is exceeded, the task is added to the blacklist. |
| balance_blacklist_retry_interval | Specifies the retry interval after a background task such as replica migration is added to the blacklist. |
| election_cpu_quota | Specifies the CPU quota for background work related to replica election. |
| election_blacklist_interval | Specifies the time interval after a primary replica is removed during which it cannot be selected as the primary replica again. |
| enable_auto_leader_switch | Specifies whether to enable automatic leader switch. |
| enable_smooth_leader_switch | Specifies whether to enable smooth leader switch. |
| global_index_build_single_replica_timeout | Specifies the timeout period for building a global index on each replica. |
| get_leader_candidate_rpc_timeout | Specifies the timeout period for internal requests when the automatic leader switch strategy is used to obtain a leader candidate. |
| migrate_concurrency | Specifies the maximum number of concurrent internal data migrations. |
| rebuild_replica_data_lag_threshold | Specifies the threshold for the transaction log lag between the standby replica and the primary replica. If this threshold is exceeded, replica reconstruction is triggered. |
| server_data_copy_out_concurrency | Specifies the maximum number of concurrent data migrations from a single node. |
| server_data_copy_in_concurrency | Specifies the maximum number of concurrent data migrations to a single node. |
| replica_safe_remove_time | Specifies the safe retention period for deleted replicas. |
Cache-related parameters
| Parameter Name | Description |
|---|---|
| bf_cache_miss_count_threshold | The number of times a Bloom filter cache is triggered. When the number of misses for a macroblock reaches this threshold, a Bloom filter cache is created. |
| bf_cache_priority | The priority of the Bloom filter cache. |
| cache_wash_threshold | The capacity threshold for triggering cache cleanup. |
| fuse_row_cache_priority | The priority of the fused row cache in the cache system. |
| user_row_cache_priority | The priority of the baseline data row cache in the cache system. |
| autoinc_cache_refresh_interval | The refresh interval for auto-increment column cache. |
| plan_cache_evict_interval | The eviction interval for the execution plan cache. |
| index_block_cache_priority | The priority of the metadata index microblock cache. |
| opt_tab_stat_cache_priority | The priority of the statistics cache. |
| tablet_ls_cache_priority | The priority of the tablet mapping cache. |
| user_block_cache_priority | The priority of the data block cache in the cache system. |
| index_info_block_cache_priority | The priority of the block index in the cache system. |
| index_cache_priority | The priority of the index in the cache system. |
| user_tab_col_stat_cache_priority | The priority of the statistics cache in the cache system. |
| plan_cache_high_watermark | The memory usage threshold for the execution plan cache. If this threshold is exceeded, automatic eviction will be triggered. |
| plan_cache_low_watermark | The memory usage threshold for the execution plan cache. If this threshold is exceeded, eviction will be stopped. |
Partition-related parameters
| Parameter | Description |
|---|---|
| tablet_meta_table_check_interval | Specifies the interval at which the background inspection thread for the DBA_OB_TABLET_REPLICAS and CDB_OB_TABLET_REPLICAS views checks. |
| tablet_meta_table_scan_batch_count | Specifies the number of tablets cached in memory during the iteration of the tablet meta table. |
| tablet_size | Specifies the size of each shard during parallel processing (such as major compactions and queries) within a partition. |
| auto_broadcast_location_cache_rate_limit | Specifies the maximum number of partitions per OBServer that can broadcast changes in location information per second. |
| auto_refresh_location_cache_rate_limit | Specifies the maximum number of partitions per OBServer that can trigger automatic refresh per second. |
| enable_pg | Specifies whether to enable partition groups. |
| gc_wait_archive | Specifies whether to wait for all log archiving to complete before performing partition GC. |
| partition_table_check_interval | Specifies the interval at which OBServer nodes remove non-existent replicas from partition tables. |
Background threads
| Configuration item | Description |
|---|---|
| sql_net_thread_count | The number of MySQL cluster I/O threads, which is the number of global_sql_nio_server threads. The default value of 0 indicates that the value of this parameter is the same as that of the net_thread_count parameter. |
| auto_leader_switch_interval | The interval between background threads for automatic leader switching. |
| switchover_process_thread_count | The number of threads in the thread pool for primary/standby database switching. |
I/O-related parameters
| Parameter | Description |
|---|---|
| sync_io_thread_count | Specifies the number of threads for synchronous I/O requests. |
| syslog_io_bandwidth_limit | Specifies the maximum disk I/O bandwidth that system logs can occupy. System logs exceeding this bandwidth will be discarded. |
| disk_io_thread_count | Specifies the number of disk I/O threads. The value must be an even number. |
| net_thread_count | Specifies the number of network I/O threads. |
| data_storage_error_tolerance_time | Specifies the tolerance time for the data disk status to be set to ERROR. |
| sys_bkgd_io_high_percentage | Specifies the maximum percentage of system background I/O. |
| sys_bkgd_io_low_percentage | Specifies the minimum percentage of system background I/O. |
| user_iort_up_percentage | Specifies the threshold for user disk I/O latency. When user disk I/O latency exceeds this threshold, system background I/O tasks will be throttled. |
| ob_esi_rpc_port | Specifies the communication port between the obesi process and the observer process. |
| enable_ob_esi_process | Specifies whether to enable the obesi (external storage interface) process. |
| ob_esi_session_timeout | Specifies the timeout period for the obesi process to hold active session resources. |
| ob_esi_io_concurrency | Specifies the number of concurrent I/O operations for the obesi process. |
| ob_esi_syslog_level | Specifies the current log recording level for the obesi process. |
| ob_esi_max_syslog_file_count | Specifies the maximum number of log files that the obesi process can retain before recycling them. |
| multiblock_read_gap_size | Specifies the maximum capacity of a block cache for a single I/O aggregation read operation. |
| multiblock_read_size | Specifies the I/O aggregation size for reading data. |
Cluster-related parameters
| Parameter | Description |
|---|---|
| all_server_list | Displays the IP addresses of all servers in the cluster. |
| cluster | Specifies the name of the OceanBase cluster. |
| cluster_id | Specifies the ID of the OceanBase cluster. |
| rpc_timeout | Specifies the timeout period for internal requests in the cluster. |
| all_cluster_list | Displays the list of servers that access the same config_url. |
| enable_election_group | Specifies whether to enable the election group strategy. |
| local_ip | Specifies the IP address of the machine where ObServer is installed. |
| observer_id | Specifies the unique identifier assigned to the OBServer node by the cluster's RS. |
| min_observer_version | Displays the minimum OBServer node application version number in the cluster. |
Bandwidth-related parameters
| Parameter | Description |
|---|---|
| enable_ob_ratelimit | Enables rate limiting between regions in RPC connections. |
| ob_ratelimit_stat_period | Specifies the time interval for the OBServer node to calculate and update the maximum bandwidth. |
Location Cache related parameters
| Parameter | Description |
|---|---|
| virtual_table_location_cache_expire_time | Specifies the expiration time of the cache for virtual table locations. |
| location_cache_refresh_rpc_timeout | Specifies the timeout period for refreshing the location_cache through an RPC call. |
| location_cache_refresh_sql_timeout | Specifies the timeout period for refreshing the location_cache through an SQL statement. |
| location_cache_refresh_min_interval | Specifies the minimum interval between location cache refresh requests to prevent excessive refresh requests from overwhelming the system. |
| location_cache_cpu_quota | Specifies the CPU quota for the location cache module. |
| location_fetch_concurrency | Specifies the maximum number of concurrent refreshes for the location cache on a single OBServer node. |
| location_refresh_thread_count | Specifies the number of threads for OBServer nodes to obtain partition locations from the Root Service. |
| enable_auto_refresh_location_cache | Specifies whether to enable the automatic refresh of location cache information. |
Directories related to the directory path
| Configuration item name | Description |
|---|---|
| config_additional_dir | Specifies multiple directories for storing configuration files on the local disk to implement redundant storage of multiple configuration files. |
| data_dir | Specifies the directory for storing data such as SSTables. |
Memory-related parameters
| Parameter Name | Description |
|---|---|
| datafile_disk_percentage | The percentage of the total space on the disk where data_dir is located (OceanBase Database will initialize this disk for storing data). |
| data_disk_usage_limit_percentage | The maximum percentage of data files that can be written, beyond which data migration is prohibited. |
| enable_sql_operator_dump | Specifies whether to allow intermediate results of SQL processing to be written to disk to free up memory. |
| global_write_halt_residual_memory | The global remaining memory threshold that triggers the halt of write operations for ordinary tenants (sys tenants are unaffected). |
| leak_mod_to_check | A parameter for checking memory leaks, which is an internal debugging feature. |
| memory_chunk_cache_size | The size of memory blocks cached by the memory allocator. |
| memory_limit | The total amount of available memory. |
| memory_limit_percentage | The percentage of the total available memory relative to the total memory size. |
| memory_reserved | The amount of memory reserved for KVCache. |
| memstore_limit_percentage | The percentage of memory occupied by MemStore relative to the total available memory for each tenant. |
| system_memory | The amount of memory reserved for the tenant with ID 500. |
| use_large_pages | Manages memory large pages used by the database. |
| datafile_maxsize | The maximum size to which the disk file can automatically expand. |
| datafile_next | The step size for the automatic expansion of the disk file. |
| storage_meta_cache_priority | The priority of the Meta Cache stored in the KVCache. |
PX-related parameters
| Parameter Name | Description |
|---|---|
| px_workers_per_cpu_quota | The ratio of parallel execution worker threads. |
| px_task_size | The amount of data processed by each task of the SQL parallel query engine. |
| max_px_worker_count | The maximum number of threads used by the SQL parallel query engine. |
Other
| Parameter name | Description |
|---|---|
| builtin_db_data_verify_cycle | Specifies the cycle for bad block self-check in days. A value of 0 indicates that no check is performed. |
| data_storage_warning_tolerance_time | Specifies the tolerance time for the data disk status to be set to WARNING. |
| dead_socket_detection_timeout | Specifies the interval for detecting failed sockets. |
| migration_disable_time | Specifies the duration in seconds for which data migration is paused when it fails due to reasons such as disk full. |
| schema_history_expire_time | Specifies the expiration time for metadata history. |
| datafile_size | Specifies the size of the data file. This parameter is generally not required. |
| devname | Specifies the name of the network interface card (NIC) device for the service process. |
| enable_perf_event | Specifies whether to collect performance events. |
| enable_record_trace_id | Specifies whether to record the trace ID set by the application. |
| enable_upgrade_mode | Specifies whether to enable the upgrade mode. In upgrade mode, some system background features are paused. |
| enable_ddl | Specifies whether to allow DDL operations. |
| high_priority_net_thread_count | Specifies the number of high-priority network threads. A value of 0 indicates that the feature is disabled. |
| obconfig_url | Specifies the URL of the OBConfig service. |
| rpc_port | Specifies the port number for remote access. |
| stack_size | Specifies the size of the program function call stack. |
| tenant_task_queue_size | Specifies the size of the request queue for each tenant. |
| zone | Specifies the name of the zone in which the node is located. This parameter is generally not required. |
| recyclebin_object_expire_time | Specifies the time after which schema objects in the recycle bin are automatically purged. |
| default_row_format | Specifies the default row format used when creating tables in MySQL mode. |
| sys_bkgd_net_percentage | Specifies the percentage of network bandwidth available to background system tasks. |
| schema_history_recycle_interval | Specifies the interval for the system to perform multi-version record recycling tasks on schema data. |
| enable_asan_for_memory_context | When ob_asan is used, specifies whether to allow ObAsanAllocator (which is the default memory context allocator, ObAllocator) to be used. |
| ofs_list | Stores the connection URLs of OceanBase File System (OFS) for each zone. This is mainly used in OFS deployment mode to enable RootService to access files across zones. |
RootService parameters
| Parameter | Description |
|---|---|
| rootservice_async_task_queue_size | Specifies the size of the asynchronous task queue in the RootService. |
| rootservice_async_task_thread_count | Specifies the size of the thread pool for asynchronous tasks in the RootService. |
| rootservice_list | Displays the list of machines where the RootService and its replicas are located. |
| rootservice_ready_check_interval | Specifies the interval for waiting and checking the cluster status after the RootService starts. |
| rootservice_memory_limit | Specifies the maximum memory capacity limit for the RootService. |
| lease_time | Specifies the length of the heartbeat lease period. |
| server_check_interval | Specifies the interval for checking the consistency of the server table. |
| server_permanent_offline_time | Specifies the time threshold for considering a node permanently offline, after which its data replicas need to be automatically replenished. |
| ob_event_history_recycle_interval | Controls the interval for recycling historical events. |
| enable_rootservice_standalone | Specifies whether to allocate OBServer nodes exclusively to the system tenant and RootService. |
| fast_recovery_concurrency | Controls the concurrency of fast recovery tasks scheduled by the RootService on OBServer nodes. |
| wait_leader_batch_count | Specifies the maximum number of partitions to be sent in each leader change command for the RootService. |
RPC authentication
| Parameter | Description |
|---|---|
| rpc_client_authentication_method | Specifies the security authentication method for RPC clients. |
| rpc_server_authentication_method | Specifies the security authentication method for RPC servers. |
SQL
| Parameter | Description |
|---|---|
| sql_login_thread_count | Specifies the number of threads for handling SQL login requests. |
| sql_audit_memory_limit | Specifies the maximum memory that can be occupied by SQL audit data. |
| enable_sys_table_ddl | Specifies whether to allow manual creation of system tables. |
| internal_sql_execute_timeout | Specifies the time interval for system internal DML requests. |
Transaction and transaction log related
| Parameter | Description |
|---|---|
| log_disk_size | Specifies the size of the redo log disk. |
| log_disk_percentage | Specifies the percentage of the total space of the disk on which the redo log is stored. |
| dtl_buffer_size | Specifies the size of the cache used by the SQL data transmission module. |
| ignore_replay_checksum_error | Specifies whether to ignore checksum errors that occur during transaction log replay. |
| trx_2pc_retry_interval | Specifies the time interval for automatic retries when two-phase commit fails. |
| standby_fetch_log_bandwidth_limit | Specifies the maximum bandwidth that can be occupied by all servers in the standby cluster for log synchronization from the primary tenant. |
| log_storage_warning_tolerance_time | Specifies the time from the failure of log disk I/O to the time when the disk is marked as bad, triggering a leader switch. |
| clog_disk_utilization_threshold | Controls the water level for reusing disk space for clogs or ilogs. |
| clog_expire_days | Specifies the expiration time for clog files. When the last modification time of a clog file is more than the expiration time from the current time, the file is deleted. |
| clog_cache_priority | Specifies the priority of transaction logs in the cache. |
| clog_disk_usage_limit_percentage | Specifies the maximum percentage of available disk space for transaction logs. |
| clog_sync_time_warn_threshold | Specifies the time threshold for transaction log synchronization. If the synchronization time exceeds this threshold, a WARN log is generated. |
| clog_transport_compress_func | Specifies the compression algorithm used for internal transaction log transmission. |
| enable_one_phase_commit | Specifies whether to enable the one-phase commit optimization feature. |
| enable_separate_sys_clog | Specifies whether to store system transaction logs separately from user transaction logs. |
| flush_log_at_trx_commit | Specifies the strategy for writing transaction logs when a transaction is committed. |
| ignore_replay_checksum_error | Specifies whether to ignore checksum errors that occur during transaction log replay. |
| index_clog_cache_priority | Specifies the priority of transaction log indexes in the cache system. |
| ilog_index_expire_time | Specifies the maximum time allowed for reading ilog files by OBServer nodes. |
| trx_force_kill_threshold | Specifies the maximum waiting time when transactions need to be killed due to freezing or leader switch. |
Lock-related
| Parameter | Description |
|---|---|
| trx_try_wait_lock_timeout | The maximum time that a statement waits for a row lock to be obtained. |
Debug-related
| Parameter | Description |
|---|---|
| debug_sync_timeout | The timeout period for the Debug Sync debugging feature. |
| enable_rich_error_msg | Specifies whether to add debugging information such as server address, time, and trace ID to client messages. |
TCP-related
| Parameter | Description |
|---|---|
| enable_tcp_keepalive | Specifies whether to enable the keep-alive mechanism for client connections. |
| tcp_keepidle | The time interval after which a Keepalive probe is sent to a client connection when no data is being sent, in seconds. |
| tcp_keepintvl | The time interval between two consecutive probes in the keep-alive mechanism for a client connection, in seconds. |
| tcp_keepcnt | The maximum number of retries before a non-active client connection is closed. |
System logs
| Parameter | Description |
|---|---|
| alert_log_level | Specifies the level of alert logs. |
| enable_record_trace_log | Specifies whether to record trace logs. |
| enable_async_syslog | Specifies whether to enable asynchronous writing of system logs. |
| enable_syslog_recycle | Specifies whether to enable the option to record old logs before the OBServer node starts. This parameter works with max_syslog_file_count to determine whether to consider old log files when recycling logs. |
| enable_syslog_wf | Specifies whether to print system logs of level WARN and above to a separate log file. |
| max_string_print_length | Specifies the maximum length of a single line of system logs to be printed. |
| max_syslog_file_count | Specifies the maximum number of log files that can be stored before recycling logs. |
| syslog_level | Specifies the level of system logs. |
| trace_log_sampling_interval | Specifies the time interval for regularly printing trace log information. |
| diag_syslog_per_error_limit | Specifies the maximum number of DIAG system logs allowed per error code per second. Logs will no longer be printed after exceeding this threshold. |
| enable_log_archive | Specifies whether to enable the log archiving feature. |
| system_trace_level | Specifies the log printing level for system trace logs. |
Compression algorithm parameters
| Parameter | Description |
|---|---|
| default_compress_func | The default compression algorithm for table data. You can also specify other compression algorithms when you create a table. |
| default_compress | The default compression strategy for creating tables in Oracle mode. |
| tableapi_transport_compress_func | The compression algorithm for query results in OBKV-Table. |
| default_transport_compress_func | The RPC compression algorithm for the entire cluster. |
Major compactions and minor compactions
| Configuration item | Description |
|---|---|
| enable_major_freeze | Specifies whether to enable automatic global freeze. |
| micro_block_merge_verify_level | Specifies the macroblock verification level during major compactions. |
| row_compaction_update_limit | Specifies the number of modifications that trigger in-memory row data compaction. |
| enable_global_freeze_trigger | Specifies whether to enable automatic global freeze. |
| enable_merge_by_turn | Specifies whether to enable the round-robin major compaction strategy. |
| enable_manual_merge | Specifies whether to enable manual major compactions. |
| global_major_freeze_residual_memory | Specifies the residual memory threshold that triggers a global major compaction. The global major compaction is triggered when the residual memory is less than this threshold. |
| minor_deferred_gc_time | Specifies the interval between major compactions and the delayed garbage collection of the SSTable. |
| zone_merge_concurrency | Specifies the maximum number of zones that can be concurrently major compacted during major compactions. If the value is 0, the system automatically determines the optimal concurrency based on the deployment configuration. |
| zone_merge_order | Specifies the order of zones for round-robin major compactions. If this parameter is not specified, the system automatically determines the order. |
| zone_merge_timeout | Specifies the timeout period for a single zone during major compactions. |
| minor_freeze_times | Specifies the number of freezes that trigger a major compaction. |
| minor_merge_concurrency | Specifies the number of concurrent threads during major compactions. |
| minor_warm_up_duration_time | Specifies the preheating time for generating new minor compaction files. |
| row_purge_thread_count | Specifies the maximum number of worker threads for in-memory row data compaction. |
Arbitration services
| Parameter name | Description |
|---|---|
| arbitration_degradation_policy | Specifies the strategy for automatic degradation. |
| ob_startup_mode | Specifies the startup mode of the OBServer node. This parameter can be modified only on the first startup. |
Resource isolation
| Parameter name | Description |
|---|---|
| clog_io_isolation_mode | Specifies whether to control I/O requests of the clog disk based on whether the clog disk and data disk are isolated. |
| enable_global_background_resource_isolation | Specifies whether to enable global background resource isolation. |
| global_background_cpu_quota | Specifies the CPU quota for background tasks when global background resource isolation is enabled. |
Tenant-level parameters
Security-related
| Configuration item name | Description |
|---|---|
| sts_credential | Specifies the credentials for accessing the STS service provided by OCP. |
| external_kms_info | Stores some key management information. |
| tde_method | Specifies the method for transparent tablespace encryption. |
| audit_sys_operations | Specifies whether to track the operation behaviors of system users. |
| audit_trail | Specifies whether to enable database auditing. |
Storage-related
| Configuration item name | Description |
|---|---|
| default_table_organization | Specifies the default table organization mode for creating tables. |
| default_table_merge_engine | Specifies the merge_engine for users to create tables in the default tenant.
NoteThis configuration item was introduced in OCP V4.3.5 BP3. |
CPU-related
| Configuration item name | Description |
|---|---|
| cpu_quota_concurrency | Specifies the maximum number of concurrent requests allowed for each CPU quota of the tenant. |
Read/write and query-related
| Configuration item name | Description |
|---|---|
| enable_monotonic_weak_read | Specifies whether to enable monotonic reads. |
| query_response_time_stats | Specifies whether to collect statistics for the information_schema.QUERY_RESPONSE_TIME view. |
| query_response_time_flush | Specifies whether to refresh the information_schema.QUERY_RESPONSE_TIME view and re-read query_response_time_range_base. |
| query_response_time_range_base | Specifies the interval for collecting time parameters for the information_schema.QUERY_RESPONSE_TIME view. |
Load balancing-related
| Configuration item name | Description |
|---|---|
| unit_gc_wait_time | Specifies the maximum wait time for Unit GC. GC is forcibly triggered if the maximum wait time is exceeded. |
| balancer_idle_time | Specifies the wake-up interval for backend task threads such as load balancing. |
| enable_rebalance | Specifies whether to enable automatic load balancing. |
| enable_transfer | Specifies whether to allow transfers within the tenant. This configuration item becomes invalid when enable_rebalance is disabled. |
| partition_balance_schedule_interval | Specifies the partition balancing schedule interval. |
Replica-related settings
| Configuration item | Description |
|---|---|
| replica_parallel_migration_mode | Specifies the mode of the log stream replica parallel migration feature. |
| choose_migration_source_policy | Specifies the priority strategy for selecting the source replica for migration. |
Backup and restore-related settings
| Configuration item | Description |
|---|---|
| recover_table_concurrency | Specifies the maximum number of tables that can be restored in parallel during cross-tenant table import in table-level restore. |
| recover_table_dop | Specifies the maximum number of tables that can be restored in parallel during cross-tenant table import in table-level restore. |
| log_restore_concurrency | Specifies the concurrency for restoring logs. |
| log_archive_concurrency | Specifies the concurrency for archiving logs. |
| backup_data_file_size | Specifies the maximum file size for a single data backup file. |
Partitioning-related parameters
| Parameter name | Description |
|---|---|
| enable_auto_split | Specifies whether to enable auto-partitioning for the tenant. The default value is false. |
| auto_split_tablet_size | Specifies the threshold for triggering auto-partitioning for the tenant. The default value is 128 MB. |
| global_index_auto_split_policy | Specifies whether to enable auto-partitioning for new global indexes. The default value is DISTRIBUTED. |
Background execution threads
| Parameter name | Description |
|---|---|
| ddl_thread_score | The number of threads used for DDL tasks. |
| compaction_low_thread_score | The number of worker threads for low-priority compactions. |
| compaction_high_thread_score | The number of worker threads for high-priority compactions. |
| compaction_mid_thread_score | The number of worker threads for medium-priority compactions. |
| ha_high_thread_score | The number of worker threads for high-priority high-availability threads. |
| ha_mid_thread_score | The number of worker threads for medium-priority high-availability threads. |
| ha_low_thread_score | The number of worker threads for low-priority high-availability threads. |
| ob_compaction_schedule_interval | The time interval for scheduling compactions. |
| compaction_dag_cnt_limit | The maximum number of DAGs allowed on the Compaction DAG queue. |
| compaction_schedule_tablet_batch_cnt | The maximum number of tablets to be scheduled in each batch for compaction. |
| tenant_sql_login_thread_count | The number of threads for MySQL tenant login, which is the number of mysql_queue threads. The default value of 0 indicates to use the value of unit_min_cpu. |
| tenant_sql_net_thread_count | The number of threads for MySQL tenant I/O, which is the number of sql_nio_server threads. The default value of 0 indicates to use the value of unit_min_cpu. |
Cache-related
| Parameter name | Description |
|---|---|
| default_storage_cache_policy | Configures the default caching policy. |
| enable_manual_storage_cache_policy | Enables user-specified manual hotspot caching policy. |
| suspend_storage_cache_task | Sets whether to suspend background caching tasks. |
| enable_adaptive_plan_cache | Specifies whether the tenant enables adaptive plan cache capabilities. |
| result_cache_max_size | Specifies the maximum amount of memory that the result cache module can use. |
| result_cache_max_result | Specifies the maximum proportion of result_cache_max_size that a single result cache object can use. |
| ob_result_cache_evict_percentage | Sets the memory eviction threshold for the result cache. |
| ob_deterministic_udf_cache_max_size | Specifies the maximum total memory that the cache pool for all deterministic UDFs can use during statement execution. |
I/O-related
| Configuration item | Description |
|---|---|
| io_category_config | Specifies the percentage of I/O requests for each category. |
Compatibility-related
Note
The following configuration items take effect only in MySQL mode.
| Configuration item | Description |
|---|---|
| enable_sql_extension | Specifies whether to enable the SQL extension feature for the tenant. |
| compatible | Controls the compatibility behavior for the tenant. This configuration item cannot be set. |
Routing-related
| Configuration item | Description |
|---|---|
| ob_proxy_readonly_transaction_routing_policy | Controls whether the routing of transactions by Proxy is affected by read-only statements. |
LOB-related
| Parameter | Description |
|---|---|
| lob_enable_block_cache_threshold | Specifies the threshold for the LOB query cache for OUTROW storage. |
Memory-related
| Parameter | Description |
|---|---|
| temporary_file_max_disk_size | Specifies the maximum disk space that a temporary file can occupy on a single node for a tenant. |
| ob_vector_memory_limit_percentage | Specifies the threshold for the memory resources used by the vector index module (in percentage). |
| range_optimizer_max_mem_size | Limits the memory used by the Query Range module. |
| rpc_memory_limit_percentage | Specifies the maximum memory for RPC, as a percentage of the tenant's total memory. |
| query_memory_limit_percentage | Specifies the percentage of tenant memory that a single SQL statement can use. |
Disk space-related
| Parameter | Description |
|---|---|
| temporary_file_max_disk_size | Specifies the maximum disk space that a temporary file can occupy on a single node for a tenant. |
OBKV-related parameters
| Parameter | Description |
|---|---|
| enable_kv_ttl | Specifies whether to enable the TTL background task. This parameter applies only to periodic TTL tasks. This parameter does not apply to user-controlled commands. Notice: The TTL feature is only available in OceanBase KV scenarios. If you enable this feature in an SQL scenario, unexpected data deletion may occur. |
| kv_ttl_duty_duration | Specifies the time period during which the daily scheduled TTL task is triggered. |
| kv_group_commit_batch_size | Specifies the number of batch operations performed in a group commit for OBKV. |
| kv_group_commit_rw_mode | Specifies the read/write mode for group commit control. |
| kv_hbase_client_scanner_timeout_period | Specifies the timeout period for OBKV-HBase streaming queries. |
| kv_ttl_history_recycle_interval | Specifies the period during which the TTL task history is retained. |
| ttl_thread_score | Specifies the number of worker threads used by the TTL task. |
PL-related
| Configuration item name | Description |
|---|---|
| plsql_code_type | The compilation mode of PL/SQL code. |
| plsql_debug | Specifies whether to compile code for debugging. |
| plsql_optimize_level | The compilation optimization level. |
| plsql_v2_compatibility | Specifies whether to enable the compilation of stored procedures during the DDL phase. |
| package_state_sync_max_size | Controls the maximum length that a single package state (package state management) can serialize. |
Direct load-related
| Configuration item name | Description |
|---|---|
| default_load_mode | Specifies the data import method in data export scenarios. |
| direct_load_allow_fallback | Specifies whether to revert to standard import mode if direct load fails in a specified direct load scenario. |
Others
| Parameter | Description |
|---|---|
| enable_early_lock_release | Specifies whether to enable the early lock release feature. |
| workarea_size_policy | Specifies whether to manually or automatically adjust the size of the SQL work area. |
| open_cursors | Specifies the maximum number of cursors that can be opened simultaneously for a single session. |
| ob_ssl_invited_common_names | Records the list of application identities of the current tenant. The identities are obtained from the cn field (common name) of the subject field in the client certificate during mutual SSL authentication. |
| ob_enable_batched_multi_statement | Specifies whether to enable the grouped execution optimization for the batch processing feature. |
| job_queue_processes | Specifies the maximum number of tasks that can run simultaneously for each tenant, to prevent tasks from consuming excessive resources of the tenant. |
| default_auto_increment_mode | Specifies the default auto-increment mode for an auto-increment column. |
| ob_query_switch_leader_retry_timeout | Specifies the maximum retry time for failed queries, in microseconds (us). |
| default_enable_extended_rowid | Specifies whether to create a table in Extended ROWID mode. |
| dump_data_dictionary_to_log_interval | Specifies the interval at which the tenant data dictionary is persisted. |
| enable_user_defined_rewrite_rules | Specifies whether to enable user-defined rules. |
| storage_rowsets_size | The maximum number of rows allowed in a batch for vectorized processing in the columnstore engine. |
| approx_count_distinct_precision | Configures the result precision of the approx_count_distinct function. |
| enable_ps_parameterize | Specifies whether PS statements are parameterized during parsing. |
| default_skip_index_level | Controls the mechanism for generating Skip Indexes in incremental SSTables under the tenant. |
Transaction and transaction log parameters
| Parameter | Description |
|---|---|
| log_disk_utilization_limit_threshold | Specifies the threshold for the tenant log disk utilization limit. When the tenant log disk usage exceeds the total space of the tenant log disk multiplied by this threshold, log writes are no longer allowed. |
| log_disk_utilization_threshold | Specifies the threshold for tenant log disk utilization. When the tenant log disk usage exceeds the total space of the tenant log disk multiplied by this threshold, log file reuse is performed. |
| writing_throttling_maximum_duration | Controls the write speed by managing memory allocation progress. Specifically, it specifies the time required to allocate the remaining MemStore memory after triggering write throttling. |
| writing_throttling_trigger_percentage | Specifies the threshold for write speed. |
| standby_db_fetch_log_rpc_timeout | Specifies the RPC timeout period for standby database log fetching, which controls the standby database log transfer service's ability to detect an unavailable primary database server and switch to another. |
| log_disk_throttling_percentage | Specifies the percentage of unrecoverable log disk space that triggers log write throttling. |
| log_transport_compress_all | Specifies whether to use compression for log transmission. |
| log_transport_compress_func | Specifies the compressor for log transmission. |
| clog_max_unconfirmed_log_count | Specifies the maximum number of unconfirmed logs allowed in the transaction module. |
| clog_persistence_compress_func | Specifies the compression algorithm for transaction log persistence. |
| enable_clog_persistence_compress | Specifies whether to enable transaction log persistence compression. |
Data types
| Configuration item | Description |
|---|---|
| json_document_max_depth | Specifies the maximum number of nested layers allowed in a JSON document. |
Locks
| Configuration item | Description |
|---|---|
| enable_lock_priority | Specifies whether to enable lock priority. |
System logs
| Configuration item | Description |
|---|---|
| log_disk_throttling_maximum_duration | Adjusts the maximum available time of the log disk after throttling is triggered. |
| ls_gc_delay_time | Specifies the time for delaying the deletion of tenant log streams. |
| standby_db_preferred_upstream_log_region | Specifies the preferred region for a standby database to synchronize upstream logs in a physical standby scenario. |
| archive_lag_target | Controls the time for tenant log archiving lag. |
Materialized view parameters
| Parameter | Description |
|---|---|
| enable_mlog_auto_maintenance | Specifies whether to enable the automatic management of materialized view logs.
NoteThis parameter is introduced in V4.3.5 BP4. |
| mlog_trim_interval | The interval between automatic pruning tasks for materialized view logs (mlogs).
NoteThis parameter is introduced in V4.3.5 BP4. |
| enable_mv_binlog_minimal_mode | Specifies whether to enable the minimal mode for materialized views.
NoteThis parameter is introduced in V4.3.5 BP5. |
User login parameters
| Configuration item | Description |
|---|---|
| enable_mlog_auto_maintenance | Specifies whether to enable automatic management of materialized view logs.
NoteThis configuration item was introduced in V4.3.5 BP4. |
| mlog_trim_interval | The interval for scheduling the automatic trimming task of materialized view logs (mlogs).
NoteThis configuration item was introduced in V4.3.5 BP4. |
User login-related parameters
Note
The following configuration items take effect only in MySQL mode.
| Configuration item | Description |
|---|---|
| connection_control_failed_connections_threshold | Specifies the threshold for user login attempts. |
| connection_control_min_connection_delay | Specifies the minimum time for locking out users after exceeding the threshold for failed login attempts. |
| connection_control_max_connection_delay | Specifies the maximum time for locking out users, after which the duration no longer increases. |
Compression algorithm parameters
| Parameter | Description |
|---|---|
| spill_compression_codec | Specifies the compression algorithm to use for compressing data spilled during SQL execution. |
| ob_encoding_granularity | Specifies the maximum number of rows allowed in a single microblock encoding. |
Major compactions and minor compactions
| Parameter | Description |
|---|---|
| default_progressive_merge_num | The default number of progressive major compactions for a newly created table. |
| major_freeze_duty_time | The time at which daily scheduled major compactions are triggered. |
| major_compact_trigger | The number of major compactions triggered before a major compaction is performed. |
| minor_compact_trigger | The number of SSTables that triggers a minor compaction. |
| undo_retention | The number of seconds that the system retains multiple versions of data. This parameter specifies the retention period of multiple versions of data during a minor compaction. |
| merger_check_interval | The interval between the scheduling of major compaction status check threads. |
| freeze_trigger_percentage | The threshold of memory usage of the tenant that triggers a global major compaction. |
| max_kept_major_version_number | The number of major compactions to retain data. |
| merge_stat_sampling_ratio | The sampling rate of data column statistics during a major compaction. |
| merge_thread_count | The number of threads for daily major compactions. |
| merger_completion_percentage | The percentage of replicas that must be completed to consider a major compaction complete. |
| merger_switch_leader_duration_time | The interval between major compactions during which the leader is changed in batches. |
| merger_warm_up_duration_time | The preheating time for the new baseline data during a major compaction. |
Arbitration service-related parameters
| Parameter | Description |
|---|---|
| arbitration_timeout | The timeout period for triggering automatic downgrade. |
Parameters that are not supported
| Parameter | Description |
|---|---|
| sql_work_area | The size of the tenant's working memory. |
| max_stale_time_for_weak_consistency | The maximum staleness of data allowed for weak-consistency reads. |