Skip to main content

Common Configuration

...About 25 min

Common Configuration

IoTDB common files for ConfigNode and DataNode are under conf.

  • iotdb-common.properties:IoTDB common configurations.

Effective

Different configuration parameters take effect in the following three ways:

  • Only allowed to be modified in first start up: Can't be modified after first start, otherwise the ConfigNode/DataNode cannot start.
  • After restarting system: Can be modified after the ConfigNode/DataNode first start, but take effect after restart.
  • hot-load: Can be modified while the ConfigNode/DataNode is running, and trigger through sending the command(sql) load configuration to the IoTDB server by client or session.

Configuration File

Replication Configuration

  • config_node_consensus_protocol_class
Nameconfig_node_consensus_protocol_class
DescriptionConsensus protocol of ConfigNode replicas, only support RatisConsensus
TypeString
Defaultorg.apache.iotdb.consensus.ratis.RatisConsensus
EffectiveOnly allowed to be modified in first start up
  • schema_replication_factor
Nameschema_replication_factor
DescriptionSchema replication num
Typeint32
Default1
EffectiveTake effect on new created Databases after restarting system
  • schema_region_consensus_protocol_class
Nameschema_region_consensus_protocol_class
DescriptionConsensus protocol of schema replicas, SimpleConsensus could only be used in 1 replica,larger than 1 replicas could only use RatisConsensus
TypeString
Defaultorg.apache.iotdb.consensus.ratis.RatisConsensus
EffectiveOnly allowed to be modified in first start up
  • data_replication_factor
Namedata_replication_factor
DescriptionData replication num
Typeint32
Default1
EffectiveTake effect on new created Databases after restarting system
  • data_region_consensus_protocol_class
Namedata_region_consensus_protocol_class
DescriptionConsensus protocol of data replicas, SimpleConsensus could only be used in 1 replica,larger than 1 replicas could use IoTConsensus or RatisConsensus
TypeString
Defaultorg.apache.iotdb.consensus.simple.SimpleConsensus
EffectiveOnly allowed to be modified in first start up

Load balancing Configuration

  • series_partition_slot_num
Nameseries_slot_num
DescriptionSlot num of series partition
Typeint32
Default10000
EffectiveOnly allowed to be modified in first start up
  • series_partition_executor_class
Nameseries_partition_executor_class
DescriptionSeries partition hash function
TypeString
Defaultorg.apache.iotdb.commons.partition.executor.hash.BKDRHashExecutor
EffectiveOnly allowed to be modified in first start up
  • schema_region_group_extension_policy
Nameschema_region_group_extension_policy
DescriptionThe extension policy of SchemaRegionGroup
Typestring
DefaultAUTO
EffectiveAfter restarting system
  • default_schema_region_group_num_per_database
Namedefault_schema_region_group_num_per_database
DescriptionThe number of SchemaRegionGroups that each Database has when using the CUSTOM-SchemaRegionGroup extension policy. The least number of SchemaRegionGroups that each Database has when using the AUTO-SchemaRegionGroup extension policy.
Typeint
Default1
EffectiveAfter restarting system
  • schema_region_per_data_node
Nameschema_region_per_data_node
DescriptionThe maximum number of SchemaRegion expected to be managed by each DataNode
Typedouble
Default1.0
EffectiveAfter restarting system
  • data_region_group_extension_policy
Namedata_region_group_extension_policy
DescriptionThe extension policy of DataRegionGroup
Typestring
DefaultAUTO
EffectiveAfter restarting system
  • default_data_region_group_num_per_database
Namedefault_data_region_group_num_per_database
DescriptionThe number of DataRegionGroups that each Database has when using the CUSTOM-DataRegionGroup extension policy. The least number of DataRegionGroups that each Database has when using the AUTO-DataRegionGroup extension policy.
Typeint
Default1
EffectiveAfter restarting system
  • data_region_per_processor
Namedata_region_per_processor
DescriptionThe maximum number of DataRegion expected to be managed by each processor
Typedouble
Default1.0
EffectiveAfter restarting system
  • enable_data_partition_inherit_policy
Nameenable_data_partition_inherit_policy
DescriptionWhether to enable the DataPartition inherit policy
TypeBoolean
Defaultfalse
EffectiveAfter restarting system
  • leader_distribution_policy
Nameleader_distribution_policy
DescriptionThe policy of cluster RegionGroups' leader distribution
TypeString
DefaultMIN_COST_FLOW
EffectiveAfter restarting system
  • enable_auto_leader_balance_for_ratis
Nameenable_auto_leader_balance_for_ratis_consensus
DescriptionWhether to enable auto leader balance for Ratis consensus protocol
TypeBoolean
Defaultfalse
EffectiveAfter restarting system
  • enable_auto_leader_balance_for_iot_consensus
Nameenable_auto_leader_balance_for_iot_consensus
DescriptionWhether to enable auto leader balance for IoTConsensus protocol
TypeBoolean
Defaulttrue
EffectiveAfter restarting system

Cluster Management

  • time_partition_interval
Nametime_partition_interval
DescriptionTime partition interval of data when ConfigNode allocate data
TypeLong
Unitms
Default604800000
EffectiveOnly allowed to be modified in first start up
  • heartbeat_interval_in_ms
Nameheartbeat_interval_in_ms
DescriptionHeartbeat interval in the cluster nodes
TypeLong
Unitms
Default1000
EffectiveAfter restarting system
  • disk_space_warning_threshold
Namedisk_space_warning_threshold
DescriptionDisk remaining threshold
Typedouble(percentage)
Default0.05
EffectiveAfter restarting system

Memory Control Configuration

  • enable_mem_control
Nameenable_mem_control
Descriptionenable memory control to avoid OOM
TypeBoolean
Defaulttrue
EffectiveAfter restarting system
  • storage_query_schema_consensus_free_memory_proportion
Namestorage_query_schema_consensus_free_memory_proportion
DescriptionMemory Allocation Ratio: StorageEngine, QueryEngine, SchemaEngine, Consensus and Free Memory
TypeRatio
Default3:3:1:1:2
EffectiveAfter restarting system
  • schema_memory_allocate_proportion
Nameschema_memory_allocate_proportion
DescriptionSchema Memory Allocation Ratio: SchemaRegion, SchemaCache, PartitionCache and LastCache
TypeRatio
Default5:3:1:1
EffectiveAfter restarting system
  • storage_engine_memory_proportion
