OmniSciDB
a5dc49c757
|
#include <blosc.h>
#include <cstddef>
#include <boost/algorithm/string.hpp>
#include <boost/algorithm/string/trim.hpp>
#include <boost/filesystem.hpp>
#include <boost/locale/generator.hpp>
#include <boost/make_shared.hpp>
#include <boost/program_options.hpp>
#include "Catalog/AuthMetadata.h"
#include "DataMgr/ForeignStorage/ForeignStorageCache.h"
#include "OSDependent/heavyai_locks.h"
#include "QueryEngine/ExtractFromTime.h"
#include "QueryEngine/HyperLogLog.h"
#include "Shared/SystemParameters.h"
Go to the source code of this file.
Classes | |
class | CommandLineOptions |
bool g_allow_auto_resultset_caching |
Definition at line 162 of file Execute.cpp.
Referenced by QueryRunner::DataRecyclerFlagsDisabler::DataRecyclerFlagsDisabler(), RelAlgExecutor::executeTableFunction(), RelAlgExecutor::executeWorkUnit(), CommandLineOptions::fillOptions(), CommandLineOptions::parse_command_line(), and QueryRunner::DataRecyclerFlagsDisabler::~DataRecyclerFlagsDisabler().
bool g_allow_cpu_retry |
Definition at line 93 of file Execute.cpp.
Referenced by RelAlgExecutor::executeRelAlgQuery(), CommandLineOptions::fillOptions(), and RelAlgExecutor::handlePersistentError().
bool g_allow_invalid_literal_buffer_reads |
Definition at line 140 of file ConstantIR.cpp.
Referenced by CodeGenerator::codegenHoistedConstantsLoads(), CommandLineOptions::fillDeveloperOptions(), and CommandLineOptions::validate().
bool g_allow_memory_status_log |
Definition at line 127 of file Execute.cpp.
bool g_allow_query_step_cpu_retry |
Definition at line 94 of file Execute.cpp.
Referenced by RelAlgExecutor::executeRelAlgSeq(), RelAlgExecutor::executeRelAlgSubSeq(), and CommandLineOptions::fillDeveloperOptions().
bool g_allow_query_step_skipping |
Definition at line 163 of file Execute.cpp.
Referenced by QueryRunner::DataRecyclerFlagsDisabler::DataRecyclerFlagsDisabler(), RelAlgExecutor::executeRelAlgSeq(), CommandLineOptions::fillOptions(), RaExecutionSequence::next(), CommandLineOptions::parse_command_line(), RaExecutionSequence::RaExecutionSequence(), and QueryRunner::DataRecyclerFlagsDisabler::~DataRecyclerFlagsDisabler().
bool g_allow_s3_server_privileges |
Definition at line 34 of file S3Archive.cpp.
Referenced by DBHandler::thrift_to_copyparams().
size_t g_auto_resultset_caching_threshold |
Definition at line 168 of file Execute.cpp.
Referenced by RelAlgExecutor::executeTableFunction(), RelAlgExecutor::executeWorkUnit(), CommandLineOptions::fillOptions(), and CommandLineOptions::parse_command_line().
size_t g_bbox_intersect_max_table_size_bytes |
Definition at line 114 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), and BoundingBoxIntersectJoinHashTable::reifyWithLayout().
double g_bbox_intersect_target_entries_per_bin |
Definition at line 115 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), and BoundingBoxIntersectJoinHashTable::reifyWithLayout().
size_t g_big_group_threshold |
Definition at line 119 of file Execute.cpp.
Referenced by RelAlgExecutor::executeWorkUnit().
bool g_bigint_count |
Definition at line 54 of file GroupByAndAggregate.cpp.
double g_bump_allocator_step_reduction |
Definition at line 133 of file Execute.cpp.
Referenced by create_dev_group_by_buffers().
size_t g_compression_limit_bytes |
Definition at line 35 of file Compressor.cpp.
size_t g_constrained_by_in_threshold |
Definition at line 117 of file Execute.cpp.
Referenced by QueryRewriter::rewriteConstrainedByInImpl().
size_t g_cpu_sub_task_size |
Definition at line 90 of file Execute.cpp.
Referenced by CommandLineOptions::fillDeveloperOptions(), and ExecutionKernel::runImpl().
unsigned g_cpu_threads_override |
Definition at line 19 of file thread_count.cpp.
Referenced by cpu_threads(), CommandLineOptions::fillDeveloperOptions(), and DBHandler::init_executor_resource_mgr().
unsigned g_dynamic_watchdog_time_limit |
Definition at line 92 of file Execute.cpp.
Referenced by DBHandler::execute_rel_alg(), QueryExecutionContext::launchGpuCode(), and CommandLineOptions::parse_command_line().
bool g_enable_add_metadata_columns |
Definition at line 90 of file ParserNode.cpp.
Referenced by CommandLineOptions::fillOptions(), and Parser::anonymous_namespace{ParserNode.cpp}::parse_copy_params().
bool g_enable_auto_metadata_update |
Definition at line 38 of file UpdelStorage.cpp.
Referenced by Executor::executeUpdate(), CommandLineOptions::fillDeveloperOptions(), and anonymous_namespace{StorageIOFacility.h}::should_recompute_metadata().
bool g_enable_automatic_ir_metadata |
Definition at line 174 of file Execute.cpp.
bool g_enable_bbox_intersect_hashjoin |
Definition at line 109 of file Execute.cpp.
Referenced by Executor::buildHashTableForQualifier(), CodeGenerator::codegenBoundingBoxIntersect(), convert_bbox_intersect_join(), CommandLineOptions::fillOptions(), and HashJoin::getInstance().
bool g_enable_bump_allocator |
Definition at line 132 of file Execute.cpp.
Referenced by anonymous_namespace{RelAlgExecutor.cpp}::can_use_bump_allocator(), and CommandLineOptions::fillDeveloperOptions().
bool g_enable_columnar_output |
Definition at line 106 of file Execute.cpp.
bool g_enable_cpu_sub_tasks |
Definition at line 89 of file Execute.cpp.
Referenced by CommandLineOptions::fillDeveloperOptions(), and Executor::launchKernelsImpl().
bool g_enable_data_recycler |
Definition at line 158 of file Execute.cpp.
Referenced by HashJoin::canAccessHashTable(), RelAlgExecutor::canUseResultsetCache(), Fragmenter_Namespace::FragmentInfo::getChunkMetadataMap(), BoundingBoxIntersectTuningParamRecycler::getItemFromCache(), ResultSetRecycler::getOutputMetaInfo(), anonymous_namespace{RelAlgExecutor.cpp}::handle_query_hint(), HashingSchemeRecycler::hasItemInCache(), BoundingBoxIntersectTuningParamRecycler::hasItemInCache(), ChunkMetadataRecycler::hasItemInCache(), ResultSetRecycler::hasItemInCache(), HashtableRecycler::hasItemInCache(), HashingSchemeRecycler::markCachedItemAsDirty(), BoundingBoxIntersectTuningParamRecycler::markCachedItemAsDirty(), ChunkMetadataRecycler::markCachedItemAsDirty(), ResultSetRecycler::markCachedItemAsDirty(), HashtableRecycler::markCachedItemAsDirty(), CommandLineOptions::parse_command_line(), HashingSchemeRecycler::putItemToCache(), BoundingBoxIntersectTuningParamRecycler::putItemToCache(), ChunkMetadataRecycler::putItemToCache(), ResultSetRecycler::putItemToCache(), HashtableRecycler::putItemToCache(), RaExecutionSequence::RaExecutionSequence(), RelAlgDag::registerQueryHints(), ResultSetRecycler::removeItemFromCache(), and HashtableRecycler::removeItemFromCache().
bool g_enable_dev_table_functions |
Definition at line 124 of file Execute.cpp.
Referenced by table_functions::TableFunctionsFactory::add(), and CommandLineOptions::fillDeveloperOptions().
bool g_enable_direct_columnarization |
Definition at line 134 of file Execute.cpp.
Referenced by CommandLineOptions::fillDeveloperOptions(), and ResultSet::isDirectColumnarConversionPossible().
bool g_enable_distance_rangejoin |
Definition at line 112 of file Execute.cpp.
Referenced by convert_bbox_intersect_join(), and CommandLineOptions::fillOptions().
bool g_enable_dynamic_watchdog |
Definition at line 81 of file Execute.cpp.
Referenced by Executor::buildHashTableForQualifier(), check_watchdog_rt(), DBHandler::execute_rel_alg(), Executor::executePlanWithGroupBy(), Executor::executePlanWithoutGroupBy(), RelAlgExecutor::executeRelAlgQueryNoRetry(), Executor::fetchChunks(), anonymous_namespace{ResultSetReductionJIT.cpp}::generate_loop_body(), DBHandler::interrupt(), Executor::interrupt(), QueryExecutionContext::launchGpuCode(), CommandLineOptions::parse_command_line(), RelAlgExecutor::prepareLeafExecution(), ResultSetStorage::reduceEntriesNoCollisionsColWise(), ResultSetStorage::reduceOneEntryBaseline(), RelAlgDag::registerQueryHints(), and Executor::resetInterrupt().
bool g_enable_executor_resource_mgr |
Definition at line 178 of file Execute.cpp.
Referenced by Executor::executeWorkUnitImpl(), CommandLineOptions::fillOptions(), Executor::get_concurrent_resource_grant_policy(), Executor::get_executor_resource_pool_info(), Executor::get_executor_resource_pool_total_resource_quantity(), DBHandler::initialize(), CommandLineOptions::parse_command_line(), anonymous_namespace{DBHandler.cpp}::pause_and_resume_executor_queue(), Executor::pause_executor_queue(), QueryRunner::QueryRunner::QueryRunner(), Executor::resume_executor_queue(), Executor::set_concurrent_resource_grant_policy(), Executor::set_executor_resource_pool_resource(), and CommandLineOptions::validate().
bool g_enable_filter_function |
Definition at line 91 of file Execute.cpp.
Referenced by CommandLineOptions::fillDeveloperOptions().
bool g_enable_filter_push_down |
Definition at line 102 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), Fragmenter_Namespace::FragmentInfo::getChunkMetadataMap(), CommandLineOptions::parse_command_line(), QueryRunner::QueryRunner::runSelectQuery(), and DBHandler::sql_execute_impl().
bool g_enable_fsi |
Definition at line 96 of file Catalog.cpp.
Referenced by AlterForeignServerCommand::AlterForeignServerCommand(), AlterForeignTableCommand::AlterForeignTableCommand(), Catalog_Namespace::Catalog::buildForeignServerMapUnlocked(), Catalog_Namespace::Catalog::buildMaps(), Catalog_Namespace::Catalog::CheckAndExecuteMigrations(), Catalog_Namespace::SysCatalog::createDatabase(), Catalog_Namespace::Catalog::createDefaultServersIfNotExists(), CreateForeignServerCommand::CreateForeignServerCommand(), CreateForeignTableCommand::CreateForeignTableCommand(), Catalog_Namespace::Catalog::createTable(), import_export::Detector::Detector(), DropForeignServerCommand::DropForeignServerCommand(), DropForeignTableCommand::DropForeignTableCommand(), Parser::GrantPrivilegesStmt::execute(), Parser::RevokePrivilegesStmt::execute(), CommandLineOptions::fillOptions(), Catalog_Namespace::SysCatalog::grantAllOnDatabase_unsafe(), Catalog_Namespace::Catalog::reassignOwners(), RefreshForeignTablesCommand::RefreshForeignTablesCommand(), Catalog_Namespace::Catalog::reloadCatalogMetadataUnlocked(), Catalog_Namespace::Catalog::reloadForeignTableUnlocked(), Catalog_Namespace::Catalog::restoreOldOwners(), ShowCreateServerCommand::ShowCreateServerCommand(), ShowForeignServersCommand::ShowForeignServersCommand(), Catalog_Namespace::thread_holding_write_lock(), Catalog_Namespace::Catalog::updateForeignTablesInMapUnlocked(), and CommandLineOptions::validate().
bool g_enable_fsi_regex_import |
Definition at line 88 of file ParserNode.cpp.
bool g_enable_geo_ops_on_uncompressed_coords |
Definition at line 125 of file Execute.cpp.
Referenced by CommandLineOptions::fillDeveloperOptions(), and RelAlgTranslator::translateBinaryGeoFunction().
bool g_enable_hashjoin_many_to_many |
Definition at line 113 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), and translate_bounding_box_intersect_with_reordering().
bool g_enable_interop |
Definition at line 55 of file RelAlgExecutor.cpp.
Referenced by RelAlgExecutor::executeRelAlgSeq(), and CommandLineOptions::fillOptions().
bool g_enable_lazy_fetch |
Definition at line 136 of file Execute.cpp.
Referenced by QueryCompilationDescriptor::compile(), CommandLineOptions::fillDeveloperOptions(), and QueryMemoryDescriptor::toString().
bool g_enable_legacy_delimited_import |
Definition at line 84 of file ParserNode.cpp.
bool g_enable_ml_functions |
Definition at line 122 of file Execute.cpp.
bool g_enable_non_kernel_time_query_interrupt |
Definition at line 138 of file Execute.cpp.
Referenced by Parser::check_session_interrupted(), anonymous_namespace{Importer.cpp}::check_session_interrupted(), ColumnarResults::compactAndCopyEntriesWithoutTargetSkipping(), ColumnarResults::compactAndCopyEntriesWithTargetSkipping(), Parser::CopyTableStmt::execute(), anonymous_namespace{ResultSetReductionJIT.cpp}::generate_loop_body(), ColumnFetcher::getAllTableColumnFragments(), QueryExecutionContext::groupBufferToDeinterleavedResults(), DBHandler::import_table(), import_export::Importer::importGDALGeo(), import_export::Importer::importGDALRaster(), DBHandler::importGeoTableSingle(), DBHandler::interrupt(), Executor::interrupt(), DBHandler::interruptQuery(), ColumnFetcher::linearizeFixedLenArrayColFrags(), ColumnFetcher::linearizeVarLenArrayColFrags(), ColumnarResults::locateAndCountEntries(), ColumnFetcher::makeJoinColumn(), ColumnarResults::materializeAllColumnsThroughIteration(), ColumnarResults::materializeAllLazyColumns(), CommandLineOptions::parse_command_line(), Parser::InsertIntoTableAsSelectStmt::populateData(), ResultSetStorage::reduceEntriesNoCollisionsColWise(), and Executor::resetInterrupt().
size_t g_enable_parallel_linearization |
Definition at line 156 of file Execute.cpp.
Referenced by ColumnFetcher::linearizeVarLenArrayColFrags().
bool g_enable_parallel_window_partition_compute |
Definition at line 41 of file WindowContext.cpp.
Referenced by WindowFunctionContext::compute(), and CommandLineOptions::fillDeveloperOptions().
bool g_enable_parallel_window_partition_sort |
Definition at line 44 of file WindowContext.cpp.
Referenced by CommandLineOptions::fillDeveloperOptions().
bool g_enable_runtime_query_interrupt |
Definition at line 137 of file Execute.cpp.
Referenced by Executor::enableRuntimeQueryInterrupt(), DBHandler::execute_rel_alg(), DBHandler::interrupt(), Executor::interrupt(), DBHandler::interruptQuery(), CommandLineOptions::parse_command_line(), Executor::resetInterrupt(), and DBHandler::sql_execute_impl().
bool g_enable_s3_fsi |
Definition at line 97 of file Catalog.cpp.
Referenced by Catalog_Namespace::thread_holding_write_lock(), CommandLineOptions::validate(), and foreign_storage::AbstractFileStorageDataWrapper::validateServerOptions().
bool g_enable_smem_grouped_non_count_agg |
Definition at line 147 of file Execute.cpp.
Referenced by CommandLineOptions::fillDeveloperOptions().
bool g_enable_smem_non_grouped_agg |
Definition at line 150 of file Execute.cpp.
Referenced by CommandLineOptions::fillDeveloperOptions().
bool g_enable_string_functions |
Definition at line 43 of file RelAlgTranslator.cpp.
bool g_enable_table_functions |
Definition at line 121 of file Execute.cpp.
Referenced by RelAlgExecutor::executeTableFunction(), CommandLineOptions::fillOptions(), table_functions::TableFunctionsFactory::reset(), and CommandLineOptions::validate().
bool g_enable_union |
Definition at line 56 of file RelAlgExecutor.cpp.
bool g_enable_watchdog |
bool g_enable_window_functions |
Definition at line 120 of file Execute.cpp.
Referenced by RelAlgExecutor::executeWorkUnit(), and CommandLineOptions::fillDeveloperOptions().
bool g_executor_resource_mgr_allow_cpu_gpu_kernel_concurrency |
Definition at line 188 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), DBHandler::init_executor_resource_mgr(), CommandLineOptions::parse_command_line(), and CommandLineOptions::validate().
bool g_executor_resource_mgr_allow_cpu_kernel_concurrency |
Definition at line 187 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), DBHandler::init_executor_resource_mgr(), CommandLineOptions::parse_command_line(), and CommandLineOptions::validate().
bool g_executor_resource_mgr_allow_cpu_result_mem_oversubscription_concurrency |
Definition at line 194 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), DBHandler::init_executor_resource_mgr(), CommandLineOptions::parse_command_line(), and CommandLineOptions::validate().
bool g_executor_resource_mgr_allow_cpu_slot_oversubscription_concurrency |
Definition at line 191 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), DBHandler::init_executor_resource_mgr(), CommandLineOptions::parse_command_line(), and CommandLineOptions::validate().
size_t g_executor_resource_mgr_cpu_result_mem_bytes |
Definition at line 181 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), DBHandler::init_executor_resource_mgr(), and CommandLineOptions::parse_command_line().
double g_executor_resource_mgr_cpu_result_mem_ratio |
Definition at line 180 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), DBHandler::init_executor_resource_mgr(), CommandLineOptions::parse_command_line(), and CommandLineOptions::validate().
double g_executor_resource_mgr_max_available_resource_use_ratio |
Definition at line 195 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), DBHandler::init_executor_resource_mgr(), CommandLineOptions::parse_command_line(), and CommandLineOptions::validate().
double g_executor_resource_mgr_per_query_max_cpu_result_mem_ratio |
Definition at line 183 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), DBHandler::init_executor_resource_mgr(), CommandLineOptions::parse_command_line(), and CommandLineOptions::validate().
double g_executor_resource_mgr_per_query_max_cpu_slots_ratio |
Definition at line 182 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), DBHandler::init_executor_resource_mgr(), CommandLineOptions::parse_command_line(), and CommandLineOptions::validate().
float g_filter_push_down_high_frac |
Definition at line 104 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), and FilterSelectivity::isFilterSelectiveEnough().
float g_filter_push_down_low_frac |
Definition at line 103 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), and FilterSelectivity::isFilterSelectiveEnough().
size_t g_filter_push_down_passing_row_ubound |
Definition at line 105 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), and FilterSelectivity::isFilterSelectiveEnough().
bool g_from_table_reordering |
Definition at line 97 of file Execute.cpp.
size_t g_gpu_smem_threshold |
Definition at line 142 of file Execute.cpp.
Referenced by CommandLineOptions::fillDeveloperOptions().
size_t g_hashtable_cache_total_bytes |
Definition at line 164 of file Execute.cpp.
Referenced by CommandLineOptions::parse_command_line().
size_t g_in_clause_num_elem_skip_bitmap |
Definition at line 88 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), and RelAlgTranslator::translateInOper().
bool g_inner_join_fragment_skipping |
Definition at line 98 of file Execute.cpp.
Referenced by Executor::createKernels(), and CommandLineOptions::fillOptions().
size_t g_leaf_count |
Definition at line 79 of file ParserNode.cpp.
Referenced by Catalog_Namespace::Catalog::dumpCreateTableUnlocked(), Catalog_Namespace::Catalog::dumpSchema(), Parser::anonymous_namespace{ParserNode.cpp}::get_shard_count_def(), DBHandler::get_table_details_impl(), GroupByAndAggregate::getShardedTopBucket(), and loadGeo().
|
inline |
Definition at line 24 of file heavyai_locks.h.
size_t g_max_cacheable_hashtable_size_bytes |
Definition at line 165 of file Execute.cpp.
Referenced by CommandLineOptions::parse_command_line().
size_t g_max_cacheable_query_resultset_size_bytes |
Definition at line 167 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), and CommandLineOptions::parse_command_line().
size_t g_max_import_threads |
Definition at line 105 of file Importer.cpp.
size_t g_max_log_length |
Definition at line 176 of file Execute.cpp.
Referenced by anonymous_namespace{RelAlgOptimizer.cpp}::add_new_indices_for(), anonymous_namespace{RelAlgOptimizer.cpp}::cleanup_dead_nodes(), CommandLineOptions::fillDeveloperOptions(), fold_filters(), and DBHandler::sql_execute_impl().
size_t g_max_memory_allocation_size |
Definition at line 251 of file CommandLineOptions.h.
Referenced by create_dev_group_by_buffers(), CommandLineOptions::fillDeveloperOptions(), and QueryMemoryInitializer::QueryMemoryInitializer().
size_t g_min_memory_allocation_size |
Definition at line 129 of file Execute.cpp.
Referenced by create_dev_group_by_buffers(), and CommandLineOptions::fillDeveloperOptions().
|
inline |
Definition at line 22 of file heavyai_locks.h.
bool g_null_div_by_zero |
Definition at line 95 of file Execute.cpp.
Referenced by CodeGenerator::codegenDiv(), CommandLineOptions::fillOptions(), and ExpressionRange::operator/().
size_t g_num_tuple_threshold_switch_to_baseline |
Definition at line 110 of file Execute.cpp.
Referenced by CommandLineOptions::fillDeveloperOptions(), PerfectJoinHashTable::getInstance(), and DBHandler::validate_configurations().
int64_t g_omni_kafka_seek |
bool g_optimize_cuda_block_and_grid_sizes |
Definition at line 169 of file Execute.cpp.
Referenced by DBHandler::execute_rel_alg(), and CommandLineOptions::parse_command_line().
bool g_optimize_row_initialization |
Definition at line 108 of file Execute.cpp.
Referenced by CommandLineOptions::fillDeveloperOptions(), and QueryMemoryInitializer::initRowGroups().
unsigned g_pending_query_interrupt_freq |
Definition at line 140 of file Execute.cpp.
Referenced by Executor::enableRuntimeQueryInterrupt(), DBHandler::execute_rel_alg(), and CommandLineOptions::parse_command_line().
size_t g_preflight_count_query_threshold |
Definition at line 185 of file CommandLineOptions.h.
Referenced by anonymous_namespace{RelAlgExecutor.cpp}::compute_output_buffer_size(), and CommandLineOptions::parse_command_line().
|
inline |
Definition at line 10 of file QueryEngine.h.
Referenced by CommandLineOptions::fillDeveloperOptions(), QueryEngine::getCudaStream(), QueryEngine::getCudaStreamForDevice(), QueryEngine::QueryEngine(), and QueryEngine::~QueryEngine().
size_t g_query_resultset_cache_total_bytes |
Definition at line 166 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), and CommandLineOptions::parse_command_line().
size_t g_ratio_num_hash_entry_to_num_tuple_switch_to_baseline |
Definition at line 111 of file Execute.cpp.
Referenced by CommandLineOptions::fillDeveloperOptions(), PerfectJoinHashTable::getInstance(), and DBHandler::validate_configurations().
|
inline |
Definition at line 21 of file heavyai_locks.h.
bool g_restrict_ml_model_metadata_to_superusers |
Definition at line 123 of file Execute.cpp.
double g_running_query_interrupt_freq |
Definition at line 141 of file Execute.cpp.
Referenced by Executor::enableRuntimeQueryInterrupt(), DBHandler::execute_rel_alg(), and CommandLineOptions::parse_command_line().
bool g_skip_intermediate_count |
Definition at line 54 of file RelAlgExecutor.cpp.
Referenced by RelAlgExecutor::executeRelAlgStep(), and CommandLineOptions::fillDeveloperOptions().
bool g_strip_join_covered_quals |
Definition at line 116 of file Execute.cpp.
Referenced by CommandLineOptions::fillDeveloperOptions(), and strip_join_covered_filter_quals().
unsigned g_trivial_loop_join_threshold |
Definition at line 96 of file Execute.cpp.
Referenced by anonymous_namespace{IRCodegen.cpp}::check_if_loop_join_is_allowed(), CommandLineOptions::fillOptions(), and anonymous_namespace{FromTableReordering.cpp}::traverse_join_cost_graph().
bool g_use_chunk_metadata_cache |
Definition at line 161 of file Execute.cpp.
Referenced by QueryRunner::DataRecyclerFlagsDisabler::DataRecyclerFlagsDisabler(), CommandLineOptions::fillOptions(), Fragmenter_Namespace::FragmentInfo::getChunkMetadataMap(), ChunkMetadataRecycler::hasItemInCache(), ChunkMetadataRecycler::markCachedItemAsDirty(), CommandLineOptions::parse_command_line(), ChunkMetadataRecycler::putItemToCache(), and QueryRunner::DataRecyclerFlagsDisabler::~DataRecyclerFlagsDisabler().
bool g_use_estimator_result_cache |
Definition at line 139 of file Execute.cpp.
Referenced by Executor::addToCardinalityCache(), Executor::clearCardinalityCache(), Executor::getCachedCardinality(), Executor::invalidateCardinalityCacheForTable(), and CommandLineOptions::parse_command_line().
bool g_use_hashtable_cache |
Definition at line 159 of file Execute.cpp.
Referenced by HashJoin::canAccessHashTable(), BoundingBoxIntersectTuningParamRecycler::getItemFromCache(), HashingSchemeRecycler::hasItemInCache(), BoundingBoxIntersectTuningParamRecycler::hasItemInCache(), HashtableRecycler::hasItemInCache(), HashingSchemeRecycler::markCachedItemAsDirty(), BoundingBoxIntersectTuningParamRecycler::markCachedItemAsDirty(), HashtableRecycler::markCachedItemAsDirty(), CommandLineOptions::parse_command_line(), HashingSchemeRecycler::putItemToCache(), BoundingBoxIntersectTuningParamRecycler::putItemToCache(), HashtableRecycler::putItemToCache(), and HashtableRecycler::removeItemFromCache().
bool g_use_query_resultset_cache |
Definition at line 160 of file Execute.cpp.
Referenced by RelAlgExecutor::canUseResultsetCache(), QueryRunner::DataRecyclerFlagsDisabler::DataRecyclerFlagsDisabler(), CommandLineOptions::fillOptions(), ResultSetRecycler::getOutputMetaInfo(), anonymous_namespace{RelAlgExecutor.cpp}::handle_query_hint(), ResultSetRecycler::hasItemInCache(), ResultSetRecycler::markCachedItemAsDirty(), CommandLineOptions::parse_command_line(), ResultSetRecycler::putItemToCache(), RaExecutionSequence::RaExecutionSequence(), RelAlgDag::registerQueryHints(), ResultSetRecycler::removeItemFromCache(), and QueryRunner::DataRecyclerFlagsDisabler::~DataRecyclerFlagsDisabler().
float g_vacuum_min_selectivity |
Definition at line 27 of file TableOptimizer.cpp.
Referenced by CommandLineOptions::fillDeveloperOptions(), TableOptimizer::vacuumFragmentsAboveMinSelectivity(), and CommandLineOptions::validate().
size_t g_watchdog_in_clause_max_num_elem_bitmap |
Definition at line 86 of file Execute.cpp.
Referenced by anonymous_namespace{RelAlgTranslator.cpp}::fill_dictionary_encoded_in_vals(), anonymous_namespace{RelAlgTranslator.cpp}::fill_integer_in_vals(), and CommandLineOptions::fillOptions().
size_t g_watchdog_in_clause_max_num_elem_non_bitmap |
Definition at line 85 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), and RelAlgTranslator::translateInOper().
size_t g_watchdog_in_clause_max_num_input_rows |
Definition at line 87 of file Execute.cpp.
Referenced by CommandLineOptions::fillOptions(), and anonymous_namespace{RelAlgTranslator.cpp}::get_in_values_expr().
size_t g_watchdog_in_subquery_max_in_values |
size_t g_watchdog_max_projected_rows_per_device |
Definition at line 183 of file CommandLineOptions.h.
Referenced by anonymous_namespace{Execute.cpp}::checkWorkUnitWatchdog(), CommandLineOptions::fillOptions(), and CommandLineOptions::parse_command_line().
size_t g_watchdog_none_encoded_string_translation_limit |
Definition at line 82 of file Execute.cpp.
Referenced by anonymous_namespace{RelAlgExecutor.cpp}::check_none_encoded_string_cast_tuple_limit(), and CommandLineOptions::fillOptions().
size_t g_window_function_aggregation_tree_fanout |
Definition at line 47 of file WindowContext.cpp.
Referenced by RelAlgExecutor::createWindowFunctionContext(), and CommandLineOptions::fillDeveloperOptions().