- g -
- g_allow_auto_resultset_caching
: Execute.cpp
, CommandLineOptions.h
- g_allow_cpu_retry
: CommandLineOptions.h
, Execute.cpp
- g_allow_invalid_literal_buffer_reads
: ConstantIR.cpp
, CommandLineOptions.h
- g_allow_memory_status_log
: Execute.cpp
, CommandLineOptions.cpp
, CommandLineOptions.h
, DBHandler.cpp
, RowSetMemoryOwner.h
- g_allow_query_step_cpu_retry
: Execute.cpp
, CommandLineOptions.h
- g_allow_query_step_skipping
: Execute.cpp
, CommandLineOptions.h
- g_allow_s3_server_privileges
: S3Archive.cpp
, CommandLineOptions.h
- g_allow_system_dashboard_update
: CommandLineOptions.cpp
, DBHandler.cpp
- g_approx_quantile_buffer
: Execute.cpp
, GroupByAndAggregate.cpp
, CommandLineOptions.cpp
- g_approx_quantile_centroids
: Execute.cpp
, GroupByAndAggregate.cpp
, CommandLineOptions.cpp
- g_archive_read_buf_size
: PosixFileArchive.h
, Importer.cpp
- g_auto_resultset_caching_threshold
: Execute.cpp
, CommandLineOptions.h
- g_base_path
: TableArchiver.cpp
, SysCatalog.cpp
, SysCatalog.h
- g_bbox_intersect_max_table_size_bytes
: Execute.cpp
, CommandLineOptions.h
- g_bbox_intersect_target_entries_per_bin
: Execute.cpp
, CommandLineOptions.h
- g_big_group_threshold
: Execute.cpp
, CommandLineOptions.h
- g_bigint_count
: CalciteDeserializerUtils.cpp
, ColSlotContext.cpp
, GroupByAndAggregate.cpp
, GroupByAndAggregate.h
, OutputBufferInitialization.cpp
, ResultSetRecyclerHolder.cpp
, CommandLineOptions.h
- g_bitmap_memory_limit
: GroupByAndAggregate.cpp
, InValuesBitmap.cpp
, QueryMemoryInitializer.cpp
, CommandLineOptions.cpp
- g_bump_allocator_step_reduction
: Execute.cpp
, GpuMemUtils.cpp
, CommandLineOptions.h
- g_cache_string_hash
: Catalog.cpp
, Execute.cpp
, StringDictionary.cpp
, CommandLineOptions.cpp
- g_cluster
: QueryMemoryDescriptor.h
, RelAlgDag.cpp
, distributed.h
, TableArchiver.cpp
- g_code_cache_max_num_items
: QueryEngine.h
- g_columnar_large_projections
: RelAlgExecutor.cpp
, CommandLineOptions.cpp
- g_columnar_large_projections_threshold
: RelAlgExecutor.cpp
, CommandLineOptions.cpp
- g_compression_limit_bytes
: Compressor.cpp
, CommandLineOptions.h
- g_constrained_by_in_threshold
: Execute.cpp
, CommandLineOptions.h
- g_cpu_sub_task_size
: Execute.cpp
, CommandLineOptions.h
- g_cpu_threads_override
: thread_count.cpp
, thread_count.h
, CommandLineOptions.h
- g_default_max_groups_buffer_entry_guess
: Execute.cpp
, GroupByAndAggregate.cpp
, RelAlgExecutor.cpp
- g_detect_test_sample_size
: Importer.cpp
- g_distributed_leaf_idx
: Catalog.cpp
, distributed.h
- g_distributed_num_leaves
: Catalog.cpp
, distributed.h
- g_dynamic_watchdog_time_limit
: Execute.cpp
, CommandLineOptions.h
- g_enable_add_metadata_columns
: ParserNode.cpp
, CommandLineOptions.h
- g_enable_auto_metadata_update
: UpdelStorage.cpp
, ExecuteUpdate.cpp
, StorageIOFacility.h
, CommandLineOptions.h
- g_enable_automatic_ir_metadata
: AutomaticIRMetadataGuard.h
, Execute.cpp
, CommandLineOptions.h
- g_enable_bbox_intersect_hashjoin
: Execute.cpp
, HashJoin.cpp
, CommandLineOptions.h
- g_enable_bump_allocator
: Execute.cpp
, RelAlgExecutor.cpp
, CommandLineOptions.h
- g_enable_calcite_view_optimize
: QueryRunner.cpp
- g_enable_columnar_output
: QueryMemoryDescriptor.cpp
, Execute.cpp
, CommandLineOptions.h
- g_enable_cpu_sub_tasks
: Execute.cpp
, CommandLineOptions.h
- g_enable_data_recycler
: Execute.cpp
, InputMetadata.cpp
, CommandLineOptions.h
- g_enable_debug_timer
: Logger.cpp
, Logger.h
, measure.h
- g_enable_dev_table_functions
: Execute.cpp
, TableFunctionsFactory.cpp
, CommandLineOptions.h
- g_enable_direct_columnarization
: Execute.cpp
, CommandLineOptions.h
- g_enable_distance_rangejoin
: Execute.cpp
, CommandLineOptions.h
- g_enable_dynamic_watchdog
: Execute.cpp
, ResultSetReduction.cpp
, CommandLineOptions.h
- g_enable_executor_resource_mgr
: Execute.cpp
, CommandLineOptions.h
- g_enable_filter_function
: Execute.cpp
, CommandLineOptions.h
- g_enable_filter_push_down
: QueryRunner.cpp
, CommandLineOptions.h
, Execute.cpp
, JoinFilterPushDown.h
- g_enable_foreign_table_scheduled_refresh
: HeavyDB.cpp
, CommandLineOptions.cpp
, ForeignTableRefreshScheduler.cpp
- g_enable_fsi
: Catalog.cpp
, DdlCommandExecutor.cpp
, SysCatalog.cpp
, DataMgr.cpp
, ForeignStorageMgr.cpp
, HeavyDB.cpp
, ParserNode.cpp
, CommandLineOptions.h
- g_enable_fsi_regex_import
: ForeignDataImporter.cpp
, ParserNode.cpp
, CommandLineOptions.h
- g_enable_geo_ops_on_uncompressed_coords
: Execute.cpp
, RelAlgTranslatorGeo.cpp
, CommandLineOptions.h
- g_enable_hashjoin_many_to_many
: Execute.cpp
, CommandLineOptions.h
- g_enable_http_binary_server
: HeavyDB.cpp
, CommandLineOptions.cpp
- g_enable_idp_temporary_users
: SysCatalog.cpp
, CommandLineOptions.cpp
- g_enable_interop
: RelAlgExecutor.cpp
, CommandLineOptions.h
- g_enable_lazy_fetch
: Execute.cpp
, CommandLineOptions.h
- g_enable_left_join_filter_hoisting
: Execute.cpp
, IRCodegen.cpp
, CommandLineOptions.cpp
- g_enable_legacy_delimited_import
: ForeignDataImporter.cpp
, ParserNode.cpp
, CommandLineOptions.h
- g_enable_logs_system_tables
: Catalog.cpp
, CommandLineOptions.cpp
- g_enable_logs_system_tables_auto_refresh
: Catalog.cpp
, CommandLineOptions.cpp
- g_enable_ml_functions
: DdlCommandExecutor.cpp
, ParserNode.cpp
, Execute.cpp
, TableFunctionsFactory.cpp
, CommandLineOptions.h
- g_enable_non_kernel_time_query_interrupt
: Execute.cpp
, CommandLineOptions.h
- g_enable_parallel_linearization
: Execute.cpp
, CommandLineOptions.h
- g_enable_parallel_window_partition_compute
: WindowContext.cpp
, CommandLineOptions.h
- g_enable_parallel_window_partition_sort
: WindowContext.cpp
, CommandLineOptions.h
- g_enable_rf_prop_table_functions
: Execute.cpp
- g_enable_runtime_query_interrupt
: Execute.cpp
, CommandLineOptions.h
- g_enable_s3_fsi
: Catalog.cpp
, AbstractFileStorageDataWrapper.cpp
, ForeignStorageMgr.cpp
, CommandLineOptions.h
- g_enable_seconds_refresh
: ForeignTable.cpp
, CommandLineOptions.cpp
- g_enable_smem_group_by
: Execute.cpp
, GroupByAndAggregate.h
- g_enable_smem_grouped_non_count_agg
: Execute.cpp
, CommandLineOptions.h
- g_enable_smem_non_grouped_agg
: Execute.cpp
, CommandLineOptions.h
- g_enable_string_functions
: Analyzer.h
, UpdelStorage.cpp
, ParserNode.cpp
, Execute.cpp
, RelAlgTranslator.cpp
, CommandLineOptions.h
- g_enable_stringdict_parallel
: StringDictionary.cpp
, StringDictionary.h
- g_enable_system_tables
: Catalog.cpp
, SysCatalog.cpp
, RelAlgExecutor.cpp
, CommandLineOptions.cpp
, DBHandler.cpp
- g_enable_table_functions
: Execute.cpp
, TableFunctionsFactory.cpp
, CommandLineOptions.h
- g_enable_thrift_logs
: DBEngine.cpp
, HeavyDB.cpp
, initdb.cpp
, CommandLineOptions.cpp
- g_enable_union
: DBEngine.cpp
, RelAlgDag.cpp
, RelAlgExecutor.cpp
, CommandLineOptions.h
- g_enable_watchdog
: RelAlgExecutor.cpp
, RelAlgTranslator.cpp
, CommandLineOptions.h
- g_enable_window_functions
: CommandLineOptions.h
, Execute.cpp
- g_estimator_failure_max_groupby_size
: RelAlgExecutor.cpp
, CommandLineOptions.cpp
- g_executor_resource_mgr_allow_cpu_gpu_kernel_concurrency
: Execute.cpp
, CommandLineOptions.h
- g_executor_resource_mgr_allow_cpu_kernel_concurrency
: Execute.cpp
, CommandLineOptions.h
- g_executor_resource_mgr_allow_cpu_result_mem_oversubscription_concurrency
: CommandLineOptions.h
, Execute.cpp
- g_executor_resource_mgr_allow_cpu_slot_oversubscription_concurrency
: Execute.cpp
, CommandLineOptions.h
- g_executor_resource_mgr_cpu_result_mem_bytes
: CommandLineOptions.h
, Execute.cpp
- g_executor_resource_mgr_cpu_result_mem_ratio
: Execute.cpp
, CommandLineOptions.h
- g_executor_resource_mgr_max_available_resource_use_ratio
: CommandLineOptions.h
, Execute.cpp
- g_executor_resource_mgr_per_query_max_cpu_result_mem_ratio
: Execute.cpp
, CommandLineOptions.h
- g_executor_resource_mgr_per_query_max_cpu_slots_ratio
: Execute.cpp
, CommandLineOptions.h
- g_filter_push_down_high_frac
: Execute.cpp
, JoinFilterPushDown.h
, CommandLineOptions.h
- g_filter_push_down_low_frac
: Execute.cpp
, JoinFilterPushDown.h
, CommandLineOptions.h
- g_filter_push_down_passing_row_ubound
: JoinFilterPushDown.h
, Execute.cpp
, CommandLineOptions.h
- g_fraction_code_cache_to_evict
: NativeCodegen.cpp
, CommandLineOptions.cpp
- g_from_table_reordering
: Execute.cpp
, CommandLineOptions.h
, CompilationOptions.h
- g_gpu_code_cache_max_size_in_bytes
: QueryEngine.h
, CommandLineOptions.cpp
- g_gpu_mem_limit_percent
: QueryRunner.cpp
- g_gpu_smem_threshold
: Execute.cpp
, CommandLineOptions.h
- g_hashtable_cache_total_bytes
: CommandLineOptions.h
, Execute.cpp
- g_hll_precision_bits
: GroupByAndAggregate.cpp
, HyperLogLog.h
- g_in_clause_num_elem_skip_bitmap
: RelAlgTranslator.cpp
, CommandLineOptions.h
, Execute.cpp
- g_inner_join_fragment_skipping
: Execute.cpp
, CommandLineOptions.h
- g_is_test_env
: Execute.cpp
, CodeCacheAccessor.h
, HashtableRecycler.cpp
, ResultSetRecycler.cpp
, PerfectJoinHashTable.cpp
, QueryPlanDagExtractor.cpp
- g_large_ndv_multiplier
: CardinalityEstimator.cpp
, CommandLineOptions.cpp
- g_large_ndv_threshold
: CardinalityEstimator.cpp
, CommandLineOptions.cpp
- g_leaf_count
: GroupByAndAggregate.cpp
, ParserNode.cpp
, QueryRunner.cpp
, CommandLineOptions.h
- g_lockfile_lock_extension_milliseconds
: heavyai_locks.h
, CommandLineOptions.h
- g_logs_system_tables_max_files_count
: InternalLogsDataWrapper.cpp
, CommandLineOptions.cpp
- g_logs_system_tables_refresh_interval
: Catalog.cpp
, CommandLineOptions.cpp
- g_max_cacheable_hashtable_size_bytes
: Execute.cpp
, CommandLineOptions.h
- g_max_cacheable_query_resultset_size_bytes
: Execute.cpp
, CommandLineOptions.h
- g_max_import_threads
: thread_count.h
, LazyParquetChunkLoader.h
, Importer.cpp
, CommandLineOptions.h
- g_max_log_length
: Execute.cpp
, CommandLineOptions.h
- g_max_memory_allocation_size
: CommandLineOptions.h
, Execute.cpp
, GpuMemUtils.cpp
- g_maximum_conditions_to_coalesce
: HashJoinRuntime.h
- g_min_memory_allocation_size
: Execute.cpp
, CommandLineOptions.h
, GpuMemUtils.cpp
- g_ml_models
: MLModel.h
- g_multi_instance
: MigrationMgr.cpp
, CommandLineOptions.h
, FileInfo.cpp
, heavyai_locks.h
, FileMgr.cpp
- g_ndv_groups_estimator_multiplier
: CommandLineOptions.cpp
, RelAlgExecutor.cpp
- g_null_div_by_zero
: CommandLineOptions.h
, Execute.cpp
- g_num_tuple_threshold_switch_to_baseline
: HashJoin.cpp
, CommandLineOptions.h
, Execute.cpp
- g_omni_kafka_seek
: CommandLineOptions.h
- g_optimize_cuda_block_and_grid_sizes
: CommandLineOptions.h
, Execute.cpp
- g_optimize_row_initialization
: Execute.cpp
, CommandLineOptions.h
- g_parallel_top_max
: CommandLineOptions.cpp
, ResultSet.cpp
- g_parallel_top_min
: CommandLineOptions.cpp
, ResultSet.cpp
- g_parallel_window_partition_compute_threshold
: WindowContext.cpp
- g_parallel_window_partition_sort_threshold
: WindowContext.cpp
- g_pending_query_interrupt_freq
: CommandLineOptions.h
, Execute.cpp
- g_pmem_path
: PMemAllocator.cpp
- g_pmem_size
: PMemAllocator.cpp
- g_preflight_count_query_threshold
: Execute.cpp
, RelAlgExecutor.cpp
, CommandLineOptions.h
- g_query_engine_cuda_streams
: CommandLineOptions.h
, QueryEngine.h
- g_query_resultset_cache_total_bytes
: CommandLineOptions.h
, Execute.cpp
- g_ratio_num_hash_entry_to_num_tuple_switch_to_baseline
: Execute.cpp
, CommandLineOptions.h
, HashJoin.cpp
- g_read_only
: heavyai_locks.h
, SysCatalog.cpp
, FileMgr.cpp
, FileInfo.cpp
, CommandLineOptions.h
- g_restrict_ml_model_metadata_to_superusers
: CommandLineOptions.h
, DdlCommandExecutor.cpp
, Execute.cpp
- g_running
: HeavyDB.cpp
- g_running_query_interrupt_freq
: CommandLineOptions.h
, Execute.cpp
- g_serialize_temp_tables
: QueryRunner.cpp
, DBEngine.cpp
, Catalog.cpp
- g_skip_intermediate_count
: RelAlgExecutor.cpp
, CommandLineOptions.h
, RelAlgExecutor.h
- g_streaming_topn_max
: CommandLineOptions.cpp
, QueryMemoryDescriptor.cpp
, ResultSet.cpp
- g_strip_join_covered_quals
: CommandLineOptions.h
, Execute.cpp
- g_test_drop_column_rollback
: ParserNode.cpp
- g_test_rollback_dump_restore
: TableArchiver.cpp
- g_trivial_loop_join_threshold
: CommandLineOptions.h
, Execute.cpp
- g_uniform_request_ids_per_thrift_call
: DBHandler.cpp
, CommandLineOptions.cpp
- g_use_chunk_metadata_cache
: CommandLineOptions.h
, InputMetadata.cpp
, Execute.cpp
- g_use_cpu_mem_pool_for_output_buffers
: RowSetMemoryOwner.h
, Execute.cpp
, CommandLineOptions.cpp
- g_use_cpu_mem_pool_size_for_max_cpu_slab_size
: CommandLineOptions.cpp
, DataMgr.cpp
- g_use_date_in_days_default_encoding
: DdlUtils.cpp
- g_use_estimator_result_cache
: CommandLineOptions.h
, Execute.cpp
- g_use_hashtable_cache
: Execute.cpp
, CommandLineOptions.h
- g_use_query_resultset_cache
: Execute.cpp
, CommandLineOptions.h
- g_use_table_device_offset
: InsertOrderFragmenter.cpp
, CommandLineOptions.cpp
- g_vacuum_min_selectivity
: CommandLineOptions.h
, TableOptimizer.cpp
- g_value_id
: ResultSetReductionOps.h
, ResultSetReductionInterpreter.cpp
- g_watchdog_baseline_max_groups
: GroupByAndAggregate.cpp
- g_watchdog_in_clause_max_num_elem_bitmap
: RelAlgTranslator.cpp
, Execute.cpp
, CommandLineOptions.h
- g_watchdog_in_clause_max_num_elem_non_bitmap
: RelAlgTranslator.cpp
, Execute.cpp
, CommandLineOptions.h
- g_watchdog_in_clause_max_num_input_rows
: Execute.cpp
, RelAlgTranslator.cpp
, CommandLineOptions.h
- g_watchdog_in_subquery_max_in_values
: CommandLineOptions.h
- g_watchdog_max_projected_rows_per_device
: CommandLineOptions.h
, Execute.cpp
- g_watchdog_none_encoded_string_translation_limit
: RelAlgExecutor.cpp
, Execute.cpp
, CommandLineOptions.h
- g_window_function_aggregation_tree_fanout
: WindowContext.cpp
, CommandLineOptions.h