Namestorage_engine_memory_proportion
DescriptionMemory allocation ratio in StorageEngine: Write, Compaction
TypeRatio
Default8:2
EffectiveAfter restarting system
  • write_memory_proportion
Namewrite_memory_proportion
DescriptionMemory allocation ratio in writing: Memtable, TimePartitionInfo
TypeRatio
Default19:1
EffectiveAfter restarting system
  • concurrent_writing_time_partition
Nameconcurrent_writing_time_partition
DescriptionThis config decides how many time partitions in a database can be inserted concurrently
For example, your partitionInterval is 86400 and you want to insert data in 5 different days,
Typeint32
Default1
EffectiveAfter restarting system
  • primitive_array_size
Nameprimitive_array_size
Descriptionprimitive array size (length of each array) in array pool
TypeInt32
Default64
EffectiveAfter restart system
  • chunk_metadata_size_proportion
Namechunk_metadata_size_proportion
Descriptionsize proportion for chunk metadata maintains in memory when writing tsfile
TypeDouble
Default0.1
EffectiveAfter restart system
  • flush_proportion
Nameflush_proportion
DescriptionRatio of write memory for invoking flush disk, 0.4 by default If you have extremely high write load (like batch=1000), it can be set lower than the default value like 0.2
TypeDouble
Default0.4
EffectiveAfter restart system
  • buffered_arrays_memory_proportion
Namebuffered_arrays_memory_proportion
DescriptionRatio of write memory allocated for buffered arrays
TypeDouble
Default0.6
EffectiveAfter restart system
  • reject_proportion
Namereject_proportion
DescriptionRatio of write memory for rejecting insertion
TypeDouble
Default0.8
EffectiveAfter restart system
  • write_memory_variation_report_proportion
Namewrite_memory_variation_report_proportion
Descriptionif memory cost of data region increased more than proportion of allocated memory for write, report to system
TypeDouble
Default0.001
EffectiveAfter restarting system
  • check_period_when_insert_blocked
Namecheck_period_when_insert_blocked
Descriptionwhen an inserting is rejected, waiting period (in ms) to check system again
TypeInt32
Default50
EffectiveAfter restart system
  • io_task_queue_size_for_flushing
Nameio_task_queue_size_for_flushing
Descriptionsize of ioTaskQueue. The default value is 10
TypeInt32
Default10
EffectiveAfter restart system
  • enable_query_memory_estimation
Nameenable_query_memory_estimation
DescriptionIf true, we will estimate each query's possible memory footprint before executing it and deny it if its estimated memory exceeds current free memory
Typebool
Defaulttrue
Effectivehot-load
  • partition_cache_size
Namepartition_cache_size
DescriptionThe max num of partition info record cached on DataNode.
TypeInt32
Default1000
EffectiveAfter restarting system

Schema Engine Configuration

  • mlog_buffer_size
Namemlog_buffer_size
Descriptionsize of log buffer in each metadata operation plan(in byte)
Typeint32
Default1048576
EffectiveAfter restart system
  • sync_mlog_period_in_ms
Namesync_mlog_period_in_ms
DescriptionThe cycle when metadata log is periodically forced to be written to disk(in milliseconds). If force_mlog_period_in_ms = 0 it means force metadata log to be written to disk after each refreshment
TypeInt64
Default100
EffectiveAfter restarting system
  • tag_attribute_flush_interval
Nametag_attribute_flush_interval
Descriptioninterval num for tag and attribute records when force flushing to disk. When a certain amount of tag and attribute records is reached, they will be force flushed to disk. It is possible to lose at most tag_attribute_flush_interval records
Typeint32
Default1000
EffectiveOnly allowed to be modified in first start up
  • tag_attribute_total_size
Nametag_attribute_total_size
DescriptionThe maximum persistence size of tags and attributes of each time series.
Typeint32
Default700
EffectiveOnly allowed to be modified in first start up
  • schema_region_device_node_cache_size
Nameschema_region_device_node_cache_size
DescriptionThe max num of device node, used for speeding up device query, cached in schemaRegion.
TypeInt32
Default10000
EffectiveAfter restarting system
  • max_measurement_num_of_internal_request
Namemax_measurement_num_of_internal_request
DescriptionWhen there's too many measurements in one create timeseries plan, the plan will be split to several sub plan, with measurement num no more than this param.
TypeInt32
Default10000
EffectiveAfter restarting system

Configurations for creating schema automatically

  • enable_auto_create_schema
Nameenable_auto_create_schema
Descriptionwhether auto create the time series when a non-existed time series data comes
Typetrue or false
Defaulttrue
EffectiveAfter restarting system
  • default_storage_group_level
Namedefault_storage_group_level
DescriptionDatabase level when creating schema automatically is enabled. For example, if we receives a data point from root.sg0.d1.s2, we will set root.sg0 as the database if database level is 1. (root is level 0)
Typeinteger
Default1
EffectiveAfter restarting system
  • boolean_string_infer_type
Nameboolean_string_infer_type
DescriptionTo which type the values "true" and "false" should be reslved
TypeBOOLEAN or TEXT
DefaultBOOLEAN
EffectiveAfter restarting system
  • integer_string_infer_type
Nameinteger_string_infer_type
DescriptionTo which type an integer string like "67" in a query should be resolved
TypeINT32, INT64, DOUBLE, FLOAT or TEXT
DefaultDOUBLE
EffectiveAfter restarting system
  • floating_string_infer_type
Namefloating_string_infer_type
DescriptionTo which type a floating number string like "6.7" in a query should be resolved
TypeDOUBLE, FLOAT or TEXT
DefaultFLOAT
EffectiveAfter restarting system
  • nan_string_infer_type
Namenan_string_infer_type
DescriptionTo which type the value NaN in a query should be resolved
TypeDOUBLE, FLOAT or TEXT
DefaultFLOAT
EffectiveAfter restarting system

Query Configurations

  • read_consistency_level
Namempp_data_exchange_core_pool_size
DescriptionThe read consistency level,
1. strong(Default, read from the leader replica)
2. weak(Read from a random replica)
Typestring
Defaultstrong
EffectiveAfter restarting system
  • meta_data_cache_enable
Namemeta_data_cache_enable
DescriptionWhether to cache meta data(BloomFilter, ChunkMetadata and TimeSeriesMetadata) or not.
TypeBoolean
Defaulttrue
EffectiveAfter restarting system
  • chunk_timeseriesmeta_free_memory_proportion
