Flag Description Default Current value Experimental
catalog_max_lock_skipped_topic_updates (int32) Maximum number of topic updates skipped for a table due to lock contention in catalogd after which it mustbe added to the topic the update log. This limit only applies to distinct lock operations which block the topic update thread. 3 3 false
catalog_service_port (int32) port where the CatalogService is running 26000 26000 false
catalog_topic_mode (string) The type of data that the catalog service will publish into the Catalog StateStore topic. Valid values are 'full', 'mixed', or 'minimal'. In 'full' mode, complete catalog objects are published any time a new version is available. In 'minimal' mode, only a minimal object is published when a new version of a catalog object is available. In 'mixed' mode, both types of topic entries are published. When all impalad coordinators are configured with --use_local_catalog disabled (the default), 'full' mode should be used. If all impalad coordinators are configured with --use_local_catalog enabled, 'minimal' mode should be used. When some impalads are configured with --use_local_catalog disabled and others configured with it enabled, then 'mixed' mode is required. full full false
max_wait_time_for_sync_ddl_s (int32) Maximum time (in seconds) until which a sync ddl operation will wait for the updated tables to be the added to the catalog topic. A value of 0 means sync ddl operation will wait as long as necessary until the update is propogated to all the coordinators. This flag only takes effect when topic_update_tbl_max_wait_time_ms is enabled.A value greater than 0 means catalogd will wait until that number of seconds before throwing an error indicating that not all the coordinators might have applied the changes caused due to the ddl. 0 0 false
topic_update_tbl_max_wait_time_ms (int64) Maximum time (in milliseconds) catalog's topic update thread will wait to acquire lock on table. If the topic update thread cannot acquire a table lock it skips the table from that topic update and processes the table in the next update. However to prevent starvation it only skips the table catalog_max_lock_skipped_topic_updates many times. After that limit is hit, topic thread block until it acquires the table lock. A value of 0 disables the timeout based locking which means topic update thread will always block until table lock is acquired. 120000 120000 false
initial_hms_cnxn_timeout_s (int32) Number of seconds catalogd will wait to establish an initial connection to the HMS before exiting. 120 120 false
load_catalog_in_background (bool) If true, loads catalog metadata in the background. If false, metadata is loaded lazily (on access). false false false
max_hdfs_partitions_parallel_load (int32) (Advanced) Number of threads used to load block metadata for HDFS based partitioned tables. Due to HDFS architectural limitations, it is unlikely to get a linear speed up beyond 5 threads. 5 5 false
max_nonhdfs_partitions_parallel_load (int32) (Advanced) Number of threads used to load block metadata for tables that do not support the notion of blocks/storage IDs. Currently supported for S3/ADLS. 20 20 false
num_metadata_loading_threads (int32) (Advanced) The number of metadata loading threads (degree of parallelism) to use when loading catalog metadata. 16 16 false
asm_module_dir (string) if set, saves disassembly for generated IR modules to the specified directory. false
disable_optimization_passes (bool) if true, disables llvm optimization passes (used for testing) false false false
dump_ir (bool) if true, output IR after optimization passes false false false
opt_module_dir (string) if set, saves optimized generated IR modules to the specified directory. false
perf_map (bool) if true, generate /tmp/perf-<pid>.map file for linux perf symbols. This is not recommended for production use because it may affect performance. false false false
print_llvm_ir_instruction_count (bool) if true, prints the instruction counts of all JIT'd functions false false false
unopt_module_dir (string) if set, saves unoptimized generated IR modules to the specified directory. false
abort_on_config_error (bool) Abort Impala startup if there are improper configs or running on unsupported hardware. true true false
adapt_legacy_cdh (bool) If true, use legacy backend port as StatestoreSubscriber::subscriber_id, the JVM and CodeGen metrics not add in profile false false false
anonymous_user_name (string) Default username used when a client connects to an unsecured impala daemon and does not specify a username. anonymous anonymous false
auto_create_partition_in_load_data (bool) If true, auto create new partition in LOAD DATA false false false
auto_min_query_mem_limit (int32) The minimum memory value when auto adjust the query memory limit 524288000 524288000 false
be_port (int32) port on which thrift based ImpalaInternalService is exported 22000 22000 false
be_principal (string) Kerberos principal for backend network connections only,overriding --principal if set. Must not be set if --principal is not set. false
blacklisted_dbs (string) Comma separated list for blacklisted databases. Configure which databases to be skipped for loading (in startup and global INVALIDATE METADATA). Users can't access, create, or drop databases which are blacklisted. sys,information_schema sys,information_schema false
blacklisted_tables (string) Comma separated full names (in format: <db>.<table>) of blacklisted tables. Configure which tables to be skipped for loading (in startup and reseting metadata of the table). Users can't access, create, or drop tables which are blacklisted false
buffer_pool_clean_pages_limit (string) (Advanced) Limit on bytes of clean pages that will be accumulated in the buffer pool. Specified as number of bytes ('<int>[bB]?'), megabytes ('<float>[mM]'), gigabytes ('<float>[gG]'), or percentage of the buffer pool limit ('<int>%'). Defaults to bytes if no unit is given.. 10% 10% false
buffer_pool_limit (string) (Advanced) Limit on buffer pool size. Specified as number of bytes ('<int>[bB]?'), megabytes ('<float>[mM]'), gigabytes ('<float>[gG]'), or percentage of the process memory limit (minus the JVM heap if --mem_limit_includes_jvm is true) ('<int>%'). Defaults to bytes if no unit is given. The default value and behaviour of this flag may change between releases. 85% 85% false
compact_catalog_topic (bool) If true, catalog updates sent via the statestore are compacted before transmission. This saves network bandwidth at the cost of a small quantity of CPU time. Enable this option in cluster with large catalogs. It must be enabled on both the catalog service, and all Impala demons. true true false
compute_join_mode_by_history (bool) If true, compute the distribution mode for the given join based on the history. true true false
convert_s3a_to_obs (bool) If true, convert S3AFileSystem to OBSFileSystem. false false false
debug_actions (string) For testing only. Uses the same format as the debug action query options, but allows for injection of debug actions in code paths where query options are not available. false
desc_return_both_original_and_dict_columns (bool) If true, return both the original column and dimension dictionary column. false false false
desc_return_original_column_with_dict (bool) If true, return the original column with dimension dictionary. true true false
dimension_dict_file_max_size (int32) Maximum byte size of the dimension dictionary file, default is 100m 104857600 104857600 false
disable_kudu (bool) If true, Kudu features will be disabled. false false false
enable_admission_slots (bool) If true, check if there are enough available slots on all non-default executor groups in the schedule to fit the query schedule. false false false
enable_catalogd_ha (bool) Set to true to enable CatalogD HA false false false
enable_historical_optimize (bool) If true, use historical optimize false false false
enable_incremental_metadata_updates (bool) If true, Catalog Server will send incremental table updates in partition level in the statestore topic updates. Legacy coordinators will apply the partition updates incrementally, i.e. reuse unchanged partition metadata. Disable this feature by setting this to false in the Catalog Server. Then metadata of each table will be propagated as a whole object in the statestore topic updates. Note that legacy coordinators can apply incremental or full table updates so don't need this flag. true true false
enable_infinity_ranger (bool) If true, infinity ranger is enabled. false false false
enable_inherit_login_user_without_do_as (bool) If true, session inherit first login user without DO_AS_USER hint after the session has set DO_AS_USER, else throw an error false false false
enable_insert_events (bool) Enables insert events in the events processor. When this configuration is set to true Impala will generate INSERT event types which when received by other Impala clusters can be used to automatically refresh the tables or partitions. Event processing must be turned on for this flag to have any effect. true true false
enable_legacy_avx_support (bool) If true, Impala relaxes its x86_64 CPU feature requirement to allow running on machines with AVX but no AVX2. This allows running Impala on older machines without AVX2 support. This is a legacy mode that will be removed in a future release. false false false
enable_minidumps (bool) Whether to enable minidump generation upon process crash or SIGUSR1. true true false
enable_override_cardinality_by_rf (bool) Whether it is allowed to override the current cardinality with historical values containing runtime filter. true true false
enable_process_lifetime_heap_profiling (bool) (Advanced) Enables heap profiling for the lifetime of the process. Profile output will be stored in the directory specified by -heap_profile_dir. Enabling this option will disable the on-demand/remote server profile handlers. false false false
enable_statestored_ha (bool) statestored High Availability enabled false false false
enable_stats_extrapolation (bool) If true, uses table statistics computed with COMPUTE STATS to extrapolate the row counts of partitions. false false false
etcd_connect (string) Etcd connect false
etcd_rootpath (string) Etcd root path /sensors_analytics /sensors_analytics false
expr_children_limit (int32) Limits on the number of expr children of an expr tree, default is 50000 50000 50000 false
force_disable_user_trait_view_in_user_table (bool) When it is true, no matter how other flags and QE are configured, user_trait_view_pxx will not be spliced in sql false false false
ha_zookeeper_namespace (string) ZooKeeper namespace to support High Availability sensors_analytics/backpack/lumen sensors_analytics/backpack/lumen false
heap_profile_dir (string) Output directory to store heap profiles. If not set profiles are stored in the current working directory. false
historical_exec_time_size (int32) The number of the most recent execution time saved 7 7 false
historical_mem_ttl_s (int32) The time to live of the historical memory values 1209600 1209600 false
historical_rows_ttl_s (int32) The time to live of the historical row number values 604800 604800 false
historical_update_factor (double) If "abs(estimated_rows - actual_value) / (double)max(actual_value,estimated_rows) >= historical_update_factor", then update historical values in skv, default is 0.3 0.29999999999999999 0.29999999999999999 false
hms_event_polling_interval_s (int32) Configure catalogd to invalidate cached table metadata based on metastore events. These metastore events could be generated by external systems like Apache Hive or a different Impala cluster using the same Hive metastore server as this one. A non-zero value of this flag sets the polling interval of catalogd in seconds to fetch new metastore events. A value of zero disables this feature. When enabled, this flag has the same effect as "INVALIDATE METADATA" statement on the table for certain metastore event types. Additionally, in case of events which detect creation or removal of objects from metastore, catalogd adds or removes such objects from its cached metadata. This feature is independent of time and memory based automatic invalidation of tables. Note that this is still an experimental feature and not recommended to be deployed on production systems until it is made generally available. 0 0 false
hostname (string) Hostname to use for this daemon, also used as part of the Kerberos principal, if enabled. If not set, the system default will be used ngmmserver002 false
hyperion_home_port (string) Choice of zk or etcd to use, default is zk zookeeper zookeeper false
hyperion_meta_version (string) Hyperion meta version v2 v2 false
iceberg_reload_new_files_threshold (int32) (Advanced) If during a table refresh the number of new files are greater than this, catalogd will completely reload all file metadata. If number of new files are less or equal to this, catalogd will only load the metadata of the newly added files. 100 100 false
ignore_straight_join_hint (bool) If true, ignore STRAIGHT_JOIN hint. false false false
impala_slow_rpc_threshold_ms (int64) (Advanced) Threshold for considering Impala internal RPCs to be unusually slow. Slow RPCs trigger additional logging and other diagnostics. Lowering this value may result in false positivesThis overrides KRPC's --rpc_duration_too_long_ms setting. 120000 120000 false
inc_stats_size_limit_bytes (int64) Maximum size of incremental stats the catalog is allowed to serialize per table. This limit is set as a safety check, to prevent the JVM from hitting a maximum array limit of 1GB (or OOM) while building the thrift objects to send to impalads. By default, it's set to 200MB 209715200 209715200 false
invalidate_tables_on_memory_pressure (bool) Configure catalogd to invalidate recently unused tables when the old GC generation is almost full. This is independent from time-based invalidation configured by invalidate_table_timeout_s. To enable this feature, a true flag must be applied to both catalogd and impalad. false false false
invalidate_tables_timeout_s (int32) If a table has not been referenced in a SQL statement for more than the configured amount of time, the catalog server will automatically evict its cached metadata about this table. This has the same effect as a user-initiated "INVALIDATE METADATA" statement on the table. Configuring this to 0 disables time-based automatic invalidation of tables. This is independent from memory-based invalidation configured by invalidate_tables_on_memory_pressure. To enable this feature, a non-zero flag must be applied to both catalogd and impalad. 0 0 false
keytab_file (string) Absolute path to Kerberos keytab file false
krb5_ccname (string) Absolute path to the file based credentials cache that we pass to the KRB5CCNAME environment variable. /tmp/krb5cc_impala_internal /tmp/krb5cc_impala_internal false
krb5_conf (string) Absolute path to Kerberos krb5.conf if in a non-standard location. Does not normally need to be set. false
krb5_debug_file (string) Turn on Kerberos debugging and output to this file false
krpc_port (int32) port on which KRPC based ImpalaInternalService is exported 27000 27000 false
kudu_client_connection_negotiation_timeout_ms (int32) (Advanced) Timeout for connection negotiation between Kudu client and Kudu masters and tablet servers, in milliseconds 3000 3000 false
kudu_client_rpc_timeout_ms (int32) (Advanced) Timeout (milliseconds) set for individual Kudu client rpcs. An operation may consist of several rpcs, so this is expected to be less than kudu_operation_timeout_ms. This must be a positive value or it will be ignored and Kudu's default of 10s will be used. There is no way to disable timeouts. 0 0 false
kudu_max_cell_size_bytes (int32) The maximum size of any individual cell in a table. Attempting to store string or binary columns with a size greater than this will resultin errors. 256000 256000 false
kudu_operation_timeout_ms (int32) Timeout (milliseconds) set for all Kudu operations. This must be a positive value, and there is no way to disable timeouts. 180000 180000 false
list_iceberg_object_storage_path (bool) If true, list iceberg table's object storage_path false false false
load_auth_to_local_rules (bool) If true, load auth_to_local configuration from hdfs' core-site.xml. When enabled, impalad reads the rules from the property hadoop.security.auth_to_local and applies them to translate the Kerberos principal to its corresponding local user name for authorization. false false false
log_filename (string) Prefix of log filename - full path is <log_dir>/<log_filename>.[INFO|WARN|ERROR|FATAL] statestored false
log_query_to_avro_file (bool) if true, logs completed query profiles to hdfs avro table. true true false
log_query_to_avro_path (string) if set, use this path to store avro files false
max_log_files (int32) Maximum number of log files to retain per severity level. The most recent log files are retained. If set to 0, all log files are retained. 10 10 false
max_minidumps (int32) Maximum number of minidump files to keep per daemon. Older files are removed first. Set to 0 to keep all minidump files. 9 9 false
max_thrift_file_read_buffer_bytes (int64) max thrift file size in bytes which can be read from HDFS. 50331648 50331648 false
mem_limit (string) Limit on process memory consumption. Includes the JVM's memory consumption only if --mem_limit_includes_jvm is true. Specified as number of bytes ('<int>[bB]?'), megabytes ('<float>[mM]'), gigabytes ('<float>[gG]'), or percentage of the physical memory ('<int>%'). Defaults to bytes if no unit is given. 80% 80% false
mem_limit_includes_jvm (bool) If true, --mem_limit will include the JVM's max heap size and committed memory in the process memory limit. false false false
min_buffer_size (int64) (Advanced) The minimum buffer size to use in the buffer pool 8192 8192 false
min_privilege_set_for_show_stmts (string) Comma separated list of privileges. Any one of them is required to show a database or table. Defaults to "any" which means if the user has any privilege (CREATE, SELECT, INSERT, etc) on a database or table, the database/table is visible in the results of SHOW DATABASES/TABLES. If set to "select", only dbs/tables on which the user has SELECT privilege will be shown. If set to "select,insert", only dbs/tables on which the user has SELECT or INSERT privilege will be shown. In practice, this flag can be set to "select" or "select,insert" to improve performance of SHOW DATABASES/TABLES and GET_SCHEMAS/GET_TABLES, especially when using Sentry and having thousands of candidate dbs/tables to be checked with a user with large scale of privileges. No significant performance gain when using Ranger any any false
minidump_path (string) Directory to write minidump files to. This can be either an absolute path or a path relative to log_dir. Each daemon will create an additional sub-directory to prevent naming conflicts and to make it easier to identify a crashing daemon. Minidump files contain crash-related information in a compressed format and will be written when a daemon exits unexpectedly, for example on an unhandled exception or signal. It is also possible to create minidumps on demand without exiting the process by sending SIGUSR1. Set to empty to disable writing minidump files. minidumps /var/log/impala-minidumps/statestored false
minidump_size_limit_hint_kb (int32) Size limit hint for minidump files in KB. If a minidump exceeds this value, then breakpad will reduce the stack memory it collects for each thread from 8KB to 2KB. However it will always include the full stack memory for the first 20 threads, including the thread that crashed. 20480 20480 false
num_check_authorization_threads (int32) The number of threads used to check authorization for the user when executing show tables/databases. This configuration is applicable only when authorization is enabled. A value of 1 disables multi-threaded execution for checking authorization.However, a small value of larger than 1 may limit the parallism of FE requests when checking authorization with a high concurrency. The value must be in the range of 1 to 128. 1 1 false
principal (string) Kerberos principal. If set, both client and backend network connections will use Kerberos encryption and authentication and the daemon will acquire a Kerberos TGT (i.e. do the equivalent of the kinit command) and keep it refreshed for the lifetime of the daemon. If this is not set the TGT ticket will not be acquired and incoming connections will not be authenticated or encrypted using Kerberos. However, the TGT and other settings may be inherited from the environment and used by client libraries in certain cases. false
push_down_last_seen_time_filter (bool) If true, add last seen time filter to reduce right profile table. false false false
read_size (int32) (Advanced) The preferred I/O request size in bytes to issue to HDFS or the local filesystem. Increasing the read size will increase memory requirements. Decreasing the read size may decrease I/O throughput. 8388608 8388608 false
redaction_rules_file (string) Absolute path to sensitive data redaction rules. The rules will be applied to all log messages and query text shown in the Web UI and audit records. Query results will not be affected. Refer to the documentation for the rule file format. false
redirect_stdout_stderr (bool) If true, redirects stdout/stderr to INFO/ERROR log. true true false
reserved_words_version (string) Reserved words compatibility version. Reserved words cannot be used as identifiers in SQL. This flag determines the impala version from which the reserved word list is taken. The value must be one of ["2.11.0", "3.0.0"]. 3.0.0 3.0.0 false
sa_estimation_reset_factor (string) If estimation mem value multiply executors number grater than resource pool size, reset using resource pool size divide executors num and multiply this value 0.3 0.3 false
sa_hit_historical_reset_factor (string) If hit historical and estimation mem value multiply executors number grater than resource pool size, reset using resource pool size divide executors num and multiply this value 0.7 0.7 false
sa_parameter_codegen (bool) false false false
sa_query_timeout_s (int32) SA query timeout is used for resource estimates, default is 600 600 600 false
sa_zookeeper_connect (string) SA zookeeper connect false
sa_zookeeper_rootpath (string) SA zookeeper root path /sensors_analytics /sensors_analytics false
sdw_admin_user_list (string) Comma-separated list of usernames authorized to set DO_AS_USER. lumen_infinity,sa_cluster lumen_infinity,sa_cluster false
shaded_hive_site_path (string) hive-site.xml file path for shaded hive metastore false
skip_external_kerberos_auth (bool) (Advanced) skip kerberos authentication for incoming external connections to this daemon, e.g. clients connecting to the HS2 interface. Only has an effect if --principal is set, i.e. Kerberos is enabled. false false false
skip_internal_kerberos_auth (bool) (Advanced) skip kerberos authentication for incoming internal connections from other daemons within the Impala cluster (i.e. impalads, statestored, catalogd). Must be set to the same value across all daemons. Only has an effect if --principal is set, i.e. Kerberos is enabled. false false false
start_mv_rebuild_maintain_thread (bool) If true, start mv rebuild maintain thread in coordinator false false false
tcmalloc_max_total_thread_cache_bytes (int64) (Advanced) Bound on the total amount of bytes allocated to TCMalloc thread caches. If left at 0 (default), use the default value in TCMalloc library. 0 0 false
translate_enable_profile_left_join_tag (bool) Use left join mode true true false
translate_enable_user_trait_view_in_user_table (bool) Whether to use user_trait_view in Translation true true false
translate_infinity_sql_via_sa_web (bool) If true, translate sql via sa web false false false
translate_meta_session_property_deep_copy_method (string) The deep copy method for the session property in translation metadata can be selected from default or beanutil, with the beanutil being faster. 'default' means using SerializationUtils.clone, stable but slow default default false
translate_meta_session_property_generation_method (string) The generation method of the session property in translation metadata can be selected from default or calc, with the calc being faster. 'default' means using a method of traversing all property for calculation, stable but slow default default false
translate_sql_table_delimiter (string) When sql is translated, the special table in sql will be converted into a placeholder to facilitate subsequent replacement. The placeholder is composed of the table name and the project name, and the separator is used to separate different parts of the placeholder ### ### false
translate_sql_via_sa_timeout_ms (int32) The timeout for translate sql via sa web 10000 10000 false
unlock_zorder_sort (bool) If true, enables using ZORDER option for SORT BY. true true false
use_builtin_exts_function (bool) If true, use built-in extension functions true true false
use_dict_condition_rewrite (bool) If true, use dict condition rewrite true true false
use_mem_est (bool) If true, use the estimated memory if it's smaller than the query option MEM_LIMIT. true true false
use_resolved_hostname (bool) If true, --hostname is resolved before use, so that the IP address will be used everywhere instead of the hostname. false false false
local_library_dir (string) Scratch space for local fs operations. Currently used for copying UDF binaries locally from HDFS and also for initializing the timezone db /tmp /tmp false
memory_maintenance_sleep_time_ms (int32) Sleep time in milliseconds between memory maintenance iterations 10000 10000 false
pause_monitor_sleep_time_ms (int64) Sleep time in milliseconds for pause monitor thread. 500 500 false
pause_monitor_warn_threshold_ms (int64) If the pause monitor sleeps more than this time period, a warning is logged. If set to 0 or less, pause monitor is disabled. 10000 10000 false
data_source_batch_size (int32) Batch size for calls to GetNext() on external data sources. 1024 1024 false
exchg_node_buffer_size_bytes (int64) (Advanced) Maximum size of per-query receive-side buffer 10485760 10485760 false
enable_quadratic_probing (bool) Enable quadratic probing hash table true true false
enable_orc_scanner (bool) If false, reading from ORC format tables is not supported true true false
enabled_hdfs_text_scanner_plugins (string) (Advanced) whitelist of HDFS text scanner plugins that Impala will try to dynamically load. Must be a comma-separated list of upper-case compression codec names. Each plugin implements support for decompression and hands off the decompressed bytes to Impala's builtin text parser for further processing (e.g. parsing delimited text). false
always_use_data_cache (bool) (Advanced) Always uses the IO data cache for all reads, regardless of whether the read is local or remote. By default, the IO data cache is only used if the data is expected to be remote. Used by tests. false false false
max_row_batches (int32) the maximum number of batches to queue in multithreaded HDFS scans 0 0 false
min_filter_reject_ratio (double) (Advanced) If the percentage of rows rejected by a runtime filter drops below this value, the filter is disabled. 0.10000000000000001 0.10000000000000001 false
kudu_max_row_batches (int32) The maximum size of the row batch queue, for Kudu scanners. 0 0 false
kudu_read_mode (string) (Advanced) Sets the Kudu scan ReadMode. Supported Kudu read modes are READ_LATEST and READ_AT_SNAPSHOT. Can be overridden with the query option of the same name. READ_LATEST READ_LATEST false
kudu_scanner_keep_alive_period_sec (int32) The period at which Kudu Scanners should send keep-alive requests to the tablet server to ensure that scanners do not time out. 15 15 false
pick_only_leaders_for_tests (bool) Whether to pick only leader replicas, for tests purposes only. false false false
kudu_error_buffer_size (int32) The size (bytes) of the Kudu client buffer for returning errors, with a min of 1KB.If the actual errors exceed this size the query will fail. 10485760 10485760 false
kudu_mutation_buffer_size (int32) The size (bytes) of the Kudu client buffer for mutations. 10485760 10485760 false
kudu_client_num_reactor_threads (int32) Number of threads the Kudu client can use to send rpcs to Kudu. Must be > 0. 4 4 false
kudu_client_v (int32) If >= 0, used to set the verbose logging level on the Kudu client instead of using the value of -v -1 -1 false
live_agg_mode_check_scan_progress_interval_time_sec (int32) check scan progress interval time in seconds in live agg mode 2 2 false
use_fast_timezone_conversion (bool) Fast timezone conversion, directly applying timezone offset on millisecond timestamps, without considering daylight saving time. true true false
max_page_header_size (int32) max parquet page header size in bytes 8388608 8388608 false
cache_bloomfilter (bool) cache index bloomfilter false false false
index_cache_mem_limit (int32) index cache mem limit (GB), -1 means no limit -1 -1 false
max_scan_merge_memory (int32) the maximum memory(MB) used for sa merge scan 1024 1024 false
max_user_events_in_merge_mode (int32) the maximum events per user in merge mode 102400 102400 false
max_files_per_node_in_shuffle_merge_mode (int32) the maximum files per node in SHUFFLE_MERGE mode 1000 1000 false
max_scan_thread_in_shuffle_merge_mode (int32) the maximum scan threads in SHUFFLE_MERGE mode 10 10 false
num_sampling_group (int32) num_sampling_group 64 64 false
max_queued_row_batch_bytes (int64) (Advanced) the maximum bytes of queued rows per multithreaded scan node. 16777216 16777216 false
runtime_filter_wait_time_ms (int32) (Advanced) the maximum time, in ms, that a scan node will wait for expected runtime filters to arrive. 1000 1000 false
partitioned_topn_in_mem_partitions_limit (int32) (Experimental) Soft limit on the number of in-memory partitions in an instance of the partitioned top-n operator. 1000 1000 false
partitioned_topn_soft_limit_bytes (int64) (Experimental) Soft limit on the number of in-memory partitions in an instance of the partitioned top-n operator. 67108864 67108864 false
enable_legacy_transform_codegen (bool) if true, enable transform function codegen. true true false
hdfs_zone_alias_conf (string) HDFS/S3A/ADLS path to config file defining non-standard time-zone aliases. false
hdfs_zone_info_zip (string) HDFS/S3A/ADLS path to a zip archive of the IANA time-zone database to use. false
enable_transform_codegen (bool) if true, enable transform function codegen. true true false
rpc_acceptor_listen_backlog (int32) Socket backlog parameter used when listening for RPC connections. This defines the maximum length to which the queue of pending TCP connections inbound to the RPC server may grow. If a connection request arrives when the queue is full, the client may receive an error. Higher values may help the server ride over bursts of new inbound connection requests. 128 128 false
rpc_encrypt_loopback_connections (bool) Whether to encrypt data transfer on RPC connections that stay within a single host. Encryption here is likely to offer no additional security benefit since only a local 'root' user could intercept the traffic, and wire encryption does not suitably protect against such an attacker. false false false
rpc_negotiation_inject_delay_ms (int32) If enabled, injects the given number of milliseconds delay into the RPC negotiation process on the server side. 0 0 false
rpc_trace_negotiation (bool) If enabled, dump traces of all RPC negotiations to the log false false false
rpc_callback_max_cycles (int64) The maximum number of cycles for which an RPC callback should be allowed to run without emitting a warning. (Advanced debugging option) 100000000 100000000 false
rpc_inject_cancellation_state (int32) If this flag is not -1, it is the state in which a cancellation request will be injected. Should use values in OutboundCall::State only -1 -1 false
rpc_reopen_outbound_connections (bool) Open a new connection to the server for every RPC call. If not enabled, an already existing connection to a server is reused upon making another call to the same server. When this flag is enabled, an already existing _idle_ connection to the server is closed upon making another RPC call which would reuse the connection otherwise. Used by tests only. false false false
tcp_keepalive_probe_period_s (int32) The duration in seconds after an outbound connection has gone idle before a TCP keepalive probe is sent to the peer. Set to 0 to disable TCP keepalive probes from being sent. 60 60 false
tcp_keepalive_retry_count (int32) The maximum number of keepalive probes sent before declaring the remote end as dead. Effective only if --tcp_keepalive_probe_period_s is not 0. 10 10 false
tcp_keepalive_retry_period_s (int32) The duration in seconds between successive keepalive probes from an outbound connection if the previous probes are not acknowledged. Effective only if --tcp_keepalive_probe_period_s is not 0. 3 3 false
remember_clients_ttl_ms (int64) Maximum amount of time, in milliseconds, the server "remembers" a client for the purpose of caching its responses. After this period without hearing from it, the client is no longer remembered and the memory occupied by its responses is reclaimed. Retries of requests older than 'remember_clients_ttl_ms' are treated as new ones. 3600000 3600000 false
remember_responses_ttl_ms (int64) Maximum amount of time, in milliseconds, the server "remembers" a response to a specific request for a client. After this period has elapsed, the response may have been garbage collected and the client might get a response indicating the request is STALE. 600000 600000 false
result_tracker_gc_interval_ms (int64) Interval at which the result tracker will look for entries to GC. 1000 1000 false
rpc_dump_all_traces (bool) If true, dump all RPC traces at INFO level false false false
rpc_duration_too_long_ms (int32) Threshold (in milliseconds) above which a RPC is considered too long and its duration and method name are logged at INFO level. The time measured is between when a RPC is accepted and when its call handler completes. 1000 1000 false
rpc_inject_invalid_authn_token_ratio (double) If set higher than 0, AuthenticateByToken() randomly injects errors replying with FATAL_INVALID_AUTHENTICATION_TOKEN code. The flag's value corresponds to the probability of the fault injection event. Used for only for tests. 0 0 false
rpc_inject_invalid_channel_bindings_ratio (double) The ratio of injection of invalid channel bindings during connection negotiation. This is a test-only flag. 0 0 false
rpc_send_channel_bindings (bool) Whether to send channel bindings in NegotiatePB response as prescribed by RFC 5929. This is a test-only flag. true true false
trusted_subnets (string) A trusted subnet whitelist. If set explicitly, all unauthenticated or unencrypted connections are prohibited except the ones from the specified address blocks. Otherwise, private network (127.0.0.0/8, etc.) and local subnets of all local network interfaces will be used. Set it to '0.0.0.0/0' to allow unauthenticated/unencrypted connections from all remote IP addresses. However, if network access is not otherwise restricted by a firewall, malicious users may be able to gain unauthorized access. 127.0.0.0/8,10.0.0.0/8,172.16.0.0/12,192.168.0.0/16,169.254.0.0/16 127.0.0.0/8,10.0.0.0/8,172.16.0.0/12,192.168.0.0/16,169.254.0.0/16 false
enable_exactly_once (bool) Whether to enable exactly once semantics. true true false
rpc_max_message_size_enable_validation (bool) Whether to turn off validation for --rpc_max_message_size flag. This is a test-only flag. true true false
use_system_auth_to_local (bool) When enabled, use the system krb5 library to map Kerberos principal names to local (short) usernames. If not enabled, the first component of the principal will be used as the short name. For example, 'kudu/foo.example.com@EXAMPLE' will map to 'kudu'. true true false
ipki_server_key_size (int32) the number of bits for server cert's private key. The server cert is used for TLS connections to and from clients and other servers. 2048 2048 false
openssl_security_level_override (int32) if set to 0 or greater, overrides the security level for OpenSSL library of versions 1.1.0 and newer; for test purposes only -1 -1 false
disable_blockbloomfilter_avx2 (bool) Disable AVX2 operations in BlockBloomFilter. This flag has no effect if the target CPU doesn't support AVX2 at run-time or BlockBloomFilter was built with a compiler that doesn't support AVX2. false false false
cache_force_single_shard (bool) Override all cache implementations to use just one shard false false false
cache_memtracker_approximation_ratio (double) The MemTracker associated with a cache can accumulate error up to this ratio to improve performance. For tests. 0.01 0.01 false
trace_to_console (string) Trace pattern specifying which trace events should be dumped directly to the console false
crash_on_eio (bool) Kill the process if an I/O operation results in EIO. If false, I/O resulting in EIOs will return the status IOError and leave error-handling up to the caller. false false false
encrypt_data_at_rest (bool) Whether sensitive files should be encrypted on the file system. false false false
encryption_key_length (int32) Encryption key length. 128 128 false
env_inject_eio (double) Fraction of the time that operations on certain files will fail with the posix code EIO. 0 0 false
env_inject_eio_globs (string) Comma-separated list of glob patterns specifying files on which I/O will fail. By default, all files may cause a failure. * * false
env_inject_lock_failure_globs (string) Comma-separated list of glob patterns specifying files on which attempts to obtain a file lock will fail. By default, no files will fail. false
env_inject_short_read_bytes (int32) The number of bytes less than the requested bytes to read 0 0 false
env_inject_short_write_bytes (int32) The number of bytes less than the requested bytes to write 0 0 false
env_use_fsync (bool) Use fsync(2) instead of fdatasync(2) for synchronizing dirty data to disk. false false false
env_use_ioctl_hole_punch_on_xfs (bool) Use the XFS_IOC_UNRESVSP64 ioctl instead of fallocate(2) to punch holes on XFS filesystems. true true false
never_fsync (bool) Never fsync() anything to disk. This is used by certain test cases to speed up runtime. This is very unsafe to use in production. false false false
disk_reserved_bytes_free_for_testing (int64) For testing only! Set to number of bytes free on each filesystem. Set to -1 to disable this test-specific override -1 -1 false
disk_reserved_override_prefix_1_bytes_free_for_testing (int64) For testing only! Set number of bytes free on the path prefix specified by --disk_reserved_override_prefix_1_path_for_testing. Set to -1 to disable. -1 -1 false
disk_reserved_override_prefix_1_path_for_testing (string) For testing only! Specifies a prefix to override the visible 'bytes free' on. Use --disk_reserved_override_prefix_1_bytes_free_for_testing to set the number of bytes free for this path prefix. Set to empty string to disable. false
disk_reserved_override_prefix_2_bytes_free_for_testing (int64) For testing only! Set number of bytes free on the path prefix specified by --disk_reserved_override_prefix_2_path_for_testing. Set to -1 to disable. -1 -1 false
disk_reserved_override_prefix_2_path_for_testing (string) For testing only! Specifies a prefix to override the visible 'bytes free' on. Use --disk_reserved_override_prefix_2_bytes_free_for_testing to set the number of bytes free for this path prefix. Set to empty string to disable. false
env_inject_full (double) Fraction of the time that space checks on certain paths will yield the posix code ENOSPC. 0 0 false
env_inject_full_globs (string) Comma-separated list of glob patterns specifying which paths return with space errors. * * false
disable_core_dumps (bool) Disable core dumps when this process crashes. false false false
dump_metrics_json (bool) Dump a JSON document describing all of the metrics which may be emitted by this binary. false false false
dump_metrics_xml (bool) Dump an XML document describing all of the metrics which may be emitted by this binary. false false false
redact (string) Comma-separated list that controls redaction context. Supported options are 'all','log', and 'none'. If 'all' is specified, sensitive data (sensitive configuration flags and row data) will be redacted from the web UI as well as glog and error messages. If 'log' is specified, sensitive data will only be redacted from glog and error messages. If 'none' is specified, no redaction will occur. all all false
umask (string) The umask that will be used when creating files and directories. Permissions of top-level data directories will also be modified at start-up to conform to the given umask. Changing this value may enable unauthorized local users to read or modify data stored by Kudu. 077 077 false
unlock_experimental_flags (bool) Unlock flags marked as 'experimental'. These flags are not guaranteed to be maintained across releases of Kudu, and may enable features or behavior known to be unstable. Use at your own risk. false false false
unlock_unsafe_flags (bool) Unlock flags marked as 'unsafe'. These flags are not guaranteed to be maintained across releases of Kudu, and enable features or behavior known to be unsafe. Use at your own risk. false false false
hung_task_check_interval_ms (int32) Number of milliseconds in between checks for hung threads 200 200 false
inject_latency_on_kernel_stack_lookup_ms (int32) Number of milliseconds of latency to inject when reading a thread's kernel stack 0 0 false
log_async (bool) Enable asynchronous writing to log files. This improves latency and stability. true true false
log_async_buffer_bytes_per_level (int32) The number of bytes of buffer space used by each log level. Only relevant when --log_async is enabled. 2097152 2097152 false
allocator_aligned_mode (bool) Use 16-byte alignment instead of 8-byte, unless explicitly specified otherwise - to boost SIMD false false false
metrics_retirement_age_ms (int32) The minimum number of milliseconds a metric will be kept for after it is no longer active. (Advanced option) 120000 120000 false
dns_resolver_cache_capacity_mb (uint32) Capacity of DNS resolver cache, in MiBytes. For each key, the cache stores records returned by getaddrinfo(). A value of 0 means the results of DNS name resolution are not cached. 1 1 false
dns_resolver_cache_ttl_sec (uint32) TTL of records in the DNS resolver cache, in seconds. 15 15 false
dns_resolver_max_threads_num (int32) The maximum number of threads to use for async DNS resolution 1 1 false
dns_addr_resolution_override (string) Comma-separated list of '='-separated pairs of hosts to addresses. The left-hand side of the '=' is taken as a host, and will resolve to the right-hand side which is expected to be a socket address with no port. false
fail_dns_resolution (bool) Whether to fail dns resolution, for tests. false false false
fail_dns_resolution_hostports (string) Comma-separated list of hostports that fail dns resolution. If empty, fails all dns resolution attempts. Only takes effect if --fail_dns_resolution is 'true'. false
host_for_tests (string) Host to use when resolving a given server's locally bound or advertised addresses. false
local_ip_for_outbound_sockets (string) IP to bind to when making outgoing socket connections. This must be an IP address of the form A.B.C.D, not a hostname. Advanced parameter, subject to change. false
socket_inject_short_recvs (bool) Inject short recv() responses which return less data than requested false false false
memory_limit_hard_bytes (int64) Maximum amount of memory this daemon should use, in bytes. A value of 0 autosizes based on the total system memory. A value of -1 disables all memory limiting. 0 0 false
memory_limit_soft_percentage (int32) Percentage of the hard memory limit that this daemon may consume before memory throttling of writes begins. The greater the excess, the higher the chance of throttling. In general, a lower soft limit leads to smoother write latencies but decreased throughput, and vice versa for a higher soft limit. 80 80 false
memory_limit_warn_threshold_percentage (int32) Percentage of the hard memory limit that this daemon may consume before WARNING level messages are periodically logged. 98 98 false
memory_pressure_percentage (int32) Percentage of the hard memory limit that this daemon may consume before flushing of in-memory data becomes prioritized. 60 60 false
thread_inject_start_latency_ms (int32) Number of ms to sleep when starting a new thread. (For tests). 0 0 false
accepted_cnxn_queue_depth (int32) (Advanced) The size of the post-accept, pre-setup connection queue in each thrift server set up to service Impala internal and external connections. 10000 10000 false
accepted_cnxn_setup_thread_pool_size (int32) (Advanced) The size of the thread pool that is used to process the post-accept, pre-setup connection queue in each thrift server set up to service Impala internal and external connections. 2 2 false
cookie_require_secure (bool) (Advanced) If true, authentication cookies will include the 'Secure' attribute, indicating to clients that they should only be returned over SSL connections. For testing only. true true false
max_cookie_lifetime_s (int64) Maximum amount of time in seconds that an authentication cookie will remain valid. Setting to 0 disables use of cookies. Defaults to 1 day. 86400 86400 false
enable_ldap_auth (bool) If true, use LDAP authentication for client connections false false false
enable_plugin_auth (bool) If true, use plugin authentication for client connections. false false false
internal_principals_whitelist (string) (Advanced) Comma-separated list of additional usernames authorized to access Impala's internal APIs. Defaults to 'hdfs' which is the system user that in certain deployments must access catalog server APIs. hdfs hdfs false
jwks_file_path (string) File path of the pre-installed JSON Web Key Set (JWKS) for JWT verification false
jwks_pulling_timeout_s (int32) (Advanced) The time in seconds for connection timed out when pulling JWKS from the specified URL. 10 10 false
jwks_update_frequency_s (int32) (Advanced) The time in seconds to wait between downloading JWKS from the specified URL. 60 60 false
jwks_url (string) URL of the JSON Web Key Set (JWKS) for JWT verification false
jwt_custom_claim_username (string) Custom claim 'username' username username false
jwt_token_auth (bool) When true, read the JWT token out of the HTTP Header and extract user name from the token payload. false false false
jwt_validate_signature (bool) When true, validate the signature of JWT token with pre-installed JWKS. true true false
ldap_ca_certificate (string) The full path to the certificate file used to authenticate the LDAP server's certificate for SSL / TLS connections. false
ldap_group_filter (string) Used as filter for both simple and search bind mechanisms. For simple bind it is a comma separated list of groups. If specified, users must belong to one of these groups for authentication to succeed. For search bind it is an LDAP filter that will be used during LDAP group search, it can contain '{0}' pattern which will be replaced with the user name and/or '{1}' which will be replace with the user dn. false
ldap_user_filter (string) Used as filter for both simple and search bind mechanisms. For simple bind it is a comma separated list of user names. If specified, users must be on this list for authentication to succeed. For search bind it is an LDAP filter that will be used during LDAP search, it can contain '{0}' pattern which will be replaced with the user name. false
plugin_authentication_cmd (string) A command used for authentication. Username is the first arguments and password is the second. If return code is 0, the authentication succeeds; otherwise, the authentication fails. false
sasl_path (string) Colon separated list of paths to look for SASL security library plugins. false
trusted_domain (string) If set, Impala will skip authentication for connections originating from this domain. Currently, only connections over HTTP support this. Note: It still requires the client to specify a username via the Basic Authorization header in the format <username>:<password> where the password is not used and can be left blank. false
trusted_domain_use_xff_header (bool) If set to true, this uses the 'X-Forwarded-For' HTML header to check for origin while attempting to verify if the connection request originated from a trusted domain. Only used if '--trusted_domain' is specified. Warning: Only use this if you trust the incoming connection to have this set correctly. false false false
num_acceptor_threads (int32) Number of threads dedicated to accepting connection requests for RPC services 2 2 false
num_reactor_threads (int32) Number of threads dedicated to managing network IO for RPC services. If left at default value 0, it will be set to number of CPU cores. 0 0 false
rpc_negotiation_thread_count (int32) Maximum number of threads dedicated to handling RPC connection negotiations. 64 64 false
rpc_negotiation_timeout_ms (int32) Time in milliseconds of waiting for a negotiation to complete before timing out. 300000 300000 false
rpc_retry_interval_ms (int32) Time in millisecond of waiting before retrying an RPC when remote is busy 5 5 false
rpc_use_loopback (bool) Always use loopback for local connections. This requires binding to all addresses, not just the KRPC address. false false false
rpc_use_unix_domain_socket (bool) Whether the KRPC client and server should use Unix domain socket. If enabled, each daemon is identified with Unix Domain Socket address in the unique name in "Abstract Namespace", in format @impala-krpc:<BackendId>. The KRPC server bind to a Unix domain socket. KRPC Client attempt to connect to KRPC server via a Unix domain socket. false false false
uds_address_unique_id (string) Specify unique Id for UDS address. It could be "ip_address", "backend_id", or "none" ip_address ip_address false
enable_thrift_binary_protocol_strict_read (bool) If true, the binary protocol for thrift reads message in strict mode. It will check the version when reading message begin. true true false
concurrent_scratch_ios_per_device (int32) Set this to influence the number of concurrent write I/Os issues to write data to scratch files. This is multiplied by the number of active scratch directories to obtain the target number of scratch write I/Os per query. 2 2 false
madvise_huge_pages (bool) (Advanced) If true, advise operating system to back large memory buffers with huge pages true true false
mmap_buffers (bool) (Experimental) If true, allocate buffers directly from the operating system instead of with TCMalloc. false false false
insert_inherit_permissions (bool) If true, new directories created by INSERTs will inherit the permissions of their parent directories false false false
admission_control_slots (int32) (Advanced) The maximum degree of parallelism to run queries with on this backend. This determines the number of slots available to queries in admission control for this backend. The degree of parallelism of the query determines the number of slots that it needs. Defaults to number of cores / -num_cores for executors, and 8x that value for dedicated coordinators). 0 0 false
backend_client_connection_num_retries (int32) Retry backend connections. 3 3 false
backend_client_rpc_timeout_ms (int32) (Advanced) The underlying TSocket send/recv timeout in milliseconds for a backend client RPC. 300000 300000 false
catalog_client_connection_num_retries (int32) The number of times connections or RPCs to the catalog should be retried. 10 10 false
catalog_client_rpc_retry_interval_ms (int32) (Advanced) The time to wait before retrying when the catalog RPC client fails to connect to catalogd or when RPCs to the catalogd fail. 3000 3000 false
catalog_client_rpc_timeout_ms (int32) (Advanced) The underlying TSocket send/recv timeout in milliseconds for a catalog client RPC. 0 0 false
catalog_service_host (string) hostname where CatalogService is running localhost localhost false
disable_sa_query_timeout (bool) if --disable_sa_query_timeout is true, then does not have to init sa query timeout false false false
enable_webserver (bool) If true, debug webserver is enabled true true false
max_concurrent_queries (int32) (Deprecated) This has been replaced with --admission_control_slots, which better accounts for the higher parallelism of queries with mt_dop > 1. If --admission_control_slots is not set, the value of --max_concurrent_queries is used instead for backward compatibility. 0 0 false
metrics_webserver_interface (string) Interface to start metrics webserver on. If blank, webserver binds to 0.0.0.0 false
metrics_webserver_port (int32) If non-zero, the port to run the metrics webserver on, which exposes the /metrics, /jsonmetrics, /metrics_prometheus, and /healthz endpoints without authentication enabled. 0 0 false
num_hdfs_worker_threads (int32) (Advanced) The number of threads in the global HDFS operation pool 16 16 false
ping_expose_webserver_url (bool) If true, debug webserver url is exposed via PingImpalaService/PingImpalaHS2Service RPC calls true true false
state_store_host (string) hostname where StatestoreService is running localhost localhost false
state_store_subscriber_port (int32) port where StatestoreSubscriberService should be exported 23000 23000 false
s3a_access_key_cmd (string) A Unix command whose output returns the access key to S3, i.e. "fs.s3a.access.key". false
s3a_secret_key_cmd (string) A Unix command whose output returns the secret key to S3, i.e. "fs.s3a.secret.key". false
data_cache_anonymize_trace (bool) (Advanced) Use hashes of filenames rather than file paths in the data cache access trace. false false false
data_cache_checksum (bool) (Advanced) Enable checksumming for the cached buffer. false false false
data_cache_enable_tracing (bool) (Advanced) Collect a trace of all lookups in the data cache. false false false
data_cache_eviction_policy (string) (Advanced) The cache eviction policy to use for the data cache. Either 'LRU' (default) or 'LIRS' (experimental) LRU LRU false
data_cache_file_max_size_bytes (int64) (Advanced) The maximum size which a cache file can grow to before data stops being appended to it. 1099511627776 1099511627776 false
data_cache_max_opened_files (int32) (Advanced) The maximum number of allowed opened files. This must be at least the number of specified partitions. 1000 1000 false
data_cache_trace_dir (string) The base directory for data cache tracing. The data cache trace files for each cache directory are placed in separate subdirectories underneath this base directory. If blank, defaults to <log_file_dir>/data_cache_trace/ false
data_cache_trace_percentage (int32) The percentage of cache lookups that should be emitted to the trace file. 100 100 false
data_cache_write_concurrency (int32) (Advanced) Number of concurrent threads allowed to insert into the cache per partition. 1 1 false
max_data_cache_trace_file_size (int32) The maximum size (in log entries) of the data cache trace file before a new one is created. 100000 100000 false
max_data_cache_trace_files (int32) Maximum number of data cache trace files to retain for each cache directory specified by the data_cache startup parameter. The most recent trace files are retained. If set to 0, all trace files are retained. 10 10 false
cache_abfs_file_handles (bool) Enable the file handle cache for ABFS files. true true false
cache_alluxio_file_handles (bool) Enable the file handle cache for ALLUXIO files. true true false
cache_remote_file_handles (bool) Enable the file handle cache for remote HDFS files. true true false
cache_s3_file_handles (bool) Enable the file handle cache for S3 files. true true false
data_cache (string) The configuration string for IO data cache. Default to be an empty string so it's disabled. The configuration string is expected to be a list of directories, separated by ',', followed by a ':' and a capacity quota per directory. For example /data/0,/data/1:1TB means the cache may use up to 2TB, with 1TB max in /data/0 and /data/1 respectively. Please note that each Impala daemon on a host must have a unique caching directory. false
max_cached_file_handles (uint64) Maximum number of HDFS file handles that will be cached. Disabled if set to 0. 20000 20000 false
num_abfs_io_threads (int32) Number of ABFS I/O threads 16 16 false
num_adls_io_threads (int32) Number of ADLS I/O threads 16 16 false
num_alluxio_io_threads (int32) Number of ALLUXIO I/O threads 16 16 false
num_cos_io_threads (int32) Number of COS I/O threads 16 16 false
num_disks (int32) Number of disks on data node. 0 0 false
num_file_handle_cache_partitions (uint64) Number of partitions used by the file handle cache. 16 16 false
num_gcs_io_threads (int32) Number of GCS I/O threads 16 16 false
num_io_threads_per_rotational_disk (int32) Number of I/O threads per rotational disk. Has priority over num_threads_per_disk. If neither is set, defaults to 1 thread(s) per rotational disk 0 0 false
num_io_threads_per_solid_state_disk (int32) Number of I/O threads per solid state disk. Has priority over num_threads_per_disk. If neither is set, defaults to 8 thread(s) per solid state disk 0 0 false
num_obs_io_threads (int32) Number of OBS I/O threads 16 16 false
num_ozone_io_threads (int32) Number of Ozone I/O threads 16 16 false
num_remote_hdfs_file_oper_io_threads (int32) Number of remote HDFS file operations I/O threads 8 8 false
num_remote_hdfs_io_threads (int32) Number of remote HDFS I/O threads 8 8 false
num_s3_file_oper_io_threads (int32) Number of S3 file operations I/O threads 16 16 false
num_s3_io_threads (int32) Number of S3 I/O threads 16 16 false
num_threads_per_disk (int32) Number of I/O threads per disk 0 0 false
num_us3_io_threads (int32) Number of US3 I/O threads 16 16 false
unused_file_handle_timeout_sec (uint64) Maximum time, in seconds, that an unused HDFS file handle will remain in the file handle cache. Disabled if set to 0. 21600 21600 false
fs_slow_read_log_threshold_ms (int64) Log diagnostics about I/Os issued via the HDFS client that take longer than this threshold. 10000 10000 false
fs_trace_remote_reads (bool) (Advanced) Log block locations for remote reads. false false false
use_hdfs_pread (bool) Enables using hdfsPread() instead of hdfsRead() when performing HDFS read operations. This is necessary to use HDFS hedged reads (assuming the HDFS client is configured to do so). Preads are always enabled for S3A and ABFS reads. false false false
hdfs_operation_timeout_sec (uint64) Maximum time, in seconds, that an HDFS operation should wait before timing out and failing. 300 300 false
datastream_sender_timeout_ms (int32) (Advanced) The time, in ms, that can elapse before a plan fragment will time-out trying to send the initial row batch. 120000 120000 false
datastream_service_deserialization_queue_size (int32) Number of deferred RPC requests that can be enqueued before being processed by a deserialization thread. 10000 10000 false
datastream_service_num_deserialization_threads (int32) Number of threads for deserializing RPC requests deferred due to the receiver not ready or the soft limit of the receiver is reached. 16 16 false
data_stream_sender_buffer_size (int64) (Advanced) Max size in bytes which a row batch in a data stream sender's channel can accumulate before the row batch is sent over the wire. 16384 16384 false
max_query_mem_limit_factor (double) if retry query memory estimated is more than the mem_limit multiply by this factor, reset the memory estimated and set query memory limit 0.59999999999999998 0.59999999999999998 false
reset_mem_estimate_factor (double) factor when retry query set per_host_mem_estimate from original memory estimated. 1.5 1.5 false
log_mem_usage_interval (int32) If non-zero, impalad will output memory usage every log_mem_usage_interval'th fragment completion. 0 0 false
query_exec_mgr_cancellation_thread_pool_size (int32) (Advanced) Size of the QueryExecMgr thread-pool processing cancellations due to coordinator failure 1 1 false
max_filter_error_rate (double) (Advanced) The target false positive probability used to determine the ideal size for each bloom filter size. This value can be overriden by the RUNTIME_FILTER_ERROR_RATE query option. 0.75 0.75 false
num_threads_per_core (int32) Number of threads per core. 3 3 false
allow_multiple_scratch_dirs_per_device (bool) If false and --scratch_dirs contains multiple directories on the same device, then only the first writable directory is used true true false
allow_spill_to_hdfs (bool) Spill to HDFS is a test-only feature, only when set true, the user can configure a HDFS scratch path. false false false
disk_spill_compression_buffer_limit_bytes (int64) (Advanced) Limit on the total bytes of compression buffers that will be used for spill-to-disk compression across all queries. If this limit is exceeded, some data may be spilled to disk in uncompressed form. 536870912 536870912 false
disk_spill_compression_codec (string) (Advanced) If set, data will be compressed using the specified compression codec before spilling to disk. This can substantially reduce scratch disk usage, at the cost of requiring more CPU and memory resources to compress the data. Uses the same syntax as the COMPRESSION_CODEC query option, e.g. 'lz4', 'zstd', 'zstd:6'. If this is set, then --disk_spill_punch_holes must be enabled. false
disk_spill_encryption (bool) Set this to encrypt and perform an integrity check on all data spilled to disk during a query true true false
disk_spill_punch_holes (bool) (Advanced) changes the free space management strategy for files created in --scratch_dirs to punch holes in the file when space is unused. This can reduce the amount of scratch space used by queries, particularly in conjunction with disk spill compression. This option requires the filesystems of the directories in --scratch_dirs to support hole punching. false false false
remote_tmp_file_block_size (string) Specify the size of the block for doing file uploading and fetching. The block size should be power of 2 and less than the size of remote temporary file. 1M 1M false
remote_tmp_file_size (string) Specify the size of a remote temporary file. Upper bound is 256MB. Lower bound is the block size. The size should be power of 2 and integer times of the block size. 16M 16M false
remote_tmp_files_avail_pool_lifo (bool) If true, lifo is the algo to evict the local buffer files during spilling to the remote. Otherwise, fifo would be used. false false false
scratch_dirs (string) Writable scratch directories. This is a comma-separated list of directories. Each directory is specified as the directory path, an optional limit on the bytes that will be allocated in that directory, and an optional priority for the directory. If the optional limit is provided, the path and the limit are separated by a colon. E.g. '/dir1:10G,/dir2:5GB,/dir3' will allow allocating up to 10GB of scratch in /dir1, 5GB of scratch in /dir2 and an unlimited amount in /dir3. If the optional priority is provided, the path and the limit and priority are separated by colon. Priority based spilling will result in directories getting selected as a spill target based on their priority. The lower the numerical value the higher the priority. E.g. '/dir1:10G:0,/dir2:5GB:1,/dir3::1', will cause spilling to first fill up '/dir1' followed by using '/dir2' and '/dir3' in a round robin manner. /tmp /tmp false
wait_for_spill_buffer_timeout_s (int32) Specify the timeout duration waiting for the buffer to write (second). If a spillingopertion fails to get a buffer from the pool within the duration, the operationfails. 60 60 false
admission_control_service_num_svc_threads (int32) Number of threads for processing admission control service's RPCs. if left at default value 0, it will be set to number of CPU cores. Set it to a positive value to change from the default. 0 0 false
admission_control_service_queue_mem_limit (string) (Advanced) Limit on RPC payloads consumption for AdmissionControlService. Specified as number of bytes ('<int>[bB]?'), megabytes ('<float>[mM]'), gigabytes ('<float>[gG]'), or percentage of the process memory limit ('<int>%'). Defaults to bytes if no unit is given. 50MB 50MB false
admission_service_host (string) If provided, queries submitted to this impalad will be scheduled and admitted by contacting the admission control service at the specified address and --admission_service_port. false
admission_status_wait_time_ms (int32) (Advanced) The number of milliseconds the GetQueryStatus() rpc in the admission control service will wait for admission to complete before returning. 100 100 false
admission_thread_pool_size (int32) (Advanced) Size of the thread-pool processing AdmitQuery requests. 5 5 false
max_admission_queue_size (int32) (Advanced) Max size of the queue for the AdmitQuery thread pool. 50 50 false
coordinator_rolling_time_ms (int32) The time to rolling coordinator to check whether this coordinator can admit query. 300 300 false
enable_coordinator_consistent (bool) If true, enable coordinator consistent false false false
queue_wait_timeout_ms (int64) Maximum amount of time (in milliseconds) that a request will wait to be admitted before timing out. 60000 60000 false
admission_service_port (int32) The port where the admission control service runs 29500 29500 false
blacklisting_enabled (bool) (Advanced) If false, disables local blacklisting of executors by coordinators, which temporarily removes executors that appear to be problematic from scheduling decisions. true true false
prober_quota_reserved_mem_per_executor (int64) The reserved memory (unit bytes) for the prober quota on the single executor. 524288000 524288000 false
quota_config (string) The config of quota resource {"executor-groups":[{"group":"default","quota":{"common":50}}]} {"executor-groups":[{"group":"default","quota":{"common":50}}]} false
admission_max_retry_time_s (int32) (Advanced) The amount of time in seconds the coordinator will spend attempting to retry admission if the admissiond is unreachable. 60 60 false
admission_status_retry_time_ms (int32) (Advanced) The number of milliseconds coordinators will wait before retrying the GetQueryStatus rpc. 10 10 false
auto_compute_cluster_mem_limit (bool) AutoCompute single pool's memory limit according to executors's total mem_limit. false false false
cluster_mem_limit_factor (double) The result of the cluster's mem_limit divide executors's total mem_limit summation. 1 1 false
default_pool_max_queued (int64) Maximum number of requests allowed to be queued before rejecting requests. A negative value or 0 indicates requests will always be rejected once the maximum number of concurrent requests are executing. Ignored if fair_scheduler_config_path and llama_site_path are set. 200 200 false
default_pool_max_requests (int64) Maximum number of concurrent outstanding requests allowed to run before queueing incoming requests. A negative value indicates no limit. 0 indicates no requests will be admitted. Ignored if fair_scheduler_config_path and llama_site_path are set. -1 -1 false
default_pool_mem_limit (string) Maximum amount of memory that all outstanding requests in this pool may use before new requests to this pool are queued. Specified as number of bytes ('<int>[bB]?'), megabytes ('<float>[mM]'), gigabytes ('<float>[gG]'), or percentage of the physical memory ('<int>%'). Defaults to bytes if no unit is given. Ignored if fair_scheduler_config_path and llama_site_path are set. false
disable_pool_max_requests (bool) Disables all per-pool limits on the maximum number of running requests. false false false
disable_pool_mem_limits (bool) Disables all per-pool mem limits. false false false
fair_scheduler_allocation_path (string) Path to the fair scheduler allocation file (fair-scheduler.xml). false
llama_site_path (string) Path to the Llama configuration file (llama-site.xml). If set, fair_scheduler_allocation_path must also be set. false
require_username (bool) Requires that a user be provided in order to schedule requests. If enabled and a user is not provided, requests will be rejected, otherwise requests without a username will be submitted with the username 'default'. false false false
disable_admit_immediately (bool) disable the admit-immediately feature. false false false
enable_group_fair_scheduling (bool) Enable the fair scheduling, default false. In case of multiple executor group, if coordinator & executor is not separate, enabling group fair scheduling can balance queries across multiple executor groups false false false
enable_priority_scheduller (bool) Enable the priority scheduller, default false. false false false
queue_switch_interval_s (int32) The interval of the proportion of schedulingpolicy adjustments. 120 120 false
queue_time_slice_s (int32) Rotate according to this time slice,one slice using FCFS, the following slice using round robin. 10 10 false
control_service_num_svc_threads (int32) Number of threads for processing control service's RPCs. if left at default value 0, it will be set to number of CPU cores. Set it to a positive value to change from the default. 0 0 false
control_service_queue_mem_limit (string) (Advanced) Limit on RPC payloads consumption for ControlService. Specified as number of bytes ('<int>[bB]?'), megabytes ('<float>[mM]'), gigabytes ('<float>[gG]'), or percentage of the process memory limit ('<int>%'). Defaults to bytes if no unit is given. 1% 1% false
control_service_queue_mem_limit_floor_bytes (int64) Lower bound on --control_service_queue_mem_limit in bytes. If --control_service_queue_mem_limit works out to be less than this amount, this value is used instead 52428800 52428800 false
datastream_service_num_svc_threads (int32) Number of threads for processing datastream services' RPCs. If left at default value 0, it will be set to number of CPU cores. Set it to a positive value to change from the default. 0 0 false
datastream_service_queue_mem_limit (string) (Advanced) Limit on RPC payloads consumption for DataStreamService. Specified as number of bytes ('<int>[bB]?'), megabytes ('<float>[mM]'), gigabytes ('<float>[gG]'), or percentage of the process memory limit ('<int>%'). Defaults to bytes if no unit is given. 5% 5% false
fe_expr_eval_mode (bool) if true, eval expr in Java with FeExprEvalContext. false false false
authorization_factory_class (string) Specifies the class name that implements the authorization provider. This will override the authorization_provider flag if both are specified. false
authorization_provider (string) Specifies the type of internally-provided authorization provider to use. Defaults to unset, which disables authorization. To enable authorization, set to one of the following: ['ranger'] false
authorized_proxy_group_config (string) Specifies the set of authorized proxy groups (users who can delegate to other users belonging to the specified groups during authorization) and whom they are allowed to delegate. Input is a semicolon-separated list of key=value pairs of authorized proxy users to the group(s) they can delegate to. These groups are specified as a list of groups separated by a delimiter (which defaults to comma and may be changed via --authorized_proxy_group_config_delimiter), or '*' to indicate all users. For example: hue=group1,group2;admin=* false
authorized_proxy_group_config_delimiter (string) Specifies the delimiter used in authorized_proxy_group_config. , , false
authorized_proxy_user_config (string) Specifies the set of authorized proxy users (users who can delegate to other users during authorization) and whom they are allowed to delegate. Input is a semicolon-separated list of key=value pairs of authorized proxy users to the user(s) they can delegate to. These users are specified as a list of short usernames separated by a delimiter (which defaults to comma and may be changed via --authorized_proxy_user_config_delimiter), or '*' to indicate all users. For example: hue=user1,user2;admin=* false
authorized_proxy_user_config_delimiter (string) Specifies the delimiter used in authorized_proxy_user_config. , , false
kudu_master_hosts (string) Specifies the default Kudu master(s). The given value should be a comma separated list of hostnames or IP addresses; ports are optional. false
priority_mapping_rules (string) The mapping rules for priority, schema: json. alias https://doc.sensorsdata.cn/pages/viewpage.action?pageId=293095950 false
ranger_app_id (string) Specifies the Ranger application ID. Ranger application ID is an ID to uniquely identify the application that communicates with Ranger. This flag is required when authorization with Ranger is enabled. false
ranger_service_type (string) Specifies the Ranger service type. hive hive false
server_name (string) The name to use for securing this impalad server during authorization. Set to enable authorization. false
abort_on_failed_audit_event (bool) Shutdown Impala if there is a problem recording an audit event. true true false
abort_on_failed_lineage_event (bool) Shutdown Impala if there is a problem recording a lineage record. true true false
accepted_client_cnxn_timeout (int64) (Advanced) The amount of time in milliseconds an accepted connection will wait in the post-accept, pre-setup connection queue before it is timed out and the connection request is rejected. A value of 0 means there is no timeout. 300000 300000 false
admission_heartbeat_frequency_ms (int32) (Advanced) The time in milliseconds to wait between sending heartbeats to the admission service, if enabled. Heartbeats are used to ensure resources are properly accounted for even if rpcs to the admission service occasionally fail. 1000 1000 false
audit_event_log_dir (string) The directory in which audit event log files are written. Setting this flag will enable audit event logging. false
beeswax_port (int32) port on which Beeswax client requests are served.If 0 or less, the Beeswax server is not started. This interface is deprecated and will be removed in a future version. 21000 21000 false
cancellation_thread_pool_size (int32) (Advanced) Size of the thread-pool processing cancellations due to node failure 5 5 false
convert_legacy_hive_parquet_utc_timestamps (bool) When true, TIMESTAMPs read from files written by Parquet-MR (used by Hive) will be converted from UTC to local time. Writes are unaffected. Can be overriden with the query option with the same name. false false false
default_query_options (string) key=value pair of default query options for impalad, separated by ',' false
disconnected_session_timeout (int32) The time, in seconds, that a hiveserver2 session will be maintained after the last connection that it has been used over is disconnected. 900 900 false
dump_exec_request_path (string) If set, dump TExecRequest structures to {dump_exec_request_path}/TExecRequest-{internal|external}.{query_id.hi}-{query_id.lo} false
executor_groups (string) List of executor groups, separated by comma. Each executor group specification can optionally contain a minimum size, separated by a ':', e.g. --executor_groups default-pool-1:3. Default minimum size is 1. Only when the cluster membership contains at least that number of executors for the group will it be considered healthy for admission. Currently only a single group may be specified. false
expected_executor_group_sets (string) Only used by the coordinator. List of expected executor group sets, separated by comma in the following format: <executor_group_name_prefix>:<expected_group_size> . For eg. “prefix1:10”, this set will include executor groups named like prefix1-group1, prefix1-group2, etc. The expected group size (number of executors in each group) is used during planning when no healthy executor group is available. If this flag is used then any executor groups that do not map to the specified group sets will never be used to schedule queries. false
explode_column_regex (string) For Sensors Analytics, string list columns false
external_fe_port (int32) port on which External Frontend requests are served. If 0 or less, the External Frontend server is not started. Careful consideration must be taken when enabling due to the fact that this port is currently always unauthenticated. 0 0 false
fe_service_threads (int32) number of threads available to serve client requests 128 128 false
force_expired_query_unregister (bool) Forcefully unregister the expired query and reclaim resources. false false false
hs2_http_port (int32) port on which HiveServer2 HTTP(s) client requests are served. If 0 or less, the HiveServer2 http server is not started. 0 0 false
hs2_port (int32) port on which HiveServer2 client requests are served.If 0 or less, the HiveServer2 server is not started. 21050 21050 false
idle_client_poll_period_s (int32) The poll period, in seconds, after no activity from an Impala client which an Impala service thread (beeswax and HS2) wakes up to check if the connection should be closed. If --idle_session_timeout is also set, a client connection will be closed if all the sessions associated with it have become idle. Set this to 0 to disable the polling behavior and clients' connection will remain opened until they are explicitly closed. 60 60 false
idle_query_timeout (int32) The time, in seconds, that a query may be idle for (i.e. no processing work is done and no updates are received from the client) before it is cancelled. If 0, idle queries are never expired. The query option QUERY_TIMEOUT_S overrides this setting, but, if set, --idle_query_timeout represents the maximum allowable timeout. 0 0 false
idle_session_timeout (int32) The time, in seconds, that a session may be idle for before it is closed (and all running queries cancelled) by Impala. If 0, idle sessions are never expired. It can be overridden by the query option 'idle_session_timeout' for specific sessions 1200 1200 false
is_coordinator (bool) If true, this Impala daemon can accept and coordinate queries from clients. If false, it will refuse client connections. true true false
is_executor (bool) If true, this Impala daemon will execute query fragments. true true false
lineage_event_log_dir (string) The directory in which lineage event log files are written. Setting this flag with enable lineage logging. false
log_query_to_avro_keep_partitions_num (int32) kudu workload_query table keep partitions num 30 30 false
log_query_to_file (bool) if true, logs completed query profiles to file. true true false
max_audit_event_log_file_size (int32) The maximum size (in queries) of the audit event log file before a new one is created (if event logging is enabled) 5000 5000 false
max_audit_event_log_files (int32) Maximum number of audit event log files to retain. The most recent audit event log files are retained. If set to 0, all audit event log files are retained. 0 0 false
max_lineage_log_file_size (int32) The maximum size (in queries) of the lineage event log file before a new one is created (if lineage logging is enabled) 5000 5000 false
max_profile_log_file_size (int32) The maximum size (in queries) of the profile log file before a new one is created 5000 5000 false
max_profile_log_files (int32) Maximum number of profile log files to retain. The most recent log files are retained. If set to 0, all log files are retained. 10 10 false
max_result_cache_size (int64) Maximum number of query results a client may request to be cached on a per-query basis to support restarting fetches. This option guards against unreasonably large result caches requested by clients. Requests exceeding this maximum will be rejected. 100000 100000 false
num_expected_executors (int32) The number of executors that are expected to be available for the execution of a single query. This value is used during planning if no executors have started yet. Once a healthy executor group has started, its size is used instead. NOTE: This flag is overridden by 'expected_executor_group_sets' which is a more expressive way of specifying multiple executor group sets 20 20 false
profile_log_dir (string) The directory in which profile log files are written. If blank, defaults to <log_file_dir>/profiles false
query_event_hook_classes (string) Comma-separated list of java QueryEventHook implementation classes to load and register at Impala startup. Class names should be fully-qualified and on the classpath. Whitespace acceptable around delimiters. false
query_event_hook_nthreads (int32) Number of threads to use for QueryEventHook execution. If this number is >1 then hooks will execute concurrently. 1 1 false
query_log_size (int32) Number of queries to retain in the query log. If -1, the query log has unbounded size. 100 100 false
query_stmt_size (int32) length of the statements in the query log. If <=0, the full statement is displayed in the query log without trimming. 250 250 false
record_all_query_to_workload_query (bool) if true, record all the query to workload_query table, otherwise you will skip some query, such as some DDL statements, check the ImpalaServer::CanSkipArchive function for details false false false
sensors_hs2_port (int32) port on which HiveServer2 sensors client requests are served.If 0 or less, the HiveServer2 server is not started. 20000 20000 false
shutdown_deadline_s (int64) Default time limit in seconds for the shut down process. If this duration elapses after the shut down process is started, the daemon shuts down regardless of any running queries. 3600 3600 false
shutdown_grace_period_s (int64) Shutdown startup grace period in seconds. When the shutdown process is started for this daemon, it will wait for at least the startup grace period before shutting down. This gives time for updated cluster membership information to propagate to all coordinators and for fragment instances that were scheduled based on old cluster membership to start executing (and therefore be reflected in the metrics used to detect quiescence). 120 120 false
ssl_cipher_list (string) The cipher suite preferences to use for TLS-secured Thrift RPC connections. Uses the OpenSSL cipher preference list format. See man (1) ciphers for more information. If empty, the default cipher list for your platform is used false
ssl_client_ca_certificate (string) (Advanced) The full path to a certificate used by Thrift clients to check the validity of a server certificate. May either be a certificate for a third-party Certificate Authority, or a copy of the certificate the client expects to receive from the server. false
ssl_minimum_version (string) The minimum SSL/TLS version that Thrift services should use for both client and server connections. Supported versions are TLSv1.0, TLSv1.1 and TLSv1.2 (as long as the system OpenSSL library supports them) tlsv1.2 tlsv1.2 false
ssl_private_key (string) The full path to the private key used as a counterpart to the public key contained in --ssl_server_certificate. If --ssl_server_certificate is set, this option must be set as well. false
ssl_private_key_password_cmd (string) A Unix command whose output returns the password used to decrypt the certificate private key file specified in --ssl_private_key. If the .PEM key file is not password-protected, this command will not be invoked. The output of the command will be truncated to 1024 bytes, and then all trailing whitespace will be trimmed before it is used to decrypt the private key false
ssl_server_certificate (string) The full path to the SSL certificate file used to authenticate Impala to clients. If set, both Beeswax and HiveServer2 ports will only accept SSL connections false
status_report_cancellation_padding (int32) (Advanced) The coordinator will wait --status_report_max_retry_s * (1 + --status_report_cancellation_padding / 100) without receiving a status report before deciding that a backend is unresponsive and the query should be cancelled. This must be > 0. 20 20 false
status_report_interval_ms (int32) (Advanced) Interval between profile reports in milliseconds. If set to <= 0, periodic reporting is disabled and only the final report is sent. 5000 5000 false
status_report_max_retry_s (int32) (Advanced) Max amount of time in seconds for a backend to attempt to send a status report before cancelling. This must be > --status_report_interval_ms. Effective only if --status_report_interval_ms > 0. 600 600 false
unregistration_thread_pool_queue_depth (int32) (Advanced) Max number of queries that can be queued for unregistration. 16 16 false
unregistration_thread_pool_size (int32) (Advanced) Size of the thread-pool for unregistering queries, including finalizing runtime profiles 4 4 false
use_local_tz_for_unix_timestamp_conversions (bool) When true, TIMESTAMPs are interpreted in the local time zone when converting to and from Unix times. When false, TIMESTAMPs are interpreted in the UTC time zone. Set to true for Hive compatibility. Can be overriden with the query option with the same name. false false false
disable_hbase (bool) No need HBase in the business, so comment it out for default. true true false
statestore_client_rpc_timeout_ms (int32) (Advanced) The underlying TSocket send/recv timeout in milliseconds for a catalog client RPC. 300000 300000 false
statestore_subscriber_cnxn_attempts (int32) The number of times to retry an RPC connection to the statestore. A setting of 0 means retry indefinitely 10 10 false
statestore_subscriber_cnxn_retry_interval_ms (int32) The interval, in ms, to wait between attempts to make an RPC connection to the statestore. 3000 3000 false
statestore_subscriber_timeout_seconds (int32) The amount of time (in seconds) that may elapse before the connection with the statestore is considered lost. 30 30 false
statestore_subscriber_use_resolved_address (bool) If set to true, the subscriber will register with statestore using its resolved IP address. Note that using resolved IP address may cause mismatch with the TLS certificate. false false false
state_store_port (int32) port where StatestoreService is running 24000 24000 false
statestore_heartbeat_frequency_ms (int32) (Advanced) Frequency (in ms) with which the statestore sends heartbeat heartbeats to subscribers. 1000 1000 false
statestore_heartbeat_tcp_timeout_seconds (int32) (Advanced) The time after which a heartbeat RPC to a subscriber will timeout. This setting protects against badly hung machines that are not able to respond to the heartbeat RPC in short order 3 3 false
statestore_max_missed_heartbeats (int32) Maximum number of consecutive heartbeat messages an impalad can miss before being declared failed by the statestore. 10 10 false
statestore_max_subscribers (int32) Used to control the maximum size of the pending topic-update queue. There is at most one entry per subscriber. 10000 10000 false
statestore_num_heartbeat_threads (int32) (Advanced) Number of threads used to send heartbeats in parallel to all registered subscribers. 10 10 false
statestore_num_priority_update_threads (int32) (Advanced) Number of threads used to send prioritized topic updates in parallel to all registered subscribers. 10 10 false
statestore_num_update_threads (int32) (Advanced) Number of threads used to send topic updates in parallel to all registered subscribers. 10 10 false
statestore_priority_update_frequency_ms (int32) (Advanced) Frequency (in ms) with which the statestore sends prioritized topic updates to subscribers. 100 100 false
statestore_update_frequency_ms (int32) (Advanced) Frequency (in ms) with which the statestore sends topic updates to subscribers. 2000 2000 false
statestore_update_tcp_timeout_seconds (int32) (Advanced) The time after which an update RPC to a subscriber will timeout. This setting protects against badly hung machines that are not able to respond to the update RPC in short order. 300 300 false
force_lowercase_usernames (bool) If true, all principals and usernames are mapped to lowercase shortnames before being passed to any components (Ranger, admission control) for authorization false false false
sasl_connect_tcp_timeout_ms (int32) (Advanced) The underlying TSocket send/recv timeout in milliseconds for the initial SASL handeshake. 300000 300000 false
allow_ordinals_in_having (bool) If true, allow using ordinals in HAVING clause. This non-standard feature is supported in Impala 3.x and earlier. We intend to disable it since 4.0. So it defaults to be false. See IMPALA-7844. false false false
disable_kudu_bloom_runtime_filter (bool) disable bloom runtime filter for kudu. The Bloom runtime filter cannot be pushed down to Kudu due to a lack of the 'BLOOM_FILTER_PREDICATE_V2' flag in lower versions of Kudu(lower than 1.15). Therefore, a switch is set here to disable this feature for older versions of Kudu true true false
enable_column_masking (bool) If false, disable the column masking feature. Defaults to be true. true true false
enable_row_filtering (bool) If false, disable the row filtering feature. Defaults to be true. Enabling this flag requires enable_column_masking to be true. true true false
is_compatible_with_tdbs (bool) Is it compatible with Tencent TDBS? default false.Currently, it's for Bank Of China false false false
saml2_callback_token_ttl (int32) Time (in milliseconds) for which the token issued by service provider is valid. 30000 30000 false
saml2_group_attribute_name (string) The attribute name in the SAML assertion which would be used to compare for the group name matching. By default it is empty which would allow any authenticated user. If this value is set then saml2_group_filter must be set to a non-empty value. false
saml2_group_filter (string) Comma separated list of group names which will be allowed when SAML authentication is enabled. false
saml2_idp_metadata (string) IDP metadata file for the SAML configuration. This metadata file must be exported from the external identity provider. This is used to validate the SAML assertions received. Setting this is required for SAML authentication false
saml2_keystore_password_cmd (string) Command that outputs the password to the keystore used to sign the authentication requests. Setting this is required for SAML authentication. <redacted> false
saml2_keystore_path (string) Keystore path to the saml2 client. This keystore is used to store the key pair used to sign the authentication requests when saml2_sign_requests is set to true. If the path doesn't exist, HiveServer2 will attempt to create a keystore using the default configurations otherwise it will use the one provided. Setting this is required for SAML authentication. false
saml2_private_key_password_cmd (string) Command that outputs the password for the private key which is stored in the keystore pointed by saml2_keystore_path. This key is used to sign the authentication request if saml2_sign_requests is set to true. <redacted> false
saml2_sign_requests (bool) When this configuration is set to true, Impala will sign the SAML requests which can be validated by the IDP provider. false false false
saml2_sp_callback_url (string) Callback URL where SAML responses should be posted. Currently this must be configured at the same port number as the --hs2_http_port flag. false
saml2_sp_entity_id (string) Service provider entity id for this impalad. This must match with the SP id on the external identity provider. If this is not set, saml2_sp_callback_url will be used as the SP id. false
saml2_want_assertations_signed (bool) When this configuration is set to true, Impala will validate the signature of the assertions received at the callback url. 'False' should be only used for testing as it makes the protocol unsecure. true true false
num_cores (int32) (Advanced) If > 0, it sets the number of cores available to Impala. Setting it to 0 means Impala will use all available cores on the machine according to /proc/cpuinfo. 0 0 false
web_log_bytes (int64) The maximum number of bytes to display on the debug webserver's log page 1048576 1048576 false
pmetric_bucket_boundaries (string) The bucket boundaries of the histogram in pmetrics. The number is separated by ',',can be empty string, in this time, it is default value: '5000, 20000, 30000, 60000, 120000, 180000, 300000, 600000, 1200000' false
jvm_deadlock_detector_interval_s (int64) (Advanced) Interval between JVM deadlock checks. If set to 0 or a negative value, deadlock checks are disabled. 60 60 false
ldap_group_search_basedn (string) The 'distinguished name' DN that will be used to search for the authenticating group. If left empty, group checks will not be performed. false
ldap_user_search_basedn (string) The 'distinguished name' DN that will be used to search for the authenticating user, this field is required for search bind authentication. false
ldap_baseDN (string) If set, Impala will try to bind to LDAP with a name of the form uid=<userid>,<ldap_baseDN> false
ldap_bind_pattern (string) If set, Impala will try to bind to LDAP with a name of <ldap_bind_pattern>, but where the string #UID is replaced by the user ID. Use to control the bind name precisely; do not set --ldap_domain or --ldap_baseDN with this option false
ldap_domain (string) If set, Impala will try to bind to LDAP with a name of the form <userid>@<ldap_domain> false
ldap_group_class_key (string) The LDAP objectClass each of the groups in --ldap_group_filter implements in LDAP. groupOfNames groupOfNames false
ldap_group_dn_pattern (string) Colon separated list of patterns for the 'distinguished name' used to search for groups in the directory. Each pattern may contain a '%s' which will be substituted with each group name from --ldap_group_filter when doing group searches. false
ldap_group_membership_key (string) The LDAP attribute on group entries that indicates its members. member member false
ldap_allow_anonymous_binds (bool) (Advanced) If true, LDAP authentication with a blank password (an 'anonymous bind') is allowed by Impala. false false false
ldap_bind_dn (string) Distinguished name of the user to bind as when doing user or group searches. Only required if user or group filters are being used and the LDAP server is not configured to allow anonymous searches. false
ldap_bind_password_cmd (string) A Unix command whose output returns the password to use with --ldap_bind_dn. The output of the command will be truncated to 1024 bytes and trimmed of trailing whitespace. <redacted> false
ldap_passwords_in_clear_ok (bool) If set, will allow LDAP passwords to be sent in the clear (without TLS/SSL) over the network. This option should not be used in production environments false false false
ldap_search_bind_authentication (bool) If set to true, LDAP search bind authentication will be used instead of the default simple bind. false false false
ldap_tls (bool) If true, use the secure TLS protocol to connect to the LDAP server false false false
ldap_uri (string) The URI of the LDAP server to authenticate users against false
non_impala_java_vlog (int32) (Advanced) The log level (equivalent to --v) for non-Impala Java classes (0: INFO, 1 and 2: DEBUG, 3: TRACE) 0 0 false
disable_parquetbloomfilter_avx2 (bool) Disable AVX2 operations in ParquetBloomFilter. This flag has no effect if the target CPU doesn't support AVX2 at run-time or ParquetBloomFilter was built with a compiler that doesn't support AVX2. false false false
periodic_counter_update_period_ms (int32) Period to update rate counters and sampling counters in ms 500 500 false
disable_content_security_policy_header (bool) If true then the webserver will not add the Content-Security-Policy HTTP header to HTTP responses false false false
enable_webserver_doc_root (bool) If true, webserver may serve static files from the webserver_doc_root true true false
webserver_authentication_domain (string) Domain used for debug webserver authentication false
webserver_certificate_file (string) The location of the debug webserver's SSL certificate file, in .pem format. If empty, webserver SSL support is not enabled false
webserver_doc_root (string) Files under <webserver_doc_root>/www are accessible via the debug webserver. Defaults to $IMPALA_HOME, or if $IMPALA_HOME is not set, disables the document root /data/cloudera/parcels/IMPALA_SENSORS_DATA-4.0.0.3861-cdh5.12.1.p0/lib/impala /data/cloudera/parcels/IMPALA_SENSORS_DATA-4.0.0.3861-cdh5.12.1.p0/lib/impala false
webserver_interface (string) Interface to start debug webserver on. If blank, webserver binds to 0.0.0.0 false
webserver_ldap_group_filter (string) Used as filter for both simple and search bind mechanisms for the webserver authentication. For simple bind it is a comma separated list of groups. If specified, users must belong to one of these groups for authentication to succeed. For search bind it is an LDAP filter that will be used during LDAP group search, it can contain '{0}' pattern which will be replaced with the user name and/or '{1}' which will be replace with the user dn. false
webserver_ldap_passwords_in_clear_ok (bool) (Advanced) If true, allows the webserver to start with LDAP authentication even if SSL is not enabled, a potentially insecure configuration. false false false
webserver_ldap_user_filter (string) Used as filter for both simple and search bind mechanisms for the webserver authentication. For simple bind it is a comma separated list of user names. If specified, users must be on this list for authentication to succeed. For search bind it is an LDAP filter that will be used during LDAP search, it can contain '{0}' pattern which will be replaced with the user name. false
webserver_max_post_length_bytes (int32) The maximum length of a POST request that will be accepted by the embedded web server. 1048576 1048576 false
webserver_password_file (string) (Optional) Location of .htpasswd file containing user names and hashed passwords for debug webserver authentication. Cannot be used with --webserver_require_ldap or --webserver_require_spnego. false
webserver_port (int32) Port to start debug webserver on 25000 25010 false
webserver_private_key_file (string) The full path to the private key used as a counterpart to the public key contained in --webserver_certificate_file. If --webserver_certificate_file is set, this option must be set as well. false
webserver_private_key_password_cmd (string) A Unix command whose output returns the password used to decrypt the Webserver's certificate private key file specified in --webserver_private_key_file. If the .PEM key file is not password-protected, this command will not be invoked. The output of the command will be truncated to 1024 bytes, and then all trailing whitespace will be trimmed before it is used to decrypt the private key false
webserver_require_ldap (bool) Require connections to the web server to authenticate via LDAP using HTTP Basic authentication. Cannot be used with --webserver_require_spnego or --webserver_password_file. false false false
webserver_require_spnego (bool) Require connections to the web server to authenticate via Kerberos using SPNEGO. Cannot be used with --webserver_require_ldap or --webserver_password_file. false false false
webserver_x_frame_options (string) webserver will add X-Frame-Options HTTP header with this value DENY DENY false
flagfile (string) load flags from file /run/cloudera-scm-agent/process/5376-impala-STATESTORE/impala-conf/state_store_flags false
fromenv (string) set flags from the environment [use 'export FLAGS_flag1=value'] false
tryfromenv (string) set flags from the environment if present false
undefok (string) comma-separated list of flag names that it is okay to specify on the command line even if the program does not define a flag with that name. IMPORTANT: flags in this list that have arguments MUST use the flag=value format false
tab_completion_columns (int32) Number of columns to use in output for tab completion 80 80 false
tab_completion_word (string) If non-empty, HandleCommandLineCompletions() will hijack the process and attempt to do bash-style command line flag completion on this value. false
help (bool) show help on all flags [tip: all flags can have two dashes] false false false
helpfull (bool) show help on all flags -- same as -help false false false
helpmatch (string) show help on modules whose name contains the specified substr false
helpon (string) show help on the modules named by this flag value false
helppackage (bool) show help on all modules in the main package false false false
helpshort (bool) show help on only the main module for this program false false false
helpxml (bool) produce an xml version of help false false false
version (bool) show version and build info and exit false false false
alsologtoemail (string) log messages go to these email addresses in addition to logfiles false
alsologtostderr (bool) log messages go to stderr in addition to logfiles false false false
colorlogtostderr (bool) color messages logged to stderr (if supported by terminal) false false false
drop_log_memory (bool) Drop in-memory buffers of log contents. Logs can grow very quickly and they are rarely read before they need to be evicted from memory. Instead, drop them from memory as soon as they are flushed to disk. true true false
log_backtrace_at (string) Emit a backtrace when logging at file:linenum. false
log_dir (string) If specified, logfiles are written into this directory instead of the default logging directory. /data/sa_cluster/cloudera/logs/statestore /data/sa_cluster/cloudera/logs/statestore false
log_link (string) Put additional links to the log files in this directory false
log_prefix (bool) Prepend the log prefix to the start of each log line true true false
logbuflevel (int32) Buffer log messages logged at this level or lower (-1 means don't buffer; 0 means buffer INFO only; ...) 0 0 false
logbufsecs (int32) Buffer log messages for at most this many seconds 30 30 false
logemaillevel (int32) Email log messages logged at this level or higher (0 means email all; 3 means email FATAL only; ...) 999 999 false
logfile_mode (int32) Log file mode/permissions. 436 436 false
logmailer (string) Mailer used to send logging email /bin/mail /bin/mail false
logtostderr (bool) log messages go to stderr instead of logfiles false false false
max_log_size (int32) approx. maximum log file size (in MB). A value of 0 will be silently overridden to 1. 10 10 false
minloglevel (int32) Messages logged at a lower level than this don't actually get logged anywhere 0 0 false
stderrthreshold (int32) log messages at or above this level are copied to stderr in addition to logfiles. This flag obsoletes --alsologtostderr. 2 4 false
stop_logging_if_full_disk (bool) Stop attempting to log to disk if the disk is full. false false false
symbolize_stacktrace (bool) Symbolize the stack trace in the tombstone true false false
v (int32) Show all VLOG(m) messages for m <= this. Overridable by --vmodule. 1 1 false
vmodule (string) per-module verbose level. Argument is a comma-separated list of <module name>=<log level>. <module name> is a glob pattern, matched against the filename base (that is, name ignoring .cc/.h./-inl.h). <log level> overrides any value given by --v. false