The environment configuration files (confignode-env.sh/bat and datanode-env.sh/bat) are used to configure Java environment parameters for ConfigNode and DataNode, such as JVM settings. These configurations are passed to the JVM when ConfigNode or DataNode starts.
The iotdb-system.properties file contains various configurations for managing IoTDB clusters, nodes, replication, directories, monitoring, SSL, connections, object storage, tier management, and REST services. Below is a detailed breakdown of the parameters:
Changes are distributed across nodes. Changes may not propagate to all nodes in case of network issues or node failures. Nodes that fail to update must manually modify cluster_name in their configuration files and restart. Under normal circumstances, it is not recommended to modify cluster_name by manually modifying configuration files or to perform hot-loading via load configuration method.
Schema storage path for DataNode. By default, it is stored in the data directory at the same level as the sbin directory. The starting directory of the relative path is related to the operating system. It is recommended to use an absolute path.
Data storage path for DataNode. By default, it is stored in the data directory at the same level as the sbin directory. The starting directory of the relative path is related to the operating system. It is recommended to use an absolute path.
Type
String
Default
data/datanode/data(Windows:data\datanode\data)
Effective
Restart required
dn_multi_dir_strategy
Name
dn_multi_dir_strategy
Description
The strategy used by IoTDB to select directories in data_dirs for TsFiles. You can use either the simple class name or the fully qualified class name. The system provides the following two strategies: 1. SequenceStrategy: IoTDB selects directories sequentially, iterating through all directories in data_dirs in a round-robin manner. 2. MaxDiskUsableSpaceFirstStrategy IoTDB prioritizes the directory in data_dirs with the largest disk free space. To implement a custom strategy: 1. Inherit the org.apache.iotdb.db.storageengine.rescon.disk.strategy.DirectoryStrategy class and implement your own strategy method. 2. Fill in the configuration item with the fully qualified class name of your implementation (package name + class name, e.g., UserDefineStrategyPackage). 3. Add the JAR file containing your custom class to the project.
Type
String
Default
SequenceStrategy
Effective
Hot reload.
dn_consensus_dir
Name
dn_consensus_dir
Description
Consensus log storage path for DataNode. By default, it is stored in the data directory at the same level as the sbin directory. The starting directory of the relative path is related to the operating system. It is recommended to use an absolute path.
Write-ahead log (WAL) storage path for DataNode. By default, it is stored in the data directory at the same level as the sbin directory. The starting directory of the relative path is related to the operating system. It is recommended to use an absolute path.
Type
String
Default
data/datanode/wal(Windows:data\datanode\wal)
Effective
Restart required
dn_tracing_dir
Name
dn_tracing_dir
Description
Tracing root directory for DataNode. By default, it is stored in the data directory at the same level as the sbin directory. The starting directory of the relative path is related to the operating system. It is recommended to use an absolute path.
Type
String
Default
datanode/tracing(Windows:datanode\tracing)
Effective
Restart required
dn_sync_dir
Name
dn_sync_dir
Description
Sync storage path for DataNode.By default, it is stored in the data directory at the same level as the sbin directory. The starting directory of the relative path is related to the operating system. It is recommended to use an absolute path.
Disk usage threshold, data will be moved to the next tier when the usage of the tier is higher than this threshold.If tiered storage is enabled, please separate thresholds of different tiers by semicolons ";".
Type
double
Default
0.85
Effective
Hot reload.
dn_tier_full_policy
Name
dn_tier_full_policy
Description
How to deal with the last tier's data when its used space has been higher than its dn_default_space_usage_thresholds.
Type
String
Default
NULL
Effective
Hot reload.
migrate_thread_count
Name
migrate_thread_count
Description
thread pool size for migrate operation in the DataNode's data directories.
Type
int
Default
1
Effective
Hot reload.
tiered_storage_migrate_speed_limit_bytes_per_sec
Name
tiered_storage_migrate_speed_limit_bytes_per_sec
Description
The migrate speed limit of different tiers can reach per second
The policy of extension SchemaRegionGroup for each Database.
Type
string
Default
AUTO
Effective
Restart required.
default_schema_region_group_num_per_database
Name
default_schema_region_group_num_per_database
Description
When set schema_region_group_extension_policy=CUSTOM, this parameter is the default number of SchemaRegionGroups for each Database.When set schema_region_group_extension_policy=AUTO, this parameter is the default minimal number of SchemaRegionGroups for each Database.
Type
int
Default
1
Effective
Restart required.
schema_region_per_data_node
Name
schema_region_per_data_node
Description
It only takes effect when set schema_region_group_extension_policy=AUTO.This parameter is the maximum number of SchemaRegions expected to be managed by each DataNode.
Type
double
Default
1.0
Effective
Restart required.
data_region_group_extension_policy
Name
data_region_group_extension_policy
Description
The policy of extension DataRegionGroup for each Database.
Type
string
Default
AUTO
Effective
Restart required.
default_data_region_group_num_per_database
Name
default_data_region_group_per_database
Description
When set data_region_group_extension_policy=CUSTOM, this parameter is the default number of DataRegionGroups for each Database.When set data_region_group_extension_policy=AUTO, this parameter is the default minimal number of DataRegionGroups for each Database.
Type
int
Default
2
Effective
Restart required.
data_region_per_data_node
Name
data_region_per_data_node
Description
It only takes effect when set data_region_group_extension_policy=AUTO.This parameter is the maximum number of DataRegions expected to be managed by each DataNode.
Type
double
Default
5.0
Effective
Restart required.
enable_auto_leader_balance_for_ratis_consensus
Name
enable_auto_leader_balance_for_ratis_consensus
Description
Whether to enable auto leader balance for Ratis consensus protocol.
Type
Boolean
Default
true
Effective
Restart required.
enable_auto_leader_balance_for_iot_consensus
Name
enable_auto_leader_balance_for_iot_consensus
Description
Whether to enable auto leader balance for IoTConsensus protocol.
Schema Memory Allocation Ratio: SchemaRegion, SchemaCache, and PartitionCache.
Type
Ratio
Default
5:4:1
Effective
Restart required.
storage_engine_memory_proportion
Name
storage_engine_memory_proportion
Description
Memory allocation ratio in StorageEngine: Write, Compaction
Type
Ratio
Default
8:2
Effective
Restart required.
write_memory_proportion
Name
write_memory_proportion
Description
Memory allocation ratio in writing: Memtable, TimePartitionInfo
Type
Ratio
Default
19:1
Effective
Restart required.
primitive_array_size
Name
primitive_array_size
Description
primitive array size (length of each array) in array pool
Type
int32
Default
64
Effective
Restart required.
chunk_metadata_size_proportion
Name
chunk_metadata_size_proportion
Description
Ratio of compaction memory for chunk metadata maintains in memory when doing compaction
Type
Double
Default
0.1
Effective
Restart required.
flush_proportion
Name
flush_proportion
Description
Ratio of memtable memory for invoking flush disk, 0.4 by defaultIf you have extremely high write load (like batch=1000), it can be set lower than the default value like 0.2
Type
Double
Default
0.4
Effective
Restart required.
buffered_arrays_memory_proportion
Name
buffered_arrays_memory_proportion
Description
Ratio of memtable memory allocated for buffered arrays, 0.6 by default
Type
Double
Default
0.6
Effective
Restart required.
reject_proportion
Name
reject_proportion
Description
Ratio of memtable memory for rejecting insertion, 0.8 by defaultIf you have extremely high write load (like batch=1000) and the physical memory size is large enough, it can be set higher than the default value like 0.9
Type
Double
Default
0.8
Effective
Restart required.
device_path_cache_proportion
Name
device_path_cache_proportion
Description
Ratio of memtable memory for the DevicePathCache. DevicePathCache is the deviceId cache, keeping only one copy of the same deviceId in memory
Type
Double
Default
0.05
Effective
Restart required.
write_memory_variation_report_proportion
Name
write_memory_variation_report_proportion
Description
If memory cost of data region increased more than proportion of allocated memory for writing, report to system. The default value is 0.001
Type
Double
Default
0.001
Effective
Restart required.
check_period_when_insert_blocked
Name
check_period_when_insert_blocked
Description
When an insertion is rejected, the waiting period (in ms) to check system again, 50 by default.If the insertion has been rejected and the read load is low, it can be set larger.
Type
int32
Default
50
Effective
Restart required.
io_task_queue_size_for_flushing
Name
io_task_queue_size_for_flushing
Description
size of ioTaskQueue. The default value is 10
Type
int32
Default
10
Effective
Restart required.
enable_query_memory_estimation
Name
enable_query_memory_estimation
Description
If true, we will estimate each query's possible memory footprint before executing it and deny it if its estimated memory exceeds current free memory
The schema management mode of schema engine. Currently, support Memory and PBTree.This config of all DataNodes in one cluster must keep same.
Type
string
Default
Memory
Effective
Modify before the first startup.
partition_cache_size
Name
partition_cache_size
Description
cache size for partition.
Type
Int32
Default
1000
Effective
Restart required.
sync_mlog_period_in_ms
Name
sync_mlog_period_in_ms
Description
The cycle when metadata log is periodically forced to be written to disk(in milliseconds)If sync_mlog_period_in_ms=0 it means force metadata log to be written to disk after each refreshmentSetting this parameter to 0 may slow down the operation on slow disk.
Type
Int64
Default
100
Effective
Restart required.
tag_attribute_flush_interval
Name
tag_attribute_flush_interval
Description
interval num for tag and attribute records when force flushing to disk
Type
int32
Default
1000
Effective
Modify before the first startup.
tag_attribute_total_size
Name
tag_attribute_total_size
Description
max size for a storage block for tags and attributes of a one-time series
Type
int32
Default
700
Effective
Modify before the first startup.
max_measurement_num_of_internal_request
Name
max_measurement_num_of_internal_request
Description
max measurement num of internal requestWhen creating timeseries with Session.createMultiTimeseries, the user input plan, the timeseries num ofwhich exceeds this num, will be split to several plans with timeseries no more than this num.
Type
Int32
Default
10000
Effective
Restart required.
datanode_schema_cache_eviction_policy
Name
datanode_schema_cache_eviction_policy
Description
Policy of DataNodeSchemaCache eviction.
Type
String
Default
FIFO
Effective
Restart required.
cluster_timeseries_limit_threshold
Name
cluster_timeseries_limit_threshold
Description
This configuration parameter sets the maximum number of time series allowed in the cluster.
Type
Int32
Default
-1
Effective
Restart required.
cluster_device_limit_threshold
Name
cluster_device_limit_threshold
Description
This configuration parameter sets the maximum number of devices allowed in the cluster.
Type
Int32
Default
-1
Effective
Restart required.
database_limit_threshold
Name
database_limit_threshold
Description
This configuration parameter sets the maximum number of Cluster Databases allowed.
Database level when creating schema automatically is enabled e.g. root.sg0.d1.s2We will set root.sg0 as the database if database level is 1If the incoming path is shorter than this value, the creation/insertion will fail.
Value
int32
Default
1
Effective
Restart required.
boolean_string_infer_type
Name
boolean_string_infer_type
Description
register time series as which type when receiving boolean string "true" or "false"
Value
BOOLEAN or TEXT
Default
BOOLEAN
Effective
Restart required.
integer_string_infer_type
Name
integer_string_infer_type
Description
register time series as which type when receiving an integer string and using float or double may lose precision
Value
INT32, INT64, FLOAT, DOUBLE, TEXT
Default
DOUBLE
Effective
Restart required.
floating_string_infer_type
Name
floating_string_infer_type
Description
register time series as which type when receiving a floating number string "6.7"
Value
DOUBLE, FLOAT or TEXT
Default
DOUBLE
Effective
Restart required.
nan_string_infer_type
Name
nan_string_infer_type
Description
register time series as which type when receiving the Literal NaN.
Value
DOUBLE, FLOAT or TEXT
Default
DOUBLE
Effective
Restart required.
default_boolean_encoding
Name
default_boolean_encoding
Description
BOOLEAN encoding when creating schema automatically is enabled
Value
PLAIN, RLE
Default
RLE
Effective
Restart required.
default_int32_encoding
Name
default_int32_encoding
Description
INT32 encoding when creating schema automatically is enabled
Value
PLAIN, RLE, TS_2DIFF, REGULAR, GORILLA
Default
TS_2DIFF
Effective
Restart required.
default_int64_encoding
Name
default_int64_encoding
Description
INT64 encoding when creating schema automatically is enabled
Value
PLAIN, RLE, TS_2DIFF, REGULAR, GORILLA
Default
TS_2DIFF
Effective
Restart required.
default_float_encoding
Name
default_float_encoding
Description
FLOAT encoding when creating schema automatically is enabled
Value
PLAIN, RLE, TS_2DIFF, GORILLA
Default
GORILLA
Effective
Restart required.
default_double_encoding
Name
default_double_encoding
Description
DOUBLE encoding when creating schema automatically is enabled
Value
PLAIN, RLE, TS_2DIFF, GORILLA
Default
GORILLA
Effective
Restart required.
default_text_encoding
Name
default_text_encoding
Description
TEXT encoding when creating schema automatically is enabled
The read consistency levelThese consistency levels are currently supported:strong(Default, read from the leader replica)weak(Read from a random replica)
Type
String
Default
strong
Effective
Restart required.
meta_data_cache_enable
Name
meta_data_cache_enable
Description
Whether to cache meta data (BloomFilter, ChunkMetadata and TimeSeriesMetadata) or not.
Type
Boolean
Default
true
Effective
Restart required.
chunk_timeseriesmeta_free_memory_proportion
Name
chunk_timeseriesmeta_free_memory_proportion
Description
Read memory Allocation Ratio: BloomFilterCache : ChunkCache : TimeSeriesMetadataCache : Coordinator : Operators : DataExchange : timeIndex in TsFileResourceList : others.The parameter form is a🅱️c:d:e:f:g:h, where a, b, c, d, e, f, g and h are integers. for example: 1:1:1:1:1:1:1:1 , 1💯200:50:200:200:200:50
Type
String
Default
1 : 100 : 200 : 300 : 400
Effective
Restart required.
enable_last_cache
Name
enable_last_cache
Description
Whether to enable LAST cache
Type
Boolean
Default
true
Effective
Restart required.
mpp_data_exchange_core_pool_size
Name
mpp_data_exchange_core_pool_size
Description
Core size of ThreadPool of MPP data exchange
Type
int32
Default
10
Effective
Restart required.
mpp_data_exchange_max_pool_size
Name
mpp_data_exchange_max_pool_size
Description
Max size of ThreadPool of MPP data exchange
Type
int32
Default
10
Effective
Restart required.
mpp_data_exchange_keep_alive_time_in_ms
Name
mpp_data_exchange_keep_alive_time_in_ms
Description
Max waiting time for MPP data exchange
Type
int32
Default
1000
Effective
Restart required.
driver_task_execution_time_slice_in_ms
Name
driver_task_execution_time_slice_in_ms
Description
The max execution time of a DriverTask
Type
int32
Default
200
Effective
Restart required.
max_tsblock_size_in_bytes
Name
max_tsblock_size_in_bytes
Description
The max capacity of a TsBlock
Type
int32
Default
131072
Effective
Restart required.
max_tsblock_line_numbers
Name
max_tsblock_line_numbers
Description
The max number of lines in a single TsBlock
Type
int32
Default
1000
Effective
Restart required.
slow_query_threshold
Name
slow_query_threshold
Description
Time cost(ms) threshold for slow query
Type
long
Default
10000
Effective
Hot reload
query_timeout_threshold
Name
query_timeout_threshold
Description
The max executing time of query. unit: ms
Type
Int32
Default
60000
Effective
Restart required.
max_allowed_concurrent_queries
Name
max_allowed_concurrent_queries
Description
The maximum allowed concurrently executing queries
Type
Int32
Default
1000
Effective
Restart required.
query_thread_count
Name
query_thread_count
Description
How many threads can concurrently execute query statement. When <= 0, use CPU core number.
Type
Int32
Default
0
Effective
Restart required.
degree_of_query_parallelism
Name
degree_of_query_parallelism
Description
How many pipeline drivers will be created for one fragment instance. When <= 0, use CPU core number / 2.
Type
Int32
Default
0
Effective
Restart required.
mode_map_size_threshold
Name
mode_map_size_threshold
Description
The threshold of count map size when calculating the MODE aggregation function
Type
Int32
Default
10000
Effective
Restart required.
batch_size
Name
batch_size
Description
The amount of data iterate each time in server (the number of data strips, that is, the number of different timestamps.)
Type
Int32
Default
100000
Effective
Restart required.
sort_buffer_size_in_bytes
Name
sort_buffer_size_in_bytes
Description
The memory for external sort in sort operator, when the data size is smaller than sort_buffer_size_in_bytes, the sort operator will use in-memory sort.
Type
long
Default
1048576
Effective
Restart required.
merge_threshold_of_explain_analyze
Name
merge_threshold_of_explain_analyze
Description
The threshold of operator count in the result set of EXPLAIN ANALYZE, if the number of operator in the result set is larger than this threshold, operator will be merged.
The interval of TTL check task in each database. The TTL check task will inspect and select files with a higher volume of expired data for compaction. Default is 2 hours.
Type
int
Default
7200000
Effective
Restart required.
max_expired_time
Name
max_expired_time
Description
The maximum expiring time of device which has a ttl. Default is 1 month.If the data elapsed time (current timestamp minus the maximum data timestamp of the device in the file) of such devices exceeds this value, then the file will be cleaned by compaction.
Type
int
Default
2592000000
Effective
Restart required.
expired_data_ratio
Name
expired_data_ratio
Description
The expired device ratio. If the ratio of expired devices in one file exceeds this value, then expired data of this file will be cleaned by compaction.
Use this value to set timestamp precision as "ms", "us" or "ns".
Type
String
Default
ms
Effective
Modify before the first startup.
timestamp_precision_check_enabled
Name
timestamp_precision_check_enabled
Description
When the timestamp precision check is enabled, the timestamps those are over 13 digits for ms precision, or over 16 digits for us precision are not allowed to be inserted.
Type
Boolean
Default
true
Effective
Modify before the first startup.
max_waiting_time_when_insert_blocked
Name
max_waiting_time_when_insert_blocked
Description
When the waiting time (in ms) of an inserting exceeds this, throw an exception. 10000 by default.
Type
Int32
Default
10000
Effective
Restart required.
handle_system_error
Name
handle_system_error
Description
What will the system do when unrecoverable error occurs.
Type
String
Default
CHANGE_TO_READ_ONLY
Effective
Restart required.
enable_timed_flush_seq_memtable
Name
enable_timed_flush_seq_memtable
Description
Whether to timed flush sequence tsfiles' memtables.
Type
Boolean
Default
true
Effective
Hot reload
seq_memtable_flush_interval_in_ms
Name
seq_memtable_flush_interval_in_ms
Description
If a memTable's last update time is older than current time minus this, the memtable will be flushed to disk.
Type
long
Default
600000
Effective
Hot reload
seq_memtable_flush_check_interval_in_ms
Name
seq_memtable_flush_check_interval_in_ms
Description
The interval to check whether sequence memtables need flushing.
Type
long
Default
30000
Effective
Hot reload
enable_timed_flush_unseq_memtable
Name
enable_timed_flush_unseq_memtable
Description
Whether to timed flush unsequence tsfiles' memtables.
Type
Boolean
Default
true
Effective
Hot reload
unseq_memtable_flush_interval_in_ms
Name
unseq_memtable_flush_interval_in_ms
Description
If a memTable's last update time is older than current time minus this, the memtable will be flushed to disk.
Type
long
Default
600000
Effective
Hot reload
unseq_memtable_flush_check_interval_in_ms
Name
unseq_memtable_flush_check_interval_in_ms
Description
The interval to check whether unsequence memtables need flushing.
Type
long
Default
30000
Effective
Hot reload
tvlist_sort_algorithm
Name
tvlist_sort_algorithm
Description
The sort algorithms used in the memtable's TVList
Type
String
Default
TIM
Effective
Restart required.
avg_series_point_number_threshold
Name
avg_series_point_number_threshold
Description
When the average point number of timeseries in memtable exceeds this, the memtable is flushed to disk.
Type
int32
Default
100000
Effective
Restart required.
flush_thread_count
Name
flush_thread_count
Description
How many threads can concurrently flush. When <= 0, use CPU core number.
Type
int32
Default
0
Effective
Restart required.
enable_partial_insert
Name
enable_partial_insert
Description
In one insert (one device, one timestamp, multiple measurements), if enable partial insert, one measurement failure will not impact other measurements
Type
Boolean
Default
true
Effective
Restart required.
recovery_log_interval_in_ms
Name
recovery_log_interval_in_ms
Description
the interval to log recover progress of each vsg when starting iotdb
Type
Int32
Default
5000
Effective
Restart required.
0.13_data_insert_adapt
Name
0.13_data_insert_adapt
Description
If using a v0.13 client to insert data, please set this configuration to true.
Type
Boolean
Default
false
Effective
Restart required.
enable_tsfile_validation
Name
enable_tsfile_validation
Description
Verify that TSfiles generated by Flush, Load, and Compaction are correct.
Type
boolean
Default
false
Effective
Hot reload
tier_ttl_in_ms
Name
tier_ttl_in_ms
Description
Default tier TTL. When the survival time of the data exceeds the threshold, it will be migrated to the next tier.
sequence space compaction: only compact the sequence files
Type
Boolean
Default
true
Effective
Hot reload
enable_unseq_space_compaction
Name
enable_unseq_space_compaction
Description
unsequence space compaction: only compact the unsequence files
Type
Boolean
Default
true
Effective
Hot reload
enable_cross_space_compaction
Name
enable_cross_space_compaction
Description
cross space compaction: compact the unsequence files into the overlapped sequence files
Type
Boolean
Default
true
Effective
Hot reload
enable_auto_repair_compaction
Name
enable_auto_repair_compaction
Description
enable auto repair unsorted file by compaction
Type
Boolean
Default
true
Effective
Hot reload
cross_selector
Name
cross_selector
Description
the selector of cross space compaction task
Type
String
Default
rewrite
Effective
Restart required.
cross_performer
Name
cross_performer
Description
the compaction performer of cross space compaction task
Type
String
Default
fast
Effective
Restart required.
inner_seq_selector
Name
inner_seq_selector
Description
the selector of inner sequence space compaction task
Type
String
Default
size_tiered_multi_target
Effective
Hot reload
inner_seq_performer
Name
inner_seq_performer
Description
the performer of inner sequence space compaction task
Type
String
Default
read_chunk
Effective
Restart required.
inner_unseq_selector
Name
inner_unseq_selector
Description
the selector of inner unsequence space compaction task
Type
String
Default
size_tiered_multi_target
Effective
Hot reload
inner_unseq_performer
Name
inner_unseq_performer
Description
the performer of inner unsequence space compaction task
Type
String
Default
fast
Effective
Restart required.
compaction_priority
Name
compaction_priority
Description
The priority of compaction executionINNER_CROSS: prioritize inner space compaction, reduce the number of files firstCROSS_INNER: prioritize cross space compaction, eliminate the unsequence files firstBALANCE: alternate two compaction types
Type
String
Default
INNER_CROSS
Effective
重启服务生效
candidate_compaction_task_queue_size
Name
candidate_compaction_task_queue_size
Description
The size of candidate compaction task queue.
Type
int32
Default
50
Effective
Restart required.
target_compaction_file_size
Name
target_compaction_file_size
Description
This parameter is used in two places:The target tsfile size of inner space compaction.The candidate size of seq tsfile in cross space compaction will be smaller than target_compaction_file_size * 1.5.In most cases, the target file size of cross compaction won't exceed this threshold, and if it does, it will not be much larger than it.
Type
Int64
Default
2147483648
Effective
Hot reload
inner_compaction_total_file_size_threshold
Name
inner_compaction_total_file_size_threshold
Description
The total file size limit in inner space compaction.
Type
int64
Default
10737418240
Effective
Hot reload
inner_compaction_total_file_num_threshold
Name
inner_compaction_total_file_num_threshold
Description
The total file num limit in inner space compaction.
Type
int32
Default
100
Effective
Hot reload
max_level_gap_in_inner_compaction
Name
max_level_gap_in_inner_compaction
Description
The max level gap in inner compaction selection
Type
int32
Default
2
Effective
Hot reload
target_chunk_size
Name
target_chunk_size
Description
The target chunk size in compaction and when memtable reaches this threshold, flush the memtable to disk.
Type
Int64
Default
1048576
Effective
Restart required.
target_chunk_point_num
Name
target_chunk_point_num
Description
The target point nums in one chunk in compaction
Type
int32
Default
100000
Effective
Restart required.
chunk_size_lower_bound_in_compaction
Name
chunk_size_lower_bound_in_compaction
Description
If the chunk size is lower than this threshold, it will be deserialized into points
Type
Int64
Default
128
Effective
Restart required.
chunk_point_num_lower_bound_in_compaction
Name
chunk_point_num_lower_bound_in_compaction
Description
If the chunk point num is lower than this threshold, it will be deserialized into points
Type
int32
Default
100
Effective
Restart required.
inner_compaction_candidate_file_num
Name
inner_compaction_candidate_file_num
Description
The file num requirement when selecting inner space compaction candidate files
Type
int32
Default
30
Effective
Hot reload
max_cross_compaction_candidate_file_num
Name
max_cross_compaction_candidate_file_num
Description
The max file when selecting cross space compaction candidate files
Type
int32
Default
500
Effective
Hot reload
max_cross_compaction_candidate_file_size
Name
max_cross_compaction_candidate_file_size
Description
The max total size when selecting cross space compaction candidate files
Type
Int64
Default
5368709120
Effective
Hot reload
min_cross_compaction_unseq_file_level
Name
min_cross_compaction_unseq_file_level
Description
The min inner compaction level of unsequence file which can be selected as candidate
Type
int32
Default
1
Effective
Hot reload
compaction_thread_count
Name
compaction_thread_count
Description
How many threads will be set up to perform compaction, 10 by default.
Type
int32
Default
10
Effective
Hot reload
compaction_max_aligned_series_num_in_one_batch
Name
compaction_max_aligned_series_num_in_one_batch
Description
How many chunk will be compacted in aligned series compaction, 10 by default.
Type
int32
Default
10
Effective
Hot reload
compaction_schedule_interval_in_ms
Name
compaction_schedule_interval_in_ms
Description
The interval of compaction task schedule
Type
Int64
Default
60000
Effective
Restart required.
compaction_write_throughput_mb_per_sec
Name
compaction_write_throughput_mb_per_sec
Description
The limit of write throughput merge can reach per second
Type
int32
Default
16
Effective
Restart required.
compaction_read_throughput_mb_per_sec
Name
compaction_read_throughput_mb_per_sec
Description
The limit of read throughput merge can reach per second
Type
int32
Default
0
Effective
Hot reload
compaction_read_operation_per_sec
Name
compaction_read_operation_per_sec
Description
The limit of read operation merge can reach per second
Type
int32
Default
0
Effective
Hot reload
sub_compaction_thread_count
Name
sub_compaction_thread_count
Description
The number of sub compaction threads to be set up to perform compaction.
Type
int32
Default
4
Effective
Hot reload
inner_compaction_task_selection_disk_redundancy
Name
inner_compaction_task_selection_disk_redundancy
Description
Redundancy value of disk availability, only use for inner compaction.
The details of these three modes are as follows:DISABLE: the system will disable wal.SYNC: the system will submit wal synchronously, write request will not return until its wal is fsynced to the disk successfully.ASYNC: the system will submit wal asynchronously, write request will return immediately no matter its wal is fsynced to the disk successfully.
Type
String
Default
ASYNC
Effective
Restart required.
max_wal_nodes_num
Name
max_wal_nodes_num
Description
each node corresponds to one wal directory The default value 0 means the number is determined by the system, the number is in the range of [data region num / 2, data region num].
Type
int32
Default
0
Effective
Restart required.
wal_async_mode_fsync_delay_in_ms
Name
wal_async_mode_fsync_delay_in_ms
Description
Duration a wal flush operation will wait before calling fsync in the async mode
Type
int32
Default
1000
Effective
Hot reload
wal_sync_mode_fsync_delay_in_ms
Name
wal_sync_mode_fsync_delay_in_ms
Description
Duration a wal flush operation will wait before calling fsync in the sync mode
Type
int32
Default
3
Effective
Hot reload
wal_buffer_size_in_byte
Name
wal_buffer_size_in_byte
Description
Buffer size of each wal node
Type
int32
Default
33554432
Effective
Restart required.
wal_buffer_queue_capacity
Name
wal_buffer_queue_capacity
Description
Buffer capacity of each wal queue
Type
int32
Default
500
Effective
Restart required.
wal_file_size_threshold_in_byte
Name
wal_file_size_threshold_in_byte
Description
Size threshold of each wal file
Type
int32
Default
31457280
Effective
Hot reload
wal_min_effective_info_ratio
Name
wal_min_effective_info_ratio
Description
Minimum ratio of effective information in wal files
Type
double
Default
0.1
Effective
Hot reload
wal_memtable_snapshot_threshold_in_byte
Name
wal_memtable_snapshot_threshold_in_byte
Description
MemTable size threshold for triggering MemTable snapshot in wal
Type
int64
Default
8388608
Effective
Hot reload
max_wal_memtable_snapshot_num
Name
max_wal_memtable_snapshot_num
Description
MemTable's max snapshot number in wal
Type
int32
Default
1
Effective
Hot reload
delete_wal_files_period_in_ms
Name
delete_wal_files_period_in_ms
Description
The period when outdated wal files are periodically deleted
Type
int64
Default
20000
Effective
Hot reload
wal_throttle_threshold_in_byte
Name
wal_throttle_threshold_in_byte
Description
The minimum size of wal files when throttle down in IoTConsensus
The maximum number of bytes written to disk each time the data in memory is written to disk
Type
int32
Default
134217728
Effective
Hot reload
page_size_in_byte
Name
page_size_in_byte
Description
The memory size for each series writer to pack page, default value is 64KB
Type
int32
Default
65536
Effective
Hot reload
max_number_of_points_in_page
Name
max_number_of_points_in_page
Description
The maximum number of data points in a page
Type
int32
Default
10000
Effective
Hot reload
pattern_matching_threshold
Name
pattern_matching_threshold
Description
The threshold for pattern matching in regex
Type
int32
Default
1000000
Effective
Hot reload
float_precision
Name
float_precision
Description
Floating-point precision of query results.Only effective for RLE and TS_2DIFF encodings.Due to the limitation of machine precision, some values may not be interpreted strictly.
Type
int32
Default
2
Effective
Hot reload
value_encoder
Name
value_encoder
Description
Encoder of value series. default value is PLAIN.
Type
For int, long data type, also supports TS_2DIFF and RLE(run-length encoding), GORILLA and ZIGZAG.
Default
PLAIN
Effective
Hot reload
compressor
Name
compressor
Description
Compression configuration And it is also used as the default compressor of time column in aligned timeseries.
Type
Data compression method, supports UNCOMPRESSED, SNAPPY, ZSTD, LZMA2 or LZ4. Default value is LZ4
Used to estimate the memory usage of text fields in a UDF query.It is recommended to set this value to be slightly larger than the average length of all text records.
Type
int32
Default
48
Effective
Restart required.
udf_memory_budget_in_mb
Name
udf_memory_budget_in_mb
Description
How much memory may be used in ONE UDF query (in MB). The upper limit is 20% of allocated memory for read.
The maximum number of threads that can be used to execute the pipe subtasks in PipeSubtaskExecutor. The actual value will be min(pipe_subtask_executor_max_thread_num, max(1, CPU core number / 2)).
Type
int
Default
5
Effective
Restart required.
pipe_sink_timeout_ms
Name
pipe_sink_timeout_ms
Description
The connection timeout (in milliseconds) for the thrift client.
Type
int
Default
900000
Effective
Restart required.
pipe_sink_selector_number
Name
pipe_sink_selector_number
Description
The maximum number of selectors that can be used in the sink.Recommend to set this value to less than or equal to pipe_sink_max_client_number.
Type
int
Default
4
Effective
Restart required.
pipe_sink_max_client_number
Name
pipe_sink_max_client_number
Description
The maximum number of clients that can be used in the sink.
Type
int
Default
16
Effective
Restart required.
pipe_air_gap_receiver_enabled
Name
pipe_air_gap_receiver_enabled
Description
Whether to enable receiving pipe data through air gap.The receiver can only return 0 or 1 in TCP mode to indicate whether the data is received successfully.
Type
Boolean
Default
false
Effective
Restart required.
pipe_air_gap_receiver_port
Name
pipe_air_gap_receiver_port
Description
The port for the server to receive pipe data through air gap.
Type
int
Default
9780
Effective
Restart required.
pipe_all_sinks_rate_limit_bytes_per_second
Name
pipe_all_sinks_rate_limit_bytes_per_second
Description
The total bytes that all pipe sinks can transfer per second.When given a value less than or equal to 0, it means no limit. default value is -1, which means no limit.
whether enable audit log for DML operation of datawhether enable audit log for DDL operation of schemawhether enable audit log for QUERY operation of data and schema
Load clean up task is used to clean up the unsuccessful loaded tsfile after a certain period of time.
Type
int
Default
1800
Effective
Hot reload
load_write_throughput_bytes_per_second
Name
load_write_throughput_bytes_per_second
Description
The maximum bytes per second of disk write throughput when loading tsfile.
Type
int
Default
-1
Effective
Hot reload
load_active_listening_enable
Name
load_active_listening_enable
Description
Whether to enable the active listening mode for tsfile loading.
Type
Boolean
Default
true
Effective
Hot reload
load_active_listening_dirs
Name
load_active_listening_dirs
Description
The directory to be actively listened for tsfile loading.Multiple directories should be separated by a ','.
Type
String
Default
ext/load/pending
Effective
Hot reload
load_active_listening_fail_dir
Name
load_active_listening_fail_dir
Description
The directory where tsfiles are moved if the active listening mode fails to load them.
Type
String
Default
ext/load/failed
Effective
Hot reload
load_active_listening_max_thread_num
Name
load_active_listening_max_thread_num
Description
The maximum number of threads that can be used to load tsfile actively.The default value, when this parameter is commented out or <= 0, use CPU core number.
Type
Long
Default
0
Effective
Restart required.
load_active_listening_check_interval_seconds
Name
load_active_listening_check_interval_seconds
Description
The interval specified in seconds for the active listening mode to check the directory specified in load_active_listening_dirs.The active listening mode will check the directory every load_active_listening_check_interval_seconds seconds.