Namechunk_timeseriesmeta_free_memory_proportion
DescriptionRead memory Allocation Ratio: BloomFilterCache : ChunkCache : TimeSeriesMetadataCache : Coordinator : Operators : DataExchange : timeIndex in TsFileResourceList : others.
Default1 : 100 : 200 : 300 : 400
EffectiveAfter restarting system
  • enable_last_cache
Nameenable_last_cache
DescriptionWhether to enable LAST cache.
TypeBoolean
Defaulttrue
EffectiveAfter restarting system
  • max_deduplicated_path_num
Namemax_deduplicated_path_num
Descriptionallowed max numbers of deduplicated path in one query.
TypeInt32
Default1000
EffectiveAfter restarting system
  • mpp_data_exchange_core_pool_size
Namempp_data_exchange_core_pool_size
DescriptionCore size of ThreadPool of MPP data exchange
Typeint32
Default10
EffectiveAfter restarting system
  • mpp_data_exchange_max_pool_size
Namempp_data_exchange_max_pool_size
DescriptionMax size of ThreadPool of MPP data exchange
Typeint32
Default10
EffectiveAfter restarting system
  • mpp_data_exchange_keep_alive_time_in_ms
Namempp_data_exchange_keep_alive_time_in_ms
DescriptionMax waiting time for MPP data exchange
Typelong
Default1000
EffectiveAfter restarting system
  • driver_task_execution_time_slice_in_ms
Namedriver_task_execution_time_slice_in_ms
DescriptionMaximum execution time of a DriverTask
Typeint32
Default100
EffectiveAfter restarting system
  • max_tsblock_size_in_bytes
Namemax_tsblock_size_in_bytes
DescriptionMaximum capacity of a TsBlock
Typeint32
Default1024 * 1024 (1 MB)
EffectiveAfter restarting system
  • max_tsblock_line_numbers
Namemax_tsblock_line_numbers
DescriptionMaximum number of lines in a single TsBlock
Typeint32
Default1000
EffectiveAfter restarting system
  • slow_query_threshold
Nameslow_query_threshold
DescriptionTime cost(ms) threshold for slow query.
TypeInt32
Default5000
EffectiveTrigger
  • query_timeout_threshold
Namequery_timeout_threshold
DescriptionThe max executing time of query. unit: ms
TypeInt32
Default60000
EffectiveAfter restarting system
  • max_allowed_concurrent_queries
Namemax_allowed_concurrent_queries
DescriptionThe maximum allowed concurrently executing queries.
TypeInt32
Default1000
EffectiveAfter restarting system
  • query_thread_count
Namequery_thread_count
DescriptionHow many threads can concurrently execute query statement. When <= 0, use CPU core number.
TypeInt32
DefaultCPU core number
EffectiveAfter restarting system
  • batch_size
Namebatch_size
DescriptionThe amount of data iterate each time in server (the number of data strips, that is, the number of different timestamps.)
TypeInt32
Default100000
EffectiveAfter restarting system

Storage Engine Configuration

  • timestamp_precision
Nametimestamp_precision
Descriptiontimestamp precision,support ms、us、ns
TypeString
Defaultms
EffectiveOnly allowed to be modified in first start up
  • default_ttl_in_ms
Namedefault_ttl_in_ms
DescriptionDefault ttl when each database created
TypeLong
DefaultInfinity
EffectiveAfter restarting system
  • max_waiting_time_when_insert_blocked
Namemax_waiting_time_when_insert_blocked
DescriptionWhen the waiting time(in ms) of an inserting exceeds this, throw an exception
TypeInt32
Default10000
EffectiveAfter restarting system
  • enable_discard_out_of_order_data
Nameenable_discard_out_of_order_data
Descriptionwhether to discard out of order data
TypeBoolean
Defaultfalse
EffectiveAfter restarting system
  • handle_system_error
Namehandle_system_error
DescriptionWhat will the system do when unrecoverable error occurs
TypeString
DefaultCHANGE_TO_READ_ONLY
EffectiveAfter restarting system
  • memtable_size_threshold
Namememtable_size_threshold
Descriptionmax memtable size
TypeLong
Default1073741824
Effectivewhen enable_mem_control is false & After restarting system
  • write_memory_variation_report_proportion
Namewrite_memory_variation_report_proportion
Descriptionif memory cost of data region increased more than proportion of allocated memory for write, report to system
TypeDouble
Default0.001
EffectiveAfter restarting system
  • enable_timed_flush_seq_memtable
Nameenable_timed_flush_seq_memtable
Descriptionwhether to enable timed flush sequence memtable
TypeBoolean
Defaulttrue
Effectivehot-load
  • seq_memtable_flush_interval_in_ms
Nameseq_memtable_flush_interval_in_ms
Descriptionif a memTable's created time is older than current time minus this, the memtable will be flushed to disk
Typeint32
Default10800000
Effectivehot-load
  • seq_memtable_flush_check_interval_in_ms
Nameseq_memtable_flush_check_interval_in_ms
Descriptionthe interval to check whether sequence memtables need flushing
Typeint32
Default600000
Effectivehot-load
  • enable_timed_flush_unseq_memtable
Nameenable_timed_flush_unseq_memtable
Descriptionwhether to enable timed flush unsequence memtable
TypeBoolean
Defaultfalse
Effectivehot-load
  • unseq_memtable_flush_interval_in_ms
Nameunseq_memtable_flush_interval_in_ms
Descriptionif a memTable's created time is older than current time minus this, the memtable will be flushed to disk
Typeint32
Default10800000
Effectivehot-load
  • unseq_memtable_flush_check_interval_in_ms
Nameunseq_memtable_flush_check_interval_in_ms
Descriptionthe interval to check whether unsequence memtables need flushing
Typeint32
Default600000
Effectivehot-load
  • tvlist_sort_algorithm
Nametvlist_sort_algorithm
Descriptionthe sort algorithm used in the memtable's TVList
TypeString
DefaultTIM
EffectiveAfter restarting system
  • avg_series_point_number_threshold
Nameavg_series_point_number_threshold
Descriptionmax average number of point of each series in memtable
Typeint32
Default100000
EffectiveAfter restarting system
  • flush_thread_count
Nameflush_thread_count
DescriptionThe thread number used to perform the operation when IoTDB writes data in memory to disk. If the value is less than or equal to 0, then the number of CPU cores installed on the machine is used. The default is 0.
Typeint32
Default0
EffectiveAfter restarting system
  • enable_partial_insert
Nameenable_partial_insert
DescriptionWhether continue to write other measurements if some measurements are failed in one insertion.
TypeBoolean
Defaulttrue
EffectiveAfter restarting system
  • recovery_log_interval_in_ms
Namerecovery_log_interval_in_ms
Descriptionthe interval to log recover progress of each region when starting iotdb
TypeInt32
Default5000
EffectiveAfter restarting system
  • 0.13_data_insert_adapt
Name0.13_data_insert_adapt
Descriptionif using v0.13 client to insert data, set this configuration to true.
TypeBoolean
Defaultfalse
EffectiveAfter restarting system
  • upgrade_thread_count
Nameupgrade_thread_count
DescriptionWhen there exists old version(v2) TsFile, how many thread will be set up to perform upgrade tasks
TypeInt32
Default1
EffectiveAfter restarting system
  • device_path_cache_size
Namedevice_path_cache_size
DescriptionThe max size of the device path cache. This cache is for avoiding initialize duplicated device id object in write process
TypeInt32
Default500000
EffectiveAfter restarting system
  • insert_multi_tablet_enable_multithreading_column_threshold
Nameinsert_multi_tablet_enable_multithreading_column_threshold
DescriptionWhen the insert plan column count reaches the specified threshold, multi-threading is enabled.
Typeint32
Default10
EffectiveAfter restarting system

Compaction Configurations

  • enable_seq_space_compaction
Nameenable_seq_space_compaction
Descriptionenable the compaction between sequence files
TypeBoolean
Defaulttrue
EffectiveAfter restart system
  • enable_unseq_space_compaction
Nameenable_unseq_space_compaction
Descriptionenable the compaction between unsequence files
TypeBoolean
Defaultfalse
EffectiveAfter restart system
  • enable_cross_space_compaction
Nameenable_cross_space_compaction
Descriptionenable the compaction between sequence files and unsequence files
TypeBoolean
Defaulttrue
EffectiveAfter restart system
  • cross_selector
Namecross_selector
Descriptionthe task selector type of cross space compaction
TypeString
Defaultrewrite
EffectiveAfter restart system
  • cross_performer
Namecross_performer
Descriptionthe task performer type of cross space compaction. The options are read_point and fast, read_point is the default and fast is still under test
TypeString
Defaultread_point
EffectiveAfter restart system
  • inner_seq_selector
Nameinner_seq_selector
Descriptionthe task selector type of inner sequence space compaction
TypeString
Defaultsize_tiered
EffectiveAfter restart system
  • inner_seq_performer
Nameinner_seq_peformer
Descriptionthe task performer type of inner sequence space compaction. The options are read_chunk and fast, read_chunk is the default and fast is still under test
TypeString
Defaultread_chunk
EffectiveAfter restart system
  • inner_unseq_selector
Nameinner_unseq_selector
Descriptionthe task selector type of inner unsequence space compaction
TypeString
Defaultsize_tiered
EffectiveAfter restart system
  • inner_unseq_performer
Nameinner_unseq_peformer
Descriptionthe task performer type of inner unsequence space compaction. The options are read_point and fast, read_point is the default and fast is still under test
TypeString
Defaultread_point
EffectiveAfter restart system
  • compaction_priority
Namecompaction_priority
DescriptionPriority of compaction task. When it is BALANCE, system executes all types of compaction equally; when it is INNER_CROSS, system takes precedence over executing inner space compaction task; when it is CROSS_INNER, system takes precedence over executing cross space compaction task
TypeString
DefaultBALANCE
EffectiveAfter restart system
  • target_compaction_file_size
Nametarget_compaction_file_size
DescriptionThe target file size in compaction
TypeInt64
Default2147483648
EffectiveAfter restart system
  • target_chunk_size
Nametarget_chunk_size
DescriptionThe target size of compacted chunk
TypeInt64
Default1048576
EffectiveAfter restart system
  • target_chunk_point_num
Nametarget_chunk_point_num
DescriptionThe target point number of compacted chunk
Typeint32
Default100000
EffectiveAfter restart system
  • chunk_size_lower_bound_in_compaction
Namechunk_size_lower_bound_in_compaction
DescriptionA source chunk will be deserialized in compaction when its size is less than this value
TypeInt64
Default10240
EffectiveAfter restart system
  • chunk_point_num_lower_bound_in_compaction
Namechunk_point_num_lower_bound_in_compaction
DescriptionA source chunk will be deserialized in compaction when its point num is less than this value
Typeint32
Default1000
EffectiveAfter restart system
  • max_inner_compaction_candidate_file_num
Namemax_inner_compaction_candidate_file_num
DescriptionThe max num of files encounter in inner space compaction
Typeint32
Default30
EffectiveAfter restart system
  • max_cross_compaction_file_num
Namemax_cross_compaction_candidate_file_num
DescriptionThe max num of files encounter in cross space compaction
Typeint32
Default1000
EffectiveAfter restart system
  • max_cross_compaction_file_size
Namemax_cross_compaction_candidate_file_size
DescriptionThe max size of files encounter in cross space compaction
TypeInt64
Default5368709120
EffectiveAfter restart system
  • cross_compaction_file_selection_time_budget
Namecross_compaction_file_selection_time_budget
DescriptionTime budget for cross space compaction file selection
Typeint32
Default30000
EffectiveAfter restart system
  • compaction_thread_count
Namecompaction_thread_count
Descriptionthread num to execute compaction
Typeint32
Default10
EffectiveAfter restart system
  • compaction_schedule_interval_in_ms
Namecompaction_schedule_interval_in_ms
Descriptioninterval of scheduling compaction
TypeInt64
Default60000
EffectiveAfter restart system
  • compaction_submission_interval_in_ms
Namecompaction_submission_interval_in_ms
Descriptioninterval of submitting compaction task
TypeInt64
Default60000
EffectiveAfter restart system
  • compaction_write_throughput_mb_per_sec
Namecompaction_write_throughput_mb_per_sec
DescriptionThe write rate of all compaction tasks in MB/s
Typeint32
Default16
EffectiveAfter restart system
  • sub_compaction_thread_count
Namesub_compaction_thread_count
Descriptionthe number of sub-compaction threads to accelerate cross space compaction
TypeInt32
Default4
EffectiveAfter restart system
  • enable_compaction_validation
Nameenable_compaction_validation
DescriptionEnable the check of sequence tsfile time range after compaction
TypeBoolean
Defaulttrue
EffectiveAfter restart system
  • candidate_compaction_task_queue_size
Namecandidate_compaction_task_queue_size
DescriptionThe size of candidate compaction task queue
TypeInt32
Default50
EffectiveAfter restart system

Write Ahead Log Configuration

  • wal_mode
Namewal_mode
DescriptionThe write mode of wal. For DISABLE mode, the system will disable wal. For SYNC mode, the system will submit wal synchronously, write request will not return until its wal is fsynced to the disk successfully. For ASYNC mode, the system will submit wal asynchronously, write request will return immediately no matter its wal is fsynced to the disk successfully.
TypeString
DefaultASYNC
EffectiveAfter restart system
  • max_wal_nodes_num
Namemax_wal_nodes_num
DescriptionMax number of wal nodes, each node corresponds to one wal directory. The default value 0 means the number is determined by the system.
Typeint32
Default0
EffectiveAfter restart system
  • wal_async_mode_fsync_delay_in_ms
Namewal_async_mode_fsync_delay_in_ms
DescriptionDuration a wal flush operation will wait before calling fsync in the async mode
Typeint32
Default1000
Effectivehot-load
  • wal_sync_mode_fsync_delay_in_ms
Namewal_sync_mode_fsync_delay_in_ms
DescriptionDuration a wal flush operation will wait before calling fsync in the sync mode
Typeint32
Default3
Effectivehot-load
  • wal_buffer_size_in_byte
Namewal_buffer_size_in_byte
DescriptionBuffer size of each wal node
Typeint32
Default33554432
EffectiveAfter restart system
  • wal_buffer_queue_capacity
Namewal_buffer_queue_capacity
DescriptionBlocking queue capacity of each wal buffer
Typeint32
Default500
EffectiveAfter restart system
  • wal_file_size_threshold_in_byte
Namewal_file_size_threshold_in_byte
DescriptionSize threshold of each wal file
Typeint32
Default31457280
Effectivehot-load
  • wal_min_effective_info_ratio
Namewal_min_effective_info_ratio
DescriptionMinimum ratio of effective information in wal files
Typedouble
Default0.1
Effectivehot-load
  • wal_memtable_snapshot_threshold_in_byte
Namewal_memtable_snapshot_threshold_in_byte
DescriptionMemTable size threshold for triggering MemTable snapshot in wal
Typeint64
Default8388608
Effectivehot-load
  • max_wal_memtable_snapshot_num
Namemax_wal_memtable_snapshot_num
DescriptionMemTable's max snapshot number in wal
Typeint32
Default1
Effectivehot-load
  • delete_wal_files_period_in_ms
Namedelete_wal_files_period_in_ms
DescriptionThe period when outdated wal files are periodically deleted
Typeint64
Default20000
Effectivehot-load

TsFile Configurations

  • group_size_in_byte
Namegroup_size_in_byte
DescriptionThe data size written to the disk per time
Typeint32
Default134217728
Effectivehot-load
  • page_size_in_byte
Namepage_size_in_byte
DescriptionThe maximum size of a single page written in memory when each column in memory is written (in bytes)
Typeint32
Default65536
Effectivehot-load
  • max_number_of_points_in_page
Namemax_number_of_points_in_page
DescriptionThe maximum number of data points (timestamps - valued groups) contained in a page
Typeint32
Default10000
Effectivehot-load
  • pattern_matching_threshold
Namepattern_matching_threshold
DescriptionMax matching time of regex pattern
Typeint32
Default1000000
Effectivehot-load
  • max_degree_of_index_node
Namemax_degree_of_index_node
DescriptionThe maximum degree of the metadata index tree (that is, the max number of each node's children)
Typeint32
Default256
EffectiveOnly allowed to be modified in first start up
  • max_string_length
Namemax_string_length
DescriptionThe maximum length of a single string (number of character)
Typeint32
Default128
Effectivehot-load
  • time_encoder
Nametime_encoder
DescriptionEncoding type of time column
TypeEnum String: “TS_2DIFF”,“PLAIN”,“RLE”
DefaultTS_2DIFF
Effectivehot-load
  • value_encoder
Namevalue_encoder
DescriptionEncoding type of value column
TypeEnum String: “TS_2DIFF”,“PLAIN”,“RLE”
DefaultPLAIN
Effectivehot-load
  • float_precision
Namefloat_precision
DescriptionThe precision of the floating point number.(The number of digits after the decimal point)
Typeint32
DefaultThe default is 2 digits. Note: The 32-bit floating point number has a decimal precision of 7 bits, and the 64-bit floating point number has a decimal precision of 15 bits. If the setting is out of the range, it will have no practical significance.
Effectivehot-load
  • compressor
Namecompressor
DescriptionData compression method
TypeEnum String : “UNCOMPRESSED”, “SNAPPY”, "LZ4", "ZSTD"
DefaultSNAPPY
Effectivehot-load
  • bloomFilterErrorRate
NamebloomFilterErrorRate
DescriptionThe false positive rate of bloom filter in each TsFile. Bloom filter checks whether a given time series is in the tsfile before loading metadata. This can improve the performance of loading metadata and skip the tsfile that doesn't contain specified time series. If you want to learn more about its mechanism, you can refer to: wiki page of bloom filteropen in new window.
Typefloat, (0, 1)
Default0.05
EffectiveAfter restarting system
  • freq_snr
Namefreq_snr
DescriptionSignal-noise-ratio (SNR) of lossy FREQ encoding
TypeDouble
Default40.0
Effectivehot-load
  • freq_block_size
Namefreq_block_size
DescriptionBlock size of FREQ encoding. In other words, the number of data points in a time-frequency transformation. To speed up the encoding, it is recommended to be the power of 2.
Typeint32
Default1024
Effectivehot-load

Authorization Configuration

  • authorizer_provider_class
Nameauthorizer_provider_class
Descriptionthe class name of the authorization service
TypeString
Defaultorg.apache.iotdb.commons.auth.authorizer.LocalFileAuthorizer
EffectiveAfter restarting system
Other available valuesorg.apache.iotdb.commons.auth.authorizer.OpenIdAuthorizer
  • openID_url
NameopenID_url
Descriptionthe openID server if OpenIdAuthorizer is enabled
TypeString (a http url)
Defaultno
EffectiveAfter restarting system
  • admin_name
Nameadmin_name
DescriptionThe username of admin
TypeString
Defaultroot
EffectiveOnly allowed to be modified in first start up
  • admin_password
Nameadmin_password
DescriptionThe password of admin
TypeString
Defaultroot
EffectiveOnly allowed to be modified in first start up
  • iotdb_server_encrypt_decrypt_provider
Nameiotdb_server_encrypt_decrypt_provider
DescriptionThe Class for user password encryption
TypeString
Defaultorg.apache.iotdb.commons.security.encrypt.MessageDigestEncrypt
EffectiveOnly allowed to be modified in first start up
  • iotdb_server_encrypt_decrypt_provider_parameter
Nameiotdb_server_encrypt_decrypt_provider_parameter
DescriptionParameters used to initialize the user password encryption class
TypeString
Default
EffectiveAfter restarting system
  • author_cache_size
Nameauthor_cache_size
DescriptionCache size of user and role
Typeint32
Default1000
EffectiveAfter restarting system
  • author_cache_expire_time
Nameauthor_cache_expire_time
DescriptionCache expire time of user and role, Unit: minutes
Typeint32
Default30
EffectiveAfter restarting system

UDF Configuration

  • udf_initial_byte_array_length_for_memory_control
Nameudf_initial_byte_array_length_for_memory_control
DescriptionUsed 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 texts.
Typeint32
Default48
EffectiveAfter restarting system
  • udf_memory_budget_in_mb
Nameudf_memory_budget_in_mb
DescriptionHow much memory may be used in ONE UDF query (in MB). The upper limit is 20% of allocated memory for read.
TypeFloat
Default30.0
EffectiveAfter restarting system
  • udf_reader_transformer_collector_memory_proportion
Nameudf_reader_transformer_collector_memory_proportion
DescriptionUDF memory allocation ratio for reader, transformer and collector. The parameter form is a : b : c, where a, b, and c are integers.
TypeString
Default1:1:1
EffectiveAfter restarting system
  • udf_root_dir
Nameudf_root_dir
DescriptionRoot directory of UDF
TypeString
Defaultext/udf(Windows:ext\udf)
EffectiveAfter restarting system
  • udf_lib_dir
Nameudf_lib_dir
DescriptionUDF log and jar file dir
TypeString
Defaultext/udf(Windows:ext\udf)
EffectiveAfter restarting system

Trigger Configuration

  • trigger_lib_dir
Nametrigger_lib_dir
DescriptionTrigger JAR file dir
TypeString
Defaultext/trigger
EffectiveAfter restarting system
  • stateful_trigger_retry_num_when_not_found
Namestateful_trigger_retry_num_when_not_found
DescriptionHow many times we will retry to found an instance of stateful trigger on DataNodes
TypeInt32
Default3
EffectiveAfter restarting system

SELECT-INTO

  • into_operation_buffer_size_in_byte
Nameinto_operation_buffer_size_in_byte
DescriptionWhen the select-into statement is executed, the maximum memory occupied by the data to be written (unit: Byte)
Typeint64
Default100MB
Effectivehot-load
  • select_into_insert_tablet_plan_row_limit
Nameselect_into_insert_tablet_plan_row_limit
DescriptionThe maximum number of rows that can be processed in insert-tablet-plan when executing select-into statements. When <= 0, use 10000.
Typeint32
Default10000
Effectivehot-load
  • into_operation_execution_thread_count
Nameinto_operation_execution_thread_count
DescriptionThe number of threads in the thread pool that execute insert-tablet tasks
Typeint32
Default2
EffectiveAfter restarting system

Continuous Query

  • continuous_query_execution_thread
Namecontinuous_query_execution_thread
DescriptionHow many threads will be set up to perform continuous queries
Typeint32
Defaultmax(1, the / 2)
EffectiveAfter restarting system
  • continuous_query_min_every_interval
Namecontinuous_query_min_every_interval
DescriptionMinimum every interval to perform continuous query.
Typeduration
Default1s
EffectiveAfter restarting system

PIPE Configuration

  • ip_white_list
Nameip_white_list
DescriptionSet the white list of IP addresses of the sender of the synchronization, which is expressed in the form of network segments, and multiple network segments are separated by commas. When the sender synchronizes data to the receiver, the receiver allows synchronization only when the IP address of the sender is within the network segment set in the white list. If the whitelist is empty, the receiver does not allow any sender to synchronize data. By default, the receiver rejects the synchronization request of all IP addresses except 127.0.0.1. When configuring this parameter, please ensure that all DataNode addresses on the sender are set.
TypeString
Default127.0.0.1/32
Effectivehot-load
  • max_number_of_sync_file_retry
Namemax_number_of_sync_file_retry
DescriptionThe maximum number of retries when the sender fails to synchronize files to the receiver.
Typeint32
Default5
Effectivehot-load

IOTConsensus Configuration

  • data_region_iot_max_log_entries_num_per_batch
Namedata_region_iot_max_log_entries_num_per_batch
DescriptionThe maximum log entries num in IoTConsensus Batch
Typeint32
Default1024
EffectiveAfter restarting system
  • data_region_iot_max_size_per_batch
Namedata_region_iot_max_size_per_batch
DescriptionThe maximum size in IoTConsensus Batch
Typeint32
Default16MB
EffectiveAfter restarting system
  • data_region_iot_max_pending_batches_num
Namedata_region_iot_max_pending_batches_num
DescriptionThe maximum pending batches num in IoTConsensus
Typeint32
Default12
EffectiveAfter restarting system
  • data_region_iot_max_memory_ratio_for_queue
Namedata_region_iot_max_memory_ratio_for_queue
DescriptionThe maximum memory ratio for queue in IoTConsensus
Typedouble
Default0.6
EffectiveAfter restarting system

RatisConsensus Configuration

  • config_node_ratis_log_appender_buffer_size_max
Nameconfig_node_ratis_log_appender_buffer_size_max
Descriptionconfignode max payload size for a single log-sync-RPC from leader to follower
Typeint32
Default4MB
EffectiveAfter restarting system
  • schema_region_ratis_log_appender_buffer_size_max
Nameschema_region_ratis_log_appender_buffer_size_max
Descriptionschema region max payload size for a single log-sync-RPC from leader to follower
Typeint32
Default4MB
EffectiveAfter restarting system
  • data_region_ratis_log_appender_buffer_size_max
Namedata_region_ratis_log_appender_buffer_size_max
Descriptiondata region max payload size for a single log-sync-RPC from leader to follower
Typeint32
Default4MB
EffectiveAfter restarting system
  • config_node_ratis_snapshot_trigger_threshold
Nameconfig_node_ratis_snapshot_trigger_threshold
Descriptionconfignode trigger a snapshot when snapshot_trigger_threshold logs are written
Typeint32
Default400,000
EffectiveAfter restarting system
  • schema_region_ratis_snapshot_trigger_threshold
Nameschema_region_ratis_snapshot_trigger_threshold
Descriptionschema region trigger a snapshot when snapshot_trigger_threshold logs are written
Typeint32
Default400,000
EffectiveAfter restarting system
  • data_region_ratis_snapshot_trigger_threshold
Namedata_region_ratis_snapshot_trigger_threshold
Descriptiondata region trigger a snapshot when snapshot_trigger_threshold logs are written
Typeint32
Default400,000
EffectiveAfter restarting system
  • config_node_ratis_log_unsafe_flush_enable
Nameconfig_node_ratis_log_unsafe_flush_enable
Descriptionconfignode allows flushing Raft Log asynchronously
Typeboolean
Defaultfalse
EffectiveAfter restarting system
  • schema_region_ratis_log_unsafe_flush_enable
Nameschema_region_ratis_log_unsafe_flush_enable
Descriptionschema region allows flushing Raft Log asynchronously
Typeboolean
Defaultfalse
EffectiveAfter restarting system
  • data_region_ratis_log_unsafe_flush_enable
Namedata_region_ratis_log_unsafe_flush_enable
Descriptiondata region allows flushing Raft Log asynchronously
Typeboolean
Defaultfalse
EffectiveAfter restarting system
  • config_node_ratis_log_segment_size_max_in_byte
Nameconfig_node_ratis_log_segment_size_max_in_byte
Descriptionconfignode max capacity of a single Log segment file
Typeint32
Default24MB
EffectiveAfter restarting system
  • schema_region_ratis_log_segment_size_max_in_byte
Nameschema_region_ratis_log_segment_size_max_in_byte
Descriptionschema region max capacity of a single Log segment file
Typeint32
Default24MB
EffectiveAfter restarting system
  • data_region_ratis_log_segment_size_max_in_byte
Namedata_region_ratis_log_segment_size_max_in_byte
Descriptiondata region max capacity of a single Log segment file
Typeint32
Default24MB
EffectiveAfter restarting system
  • config_node_ratis_grpc_flow_control_window
Nameconfig_node_ratis_grpc_flow_control_window
Descriptionconfignode flow control window for ratis grpc log appender
Typeint32
Default4MB
EffectiveAfter restarting system
  • schema_region_ratis_grpc_flow_control_window
Nameschema_region_ratis_grpc_flow_control_window
Descriptionschema region flow control window for ratis grpc log appender
Typeint32
Default4MB
EffectiveAfter restarting system
  • data_region_ratis_grpc_flow_control_window
Namedata_region_ratis_grpc_flow_control_window
Descriptiondata region flow control window for ratis grpc log appender
Typeint32
Default4MB
EffectiveAfter restarting system
  • data_region_ratis_grpc_leader_outstanding_appends_max
Namedata_region_ratis_grpc_leader_outstanding_appends_max
Descriptiondata region grpc pipeline concurrency threshold
Typeint32
Default128
EffectiveAfter restarting system
  • data_region_ratis_log_force_sync_num
Namedata_region_ratis_log_force_sync_num
Descriptiondata region fsync threshold
Typeint32
Default128
EffectiveAfter restarting system
  • config_node_ratis_rpc_leader_election_timeout_min_ms
Nameconfig_node_ratis_rpc_leader_election_timeout_min_ms
Descriptionconfignode min election timeout for leader election
Typeint32
Default2000ms
EffectiveAfter restarting system
  • schema_region_ratis_rpc_leader_election_timeout_min_ms
Nameschema_region_ratis_rpc_leader_election_timeout_min_ms
Descriptionschema region min election timeout for leader election
Typeint32
Default2000ms
EffectiveAfter restarting system
  • data_region_ratis_rpc_leader_election_timeout_min_ms
Namedata_region_ratis_rpc_leader_election_timeout_min_ms
Descriptiondata region min election timeout for leader election
Typeint32
Default2000ms
EffectiveAfter restarting system
  • config_node_ratis_rpc_leader_election_timeout_max_ms
Nameconfig_node_ratis_rpc_leader_election_timeout_max_ms
Descriptionconfignode max election timeout for leader election
Typeint32
Default2000ms
EffectiveAfter restarting system
  • schema_region_ratis_rpc_leader_election_timeout_max_ms
Nameschema_region_ratis_rpc_leader_election_timeout_max_ms
Descriptionschema region max election timeout for leader election
Typeint32
Default2000ms
EffectiveAfter restarting system
  • data_region_ratis_rpc_leader_election_timeout_max_ms
Namedata_region_ratis_rpc_leader_election_timeout_max_ms
Descriptiondata region max election timeout for leader election
Typeint32
Default2000ms
EffectiveAfter restarting system
  • config_node_ratis_request_timeout_ms
Nameconfig_node_ratis_request_timeout_ms
Descriptionconfignode ratis client retry threshold
Typeint32
Default10s
EffectiveAfter restarting system
  • schema_region_ratis_request_timeout_ms
Nameschema_region_ratis_request_timeout_ms
Descriptionschema region ratis client retry threshold
Typeint32
Default10s
EffectiveAfter restarting system
  • data_region_ratis_request_timeout_ms
Namedata_region_ratis_request_timeout_ms
Descriptiondata region ratis client retry threshold
Typeint32
Default10s
EffectiveAfter restarting system
  • config_node_ratis_max_retry_attempts
Nameconfig_node_ratis_max_retry_attempts
Descriptionconfignode ratis client max retry attempts
Typeint32
Default10
EffectiveAfter restarting system
  • config_node_ratis_initial_sleep_time_ms
Nameconfig_node_ratis_initial_sleep_time_ms
Descriptionconfignode ratis client retry initial sleep time
Typeint32
Default100ms
EffectiveAfter restarting system
  • config_node_ratis_max_sleep_time_ms
Nameconfig_node_ratis_max_sleep_time_ms
Descriptionconfignode ratis client retry max sleep time
Typeint32
Default10s
EffectiveAfter restarting system
  • schema_region_ratis_max_retry_attempts
Nameschema_region_ratis_max_retry_attempts
Descriptionschema region ratis client max retry attempts
Typeint32
Default10
EffectiveAfter restarting system
  • schema_region_ratis_initial_sleep_time_ms
Nameschema_region_ratis_initial_sleep_time_ms
Descriptionschema region ratis client retry initial sleep time
Typeint32
Default100ms
EffectiveAfter restarting system
  • schema_region_ratis_max_sleep_time_ms
Nameschema_region_ratis_max_sleep_time_ms
Descriptionschema region ratis client retry max sleep time
Typeint32
Default10s
EffectiveAfter restarting system
  • data_region_ratis_max_retry_attempts
Namedata_region_ratis_max_retry_attempts
Descriptiondata region ratis client max retry attempts
Typeint32
Default10
EffectiveAfter restarting system
  • data_region_ratis_initial_sleep_time_ms
Namedata_region_ratis_initial_sleep_time_ms
Descriptiondata region ratis client retry initial sleep time
Typeint32
Default100ms
EffectiveAfter restarting system
  • data_region_ratis_max_sleep_time_ms
Namedata_region_ratis_max_sleep_time_ms
Descriptiondata region ratis client retry max sleep time
Typeint32
Default10s
EffectiveAfter restarting system
  • config_node_ratis_preserve_logs_num_when_purge
Nameconfig_node_ratis_preserve_logs_num_when_purge
Descriptionconfignode preserves certain logs when take snapshot and purge
Typeint32
Default1000
EffectiveAfter restarting system
  • schema_region_ratis_preserve_logs_num_when_purge
Nameschema_region_ratis_preserve_logs_num_when_purge
Descriptionschema region preserves certain logs when take snapshot and purge
Typeint32
Default1000
EffectiveAfter restarting system
  • data_region_ratis_preserve_logs_num_when_purge
Namedata_region_ratis_preserve_logs_num_when_purge
Descriptiondata region preserves certain logs when take snapshot and purge
Typeint32
Default1000
EffectiveAfter restarting system

Procedure Configuration

  • procedure_core_worker_thread_count
Nameprocedure_core_worker_thread_count
DescriptionThe number of worker thread count
Typeint32
Default4
EffectiveAfter restarting system
  • procedure_completed_clean_interval
Nameprocedure_completed_clean_interval
DescriptionTime interval of completed procedure cleaner work in
Typeint32
Unitsecond
Default30
EffectiveAfter restarting system
  • procedure_completed_evict_ttl
Nameprocedure_completed_evict_ttl
DescriptionThe ttl of completed procedure
Typeint32
Unitsecond
Default800
EffectiveAfter restarting system

MQTT Broker Configuration

  • enable_mqtt_service
Nameenable_mqtt_service。
DescriptionWhether to enable the MQTT service
TypeBoolean
DefaultFalse
Effectivehot-load
  • mqtt_host
Namemqtt_host
DescriptionThe host to which the MQTT service is bound
TypeString
Default0.0.0.0
Effectivehot-load
  • mqtt_port
Namemqtt_port
DescriptionThe port to which the MQTT service is bound
Typeint32
Default1883
Effectivehot-load
  • mqtt_handler_pool_size
Namemqtt_handler_pool_size
DescriptionThe size of the handler pool used to process MQTT messages
Typeint32
Default1
Effectivehot-load
  • mqtt_payload_formatter
Namemqtt_payload_formatter
DescriptionMQTT message payload formatter
TypeString
DefaultJSON
Effectivehot-load
  • mqtt_max_message_size
Namemqtt_max_message_size
DescriptionMaximum length of MQTT message in bytes
Typeint32
Default1048576
Effectivehot-load

REST Service Configuration

  • enable_rest_service
Nameenable_rest_service
DescriptionWhether to enable the Rest service
TypeBoolean
Defaultfalse
EffectiveAfter restarting system
  • rest_service_port
Namerest_service_port
DescriptionThe Rest service listens to the port number
Typeint32
Default18080
EffectiveAfter restarting system
  • enable_swagger
Nameenable_swagger
DescriptionWhether to enable swagger to display rest interface information
TypeBoolean
Defaultfalse
EffectiveAfter restarting system
  • rest_query_default_row_size_limit
Namerest_query_default_row_size_limit
DescriptionThe maximum number of rows in a result set that can be returned by a query
Typeint32
Default10000
EffectiveAfter restarting system
  • cache_expire
Namecache_expire
DescriptionExpiration time for caching customer login information
Typeint32
Default28800
EffectiveAfter restarting system
  • cache_max_num
Namecache_max_num
DescriptionThe maximum number of users stored in the cache
Typeint32
Default100
EffectiveAfter restarting system
  • cache_init_num
Namecache_init_num
DescriptionInitial cache capacity
Typeint32
Default10
EffectiveAfter restarting system
  • enable_https
Namecache_init_num
DescriptionREST Service Specifies whether to enable SSL configuration
TypeBoolean
Defaultfalse
EffectiveAfter restarting system
  • key_store_path
Namekey_store_path
DescriptionkeyStore path (optional)
TypeString
Default""
EffectiveAfter restarting system
  • key_store_pwd
Namekey_store_pwd
DescriptionkeyStore Password (optional)
TypeString
Default""
EffectiveAfter restarting system
  • trust_store_path
Nametrust_store_path
DescriptionkeyStore Password (optional)
TypeString
Default""
EffectiveAfter restarting system
  • trust_store_pwd
Nametrust_store_pwd
DescriptiontrustStore Password (Optional)
TypeString
Default""
EffectiveAfter restarting system
  • idle_timeout
Nameidle_timeout
DescriptionSSL timeout duration, expressed in seconds
Typeint32
Default5000
EffectiveAfter restarting system

InfluxDB RPC Service Configuration

  • enable_influxdb_rpc_service
Nameenable_influxdb_rpc_service
DescriptionWhether to enable InfluxDB RPC service
TypeBoolean
Defaulttrue
EffectiveAfter restarting system
  • influxdb_rpc_port
Nameinfluxdb_rpc_port
DescriptionThe port used by InfluxDB RPC service
Typeint32
Default8086
EffectiveAfter restarting system

Copyright © 2024 The Apache Software Foundation.
Apache and the Apache feather logo are trademarks of The Apache Software Foundation

Have a question? Connect with us on QQ, WeChat, or Slack. Join the community now.