OmniSciDB  c1a53651b2
 All Classes Namespaces Files Functions Variables Typedefs Enumerations Enumerator Friends Macros Groups Pages
Execute.cpp File Reference
#include "QueryEngine/Execute.h"
#include <llvm/Transforms/Utils/BasicBlockUtils.h>
#include <boost/filesystem/operations.hpp>
#include <boost/filesystem/path.hpp>
#include <chrono>
#include <ctime>
#include <future>
#include <iostream>
#include <memory>
#include <mutex>
#include <numeric>
#include <set>
#include <thread>
#include "Catalog/Catalog.h"
#include "CudaMgr/CudaMgr.h"
#include "DataMgr/BufferMgr/BufferMgr.h"
#include "DataMgr/ForeignStorage/FsiChunkUtils.h"
#include "OSDependent/heavyai_path.h"
#include "Parser/ParserNode.h"
#include "QueryEngine/AggregateUtils.h"
#include "QueryEngine/AggregatedColRange.h"
#include "QueryEngine/CodeGenerator.h"
#include "QueryEngine/ColumnFetcher.h"
#include "QueryEngine/Descriptors/QueryCompilationDescriptor.h"
#include "QueryEngine/Descriptors/QueryFragmentDescriptor.h"
#include "QueryEngine/DynamicWatchdog.h"
#include "QueryEngine/EquiJoinCondition.h"
#include "QueryEngine/ErrorHandling.h"
#include "QueryEngine/ExpressionRewrite.h"
#include "QueryEngine/ExternalCacheInvalidators.h"
#include "QueryEngine/GpuMemUtils.h"
#include "QueryEngine/InPlaceSort.h"
#include "QueryEngine/JoinHashTable/BaselineJoinHashTable.h"
#include "QueryEngine/JoinHashTable/OverlapsJoinHashTable.h"
#include "QueryEngine/JsonAccessors.h"
#include "QueryEngine/OutputBufferInitialization.h"
#include "QueryEngine/QueryDispatchQueue.h"
#include "QueryEngine/QueryEngine.h"
#include "QueryEngine/QueryRewrite.h"
#include "QueryEngine/QueryTemplateGenerator.h"
#include "QueryEngine/ResultSetReductionJIT.h"
#include "QueryEngine/RuntimeFunctions.h"
#include "QueryEngine/SpeculativeTopN.h"
#include "QueryEngine/StringDictionaryGenerations.h"
#include "QueryEngine/TableFunctions/TableFunctionCompilationContext.h"
#include "QueryEngine/TableFunctions/TableFunctionExecutionContext.h"
#include "QueryEngine/Visitors/TransientStringLiteralsVisitor.h"
#include "Shared/SystemParameters.h"
#include "Shared/TypedDataAccessors.h"
#include "Shared/checked_alloc.h"
#include "Shared/measure.h"
#include "Shared/misc.h"
#include "Shared/scope.h"
#include "Shared/shard_key.h"
#include "Shared/threading.h"
#include "ArrayOps.cpp"
#include "DateAdd.cpp"
#include "GeoOps.cpp"
#include "RowFunctionOps.cpp"
#include "StringFunctions.cpp"
#include "TableFunctions/TableFunctionOps.cpp"

Go to the source code of this file.

Classes

struct  anonymous_namespace{Execute.cpp}::GetTargetInfo
 
class  anonymous_namespace{Execute.cpp}::OutVecOwner
 

Namespaces

 anonymous_namespace{Execute.cpp}
 
 foreign_storage
 

Macros

#define EXECUTE_INCLUDE
 

Functions

std::unique_ptr< llvm::Module > read_llvm_module_from_bc_file (const std::string &udf_ir_filename, llvm::LLVMContext &ctx)
 
std::unique_ptr< llvm::Module > read_llvm_module_from_ir_file (const std::string &udf_ir_filename, llvm::LLVMContext &ctx, bool is_gpu=false)
 
std::unique_ptr< llvm::Module > read_llvm_module_from_ir_string (const std::string &udf_ir_string, llvm::LLVMContext &ctx, bool is_gpu=false)
 
void anonymous_namespace{Execute.cpp}::prepare_string_dictionaries (const std::unordered_set< PhysicalInput > &phys_inputs)
 
bool anonymous_namespace{Execute.cpp}::is_empty_table (Fragmenter_Namespace::AbstractFragmenter *fragmenter)
 
void foreign_storage::populate_string_dictionary (int32_t table_id, int32_t col_id, int32_t db_id)
 
 block_size_x_ (block_size_x)
 
 grid_size_x_ (grid_size_x)
 
 max_gpu_slab_size_ (max_gpu_slab_size)
 
 debug_dir_ (debug_dir)
 
 debug_file_ (debug_file)
 
 data_mgr_ (data_mgr)
 
 temporary_tables_ (nullptr)
 
 input_table_info_cache_ (this)
 
ResultSetPtr anonymous_namespace{Execute.cpp}::get_merged_result (std::vector< std::pair< ResultSetPtr, std::vector< size_t >>> &results_per_device, std::vector< TargetInfo > const &targets)
 
ReductionCode anonymous_namespace{Execute.cpp}::get_reduction_code (const size_t executor_id, std::vector< std::pair< ResultSetPtr, std::vector< size_t >>> &results_per_device, int64_t *compilation_queue_time)
 
std::unordered_set< int > get_available_gpus (const Data_Namespace::DataMgr *data_mgr)
 
size_t get_context_count (const ExecutorDeviceType device_type, const size_t cpu_count, const size_t gpu_count)
 
size_t anonymous_namespace{Execute.cpp}::compute_buffer_entry_guess (const std::vector< InputTableInfo > &query_infos)
 
std::string anonymous_namespace{Execute.cpp}::get_table_name (const InputDescriptor &input_desc)
 
size_t anonymous_namespace{Execute.cpp}::getDeviceBasedScanLimit (const ExecutorDeviceType device_type, const int device_count)
 
void anonymous_namespace{Execute.cpp}::checkWorkUnitWatchdog (const RelAlgExecutionUnit &ra_exe_unit, const std::vector< InputTableInfo > &table_infos, const ExecutorDeviceType device_type, const int device_count)
 
size_t get_loop_join_size (const std::vector< InputTableInfo > &query_infos, const RelAlgExecutionUnit &ra_exe_unit)
 
template<typename T >
std::vector< std::string > anonymous_namespace{Execute.cpp}::expr_container_to_string (const T &expr_container)
 
template<>
std::vector< std::string > anonymous_namespace{Execute.cpp}::expr_container_to_string (const std::list< Analyzer::OrderEntry > &expr_container)
 
std::string anonymous_namespace{Execute.cpp}::sort_algorithm_to_string (const SortAlgorithm algorithm)
 
std::string ra_exec_unit_desc_for_caching (const RelAlgExecutionUnit &ra_exe_unit)
 
std::ostream & operator<< (std::ostream &os, const RelAlgExecutionUnit &ra_exe_unit)
 
RelAlgExecutionUnit anonymous_namespace{Execute.cpp}::replace_scan_limit (const RelAlgExecutionUnit &ra_exe_unit_in, const size_t new_scan_limit)
 
int64_t anonymous_namespace{Execute.cpp}::inline_null_val (const SQLTypeInfo &ti, const bool float_argument_input)
 
void anonymous_namespace{Execute.cpp}::fill_entries_for_empty_input (std::vector< TargetInfo > &target_infos, std::vector< int64_t > &entry, const std::vector< Analyzer::Expr * > &target_exprs, const QueryMemoryDescriptor &query_mem_desc)
 
ResultSetPtr anonymous_namespace{Execute.cpp}::build_row_for_empty_input (const std::vector< Analyzer::Expr * > &target_exprs_in, const QueryMemoryDescriptor &query_mem_desc, const ExecutorDeviceType device_type)
 
size_t anonymous_namespace{Execute.cpp}::permute_storage_columnar (const ResultSetStorage *input_storage, const QueryMemoryDescriptor &input_query_mem_desc, const ResultSetStorage *output_storage, size_t output_row_index, const QueryMemoryDescriptor &output_query_mem_desc, const std::vector< uint32_t > &top_permutation)
 
size_t anonymous_namespace{Execute.cpp}::permute_storage_row_wise (const ResultSetStorage *input_storage, const ResultSetStorage *output_storage, size_t output_row_index, const QueryMemoryDescriptor &output_query_mem_desc, const std::vector< uint32_t > &top_permutation)
 
bool anonymous_namespace{Execute.cpp}::has_lazy_fetched_columns (const std::vector< ColumnLazyFetchInfo > &fetched_cols)
 
const ColumnDescriptoranonymous_namespace{Execute.cpp}::try_get_column_descriptor (const InputColDescriptor *col_desc)
 
std::map< shared::TableKey,
std::vector< uint64_t > > 
get_table_id_to_frag_offsets (const std::vector< InputDescriptor > &input_descs, const std::map< shared::TableKey, const TableFragments * > &all_tables_fragments)
 
std::ostream & operator<< (std::ostream &os, FetchResult const &fetch_result)
 
size_t anonymous_namespace{Execute.cpp}::get_selected_input_descs_index (const shared::TableKey &table_key, std::vector< InputDescriptor > const &input_descs)
 
size_t anonymous_namespace{Execute.cpp}::get_selected_input_col_descs_index (const shared::TableKey &table_key, std::list< std::shared_ptr< InputColDescriptor const >> const &input_col_descs)
 
std::list< std::shared_ptr
< const InputColDescriptor > > 
anonymous_namespace{Execute.cpp}::get_selected_input_col_descs (const shared::TableKey &table_key, std::list< std::shared_ptr< InputColDescriptor const >> const &input_col_descs)
 
void anonymous_namespace{Execute.cpp}::set_mod_range (std::vector< int8_t const * > &frag_col_buffers, int8_t const *const ptr, size_t const local_col_id, size_t const N)
 
bool anonymous_namespace{Execute.cpp}::check_rows_less_than_needed (const ResultSetPtr &results, const size_t scan_limit)
 
void anonymous_namespace{Execute.cpp}::add_deleted_col_to_map (PlanState::DeletedColumnsMap &deleted_cols_map, const ColumnDescriptor *deleted_cd, const shared::TableKey &table_key)
 
std::tuple< bool, int64_t,
int64_t > 
anonymous_namespace{Execute.cpp}::get_hpt_overflow_underflow_safe_scaled_values (const int64_t chunk_min, const int64_t chunk_max, const SQLTypeInfo &lhs_type, const SQLTypeInfo &rhs_type)
 

Variables

bool g_enable_watchdog false
 
bool g_enable_dynamic_watchdog {false}
 
size_t g_watchdog_none_encoded_string_translation_limit {1000000UL}
 
bool g_enable_cpu_sub_tasks {false}
 
size_t g_cpu_sub_task_size {500'000}
 
bool g_enable_filter_function {true}
 
unsigned g_dynamic_watchdog_time_limit {10000}
 
bool g_allow_cpu_retry {true}
 
bool g_allow_query_step_cpu_retry {true}
 
bool g_null_div_by_zero {false}
 
unsigned g_trivial_loop_join_threshold {1000}
 
bool g_from_table_reordering {true}
 
bool g_inner_join_fragment_skipping {true}
 
bool g_enable_smem_group_by
 
std::unique_ptr< llvm::Module > udf_gpu_module
 
std::unique_ptr< llvm::Module > udf_cpu_module
 
bool g_enable_filter_push_down {false}
 
float g_filter_push_down_low_frac {-1.0f}
 
float g_filter_push_down_high_frac {-1.0f}
 
size_t g_filter_push_down_passing_row_ubound {0}
 
bool g_enable_columnar_output {false}
 
bool g_enable_left_join_filter_hoisting {true}
 
bool g_optimize_row_initialization {true}
 
bool g_enable_overlaps_hashjoin {true}
 
bool g_enable_distance_rangejoin {true}
 
bool g_enable_hashjoin_many_to_many {false}
 
size_t g_overlaps_max_table_size_bytes {1024 * 1024 * 1024}
 
double g_overlaps_target_entries_per_bin {1.3}
 
bool g_strip_join_covered_quals {false}
 
size_t g_constrained_by_in_threshold {10}
 
size_t g_default_max_groups_buffer_entry_guess {16384}
 
size_t g_big_group_threshold {g_default_max_groups_buffer_entry_guess}
 
bool g_enable_window_functions {true}
 
bool g_enable_table_functions {true}
 
bool g_enable_dev_table_functions {false}
 
bool g_enable_geo_ops_on_uncompressed_coords {true}
 
bool g_enable_rf_prop_table_functions {true}
 
size_t g_max_memory_allocation_size {2000000000}
 
size_t g_min_memory_allocation_size
 
bool g_enable_bump_allocator {false}
 
double g_bump_allocator_step_reduction {0.75}
 
bool g_enable_direct_columnarization {true}
 
bool g_enable_string_functions
 
bool g_enable_lazy_fetch {true}
 
bool g_enable_runtime_query_interrupt {true}
 
bool g_enable_non_kernel_time_query_interrupt {true}
 
bool g_use_estimator_result_cache {true}
 
unsigned g_pending_query_interrupt_freq {1000}
 
double g_running_query_interrupt_freq {0.1}
 
size_t g_gpu_smem_threshold
 
bool g_enable_smem_grouped_non_count_agg
 
bool g_enable_smem_non_grouped_agg
 
bool g_is_test_env {false}
 
size_t g_enable_parallel_linearization
 
bool g_enable_data_recycler {true}
 
bool g_use_hashtable_cache {true}
 
bool g_use_query_resultset_cache {true}
 
bool g_use_chunk_metadata_cache {true}
 
bool g_allow_auto_resultset_caching {false}
 
bool g_allow_query_step_skipping {true}
 
size_t g_hashtable_cache_total_bytes {size_t(1) << 32}
 
size_t g_max_cacheable_hashtable_size_bytes {size_t(1) << 31}
 
size_t g_query_resultset_cache_total_bytes {size_t(1) << 32}
 
size_t g_max_cacheable_query_resultset_size_bytes {size_t(1) << 31}
 
size_t g_auto_resultset_caching_threshold {size_t(1) << 20}
 
bool g_optimize_cuda_block_and_grid_sizes {false}
 
size_t g_approx_quantile_buffer {1000}
 
size_t g_approx_quantile_centroids {300}
 
bool g_enable_automatic_ir_metadata {true}
 
size_t g_max_log_length {500}
 
bool g_cache_string_hash
 
 this
 

Macro Definition Documentation

#define EXECUTE_INCLUDE

Definition at line 3908 of file Execute.cpp.

Function Documentation

block_size_x_ ( block_size_x  )
data_mgr_ ( data_mgr  )

Referenced by BaselineHashTable::BaselineHashTable(), Executor::interrupt(), ResultSet::syncEstimatorBuffer(), BaselineHashTable::~BaselineHashTable(), and ResultSet::~ResultSet().

+ Here is the caller graph for this function:

debug_dir_ ( debug_dir  )
debug_file_ ( debug_file  )
std::unordered_set<int> get_available_gpus ( const Data_Namespace::DataMgr data_mgr)

Definition at line 1439 of file Execute.cpp.

References CHECK, CHECK_GT, Data_Namespace::DataMgr::getCudaMgr(), CudaMgr_Namespace::CudaMgr::getDeviceCount(), and Data_Namespace::DataMgr::gpusPresent().

Referenced by Executor::executeWorkUnitImpl().

1439  {
1440  CHECK(data_mgr);
1441  std::unordered_set<int> available_gpus;
1442  if (data_mgr->gpusPresent()) {
1443  CHECK(data_mgr->getCudaMgr());
1444  const int gpu_count = data_mgr->getCudaMgr()->getDeviceCount();
1445  CHECK_GT(gpu_count, 0);
1446  for (int gpu_id = 0; gpu_id < gpu_count; ++gpu_id) {
1447  available_gpus.insert(gpu_id);
1448  }
1449  }
1450  return available_gpus;
1451 }
CudaMgr_Namespace::CudaMgr * getCudaMgr() const
Definition: DataMgr.h:224
#define CHECK_GT(x, y)
Definition: Logger.h:305
int getDeviceCount() const
Definition: CudaMgr.h:87
#define CHECK(condition)
Definition: Logger.h:291
bool gpusPresent() const
Definition: DataMgr.h:218

+ Here is the call graph for this function:

+ Here is the caller graph for this function:

size_t get_context_count ( const ExecutorDeviceType  device_type,
const size_t  cpu_count,
const size_t  gpu_count 
)

Definition at line 1453 of file Execute.cpp.

References GPU.

Referenced by Executor::executeWorkUnitImpl().

1455  {
1456  return device_type == ExecutorDeviceType::GPU ? gpu_count
1457  : static_cast<size_t>(cpu_count);
1458 }

+ Here is the caller graph for this function:

size_t get_loop_join_size ( const std::vector< InputTableInfo > &  query_infos,
const RelAlgExecutionUnit ra_exe_unit 
)

Definition at line 1561 of file Execute.cpp.

References CHECK, and RelAlgExecutionUnit::input_descs.

Referenced by anonymous_namespace{IRCodegen.cpp}::check_if_loop_join_is_allowed().

1562  {
1563  const auto inner_table_key = ra_exe_unit.input_descs.back().getTableKey();
1564 
1565  std::optional<size_t> inner_table_idx;
1566  for (size_t i = 0; i < query_infos.size(); ++i) {
1567  if (query_infos[i].table_key == inner_table_key) {
1568  inner_table_idx = i;
1569  break;
1570  }
1571  }
1572  CHECK(inner_table_idx);
1573  return query_infos[*inner_table_idx].info.getNumTuples();
1574 }
std::vector< InputDescriptor > input_descs
#define CHECK(condition)
Definition: Logger.h:291

+ Here is the caller graph for this function:

std::map<shared::TableKey, std::vector<uint64_t> > get_table_id_to_frag_offsets ( const std::vector< InputDescriptor > &  input_descs,
const std::map< shared::TableKey, const TableFragments * > &  all_tables_fragments 
)

Definition at line 2806 of file Execute.cpp.

References CHECK.

Referenced by Executor::getRowCountAndOffsetForAllFrags().

2808  {
2809  std::map<shared::TableKey, std::vector<uint64_t>> tab_id_to_frag_offsets;
2810  for (auto& desc : input_descs) {
2811  const auto fragments_it = all_tables_fragments.find(desc.getTableKey());
2812  CHECK(fragments_it != all_tables_fragments.end());
2813  const auto& fragments = *fragments_it->second;
2814  std::vector<uint64_t> frag_offsets(fragments.size(), 0);
2815  for (size_t i = 0, off = 0; i < fragments.size(); ++i) {
2816  frag_offsets[i] = off;
2817  off += fragments[i].getNumTuples();
2818  }
2819  tab_id_to_frag_offsets.insert(std::make_pair(desc.getTableKey(), frag_offsets));
2820  }
2821  return tab_id_to_frag_offsets;
2822 }
#define CHECK(condition)
Definition: Logger.h:291

+ Here is the caller graph for this function:

grid_size_x_ ( grid_size_x  )
input_table_info_cache_ ( this  )

Definition at line 261 of file Execute.cpp.

References Executor::initialize_extension_module_sources().

261  {
263  update_extension_modules();
264 }
static void initialize_extension_module_sources()
Definition: Execute.cpp:266

+ Here is the call graph for this function:

max_gpu_slab_size_ ( max_gpu_slab_size  )
std::ostream& operator<< ( std::ostream &  os,
const RelAlgExecutionUnit ra_exe_unit 
)

Definition at line 1667 of file Execute.cpp.

References RelAlgExecutionUnit::estimator, anonymous_namespace{Execute.cpp}::expr_container_to_string(), RelAlgExecutionUnit::groupby_exprs, RelAlgExecutionUnit::input_col_descs, join(), RelAlgExecutionUnit::join_quals, RelAlgExecutionUnit::quals, RelAlgExecutionUnit::query_plan_dag_hash, RelAlgExecutionUnit::scan_limit, RelAlgExecutionUnit::simple_quals, anonymous_namespace{Execute.cpp}::sort_algorithm_to_string(), RelAlgExecutionUnit::sort_info, RelAlgExecutionUnit::target_exprs, to_string(), toString(), RelAlgExecutionUnit::union_all, and RelAlgExecutionUnit::use_bump_allocator.

1667  {
1668  os << "\n\tExtracted Query Plan Dag Hash: " << ra_exe_unit.query_plan_dag_hash;
1669  os << "\n\tTable/Col/Levels: ";
1670  for (const auto& input_col_desc : ra_exe_unit.input_col_descs) {
1671  const auto& scan_desc = input_col_desc->getScanDesc();
1672  os << "(" << scan_desc.getTableKey() << ", " << input_col_desc->getColId() << ", "
1673  << scan_desc.getNestLevel() << ") ";
1674  }
1675  if (!ra_exe_unit.simple_quals.empty()) {
1676  os << "\n\tSimple Quals: "
1678  ", ");
1679  }
1680  if (!ra_exe_unit.quals.empty()) {
1681  os << "\n\tQuals: "
1682  << boost::algorithm::join(expr_container_to_string(ra_exe_unit.quals), ", ");
1683  }
1684  if (!ra_exe_unit.join_quals.empty()) {
1685  os << "\n\tJoin Quals: ";
1686  for (size_t i = 0; i < ra_exe_unit.join_quals.size(); i++) {
1687  const auto& join_condition = ra_exe_unit.join_quals[i];
1688  os << "\t\t" << std::to_string(i) << " " << ::toString(join_condition.type);
1689  os << boost::algorithm::join(expr_container_to_string(join_condition.quals), ", ");
1690  }
1691  }
1692  if (!ra_exe_unit.groupby_exprs.empty()) {
1693  os << "\n\tGroup By: "
1695  ", ");
1696  }
1697  os << "\n\tProjected targets: "
1699  os << "\n\tHas Estimator: " << ::toString(ra_exe_unit.estimator == nullptr);
1700  os << "\n\tSort Info: ";
1701  const auto& sort_info = ra_exe_unit.sort_info;
1702  os << "\n\t Order Entries: "
1703  << boost::algorithm::join(expr_container_to_string(sort_info.order_entries), ", ");
1704  os << "\n\t Algorithm: " << sort_algorithm_to_string(sort_info.algorithm);
1705  os << "\n\t Limit: " << std::to_string(sort_info.limit);
1706  os << "\n\t Offset: " << std::to_string(sort_info.offset);
1707  os << "\n\tScan Limit: " << std::to_string(ra_exe_unit.scan_limit);
1708  os << "\n\tBump Allocator: " << ::toString(ra_exe_unit.use_bump_allocator);
1709  if (ra_exe_unit.union_all) {
1710  os << "\n\tUnion: " << std::string(*ra_exe_unit.union_all ? "UNION ALL" : "UNION");
1711  }
1712  return os;
1713 }
std::vector< Analyzer::Expr * > target_exprs
QueryPlanHash query_plan_dag_hash
const std::optional< bool > union_all
std::string join(T const &container, std::string const &delim)
const std::list< std::shared_ptr< Analyzer::Expr > > groupby_exprs
std::string to_string(char const *&&v)
const JoinQualsPerNestingLevel join_quals
std::vector< std::string > expr_container_to_string(const T &expr_container)
Definition: Execute.cpp:1579
std::string toString(const ExecutorDeviceType &device_type)
const std::shared_ptr< Analyzer::Estimator > estimator
std::string sort_algorithm_to_string(const SortAlgorithm algorithm)
Definition: Execute.cpp:1601
std::list< std::shared_ptr< Analyzer::Expr > > quals
std::list< std::shared_ptr< const InputColDescriptor > > input_col_descs
std::list< std::shared_ptr< Analyzer::Expr > > simple_quals

+ Here is the call graph for this function:

std::ostream& operator<< ( std::ostream &  os,
FetchResult const &  fetch_result 
)

Definition at line 2910 of file Execute.cpp.

References FetchResult::col_buffers, FetchResult::frag_offsets, FetchResult::num_rows, and shared::printContainer().

2910  {
2911  return os << "col_buffers" << shared::printContainer(fetch_result.col_buffers)
2912  << " num_rows" << shared::printContainer(fetch_result.num_rows)
2913  << " frag_offsets" << shared::printContainer(fetch_result.frag_offsets);
2914 }
PrintContainer< CONTAINER > printContainer(CONTAINER &container)
Definition: misc.h:107

+ Here is the call graph for this function:

std::string ra_exec_unit_desc_for_caching ( const RelAlgExecutionUnit ra_exe_unit)

Definition at line 1616 of file Execute.cpp.

References RelAlgExecutionUnit::estimator, RelAlgExecutionUnit::groupby_exprs, RelAlgExecutionUnit::input_col_descs, RelAlgExecutionUnit::join_quals, RelAlgExecutionUnit::quals, RelAlgExecutionUnit::scan_limit, RelAlgExecutionUnit::simple_quals, RelAlgExecutionUnit::target_exprs, to_string(), and toString().

Referenced by RelAlgExecutor::executeWorkUnit().

1616  {
1617  // todo(yoonmin): replace a cache key as a DAG representation of a query plan
1618  // instead of ra_exec_unit description if possible
1619  std::ostringstream os;
1620  for (const auto& input_col_desc : ra_exe_unit.input_col_descs) {
1621  const auto& scan_desc = input_col_desc->getScanDesc();
1622  os << scan_desc.getTableKey() << "," << input_col_desc->getColId() << ","
1623  << scan_desc.getNestLevel();
1624  }
1625  if (!ra_exe_unit.simple_quals.empty()) {
1626  for (const auto& qual : ra_exe_unit.simple_quals) {
1627  if (qual) {
1628  os << qual->toString() << ",";
1629  }
1630  }
1631  }
1632  if (!ra_exe_unit.quals.empty()) {
1633  for (const auto& qual : ra_exe_unit.quals) {
1634  if (qual) {
1635  os << qual->toString() << ",";
1636  }
1637  }
1638  }
1639  if (!ra_exe_unit.join_quals.empty()) {
1640  for (size_t i = 0; i < ra_exe_unit.join_quals.size(); i++) {
1641  const auto& join_condition = ra_exe_unit.join_quals[i];
1642  os << std::to_string(i) << ::toString(join_condition.type);
1643  for (const auto& qual : join_condition.quals) {
1644  if (qual) {
1645  os << qual->toString() << ",";
1646  }
1647  }
1648  }
1649  }
1650  if (!ra_exe_unit.groupby_exprs.empty()) {
1651  for (const auto& qual : ra_exe_unit.groupby_exprs) {
1652  if (qual) {
1653  os << qual->toString() << ",";
1654  }
1655  }
1656  }
1657  for (const auto& expr : ra_exe_unit.target_exprs) {
1658  if (expr) {
1659  os << expr->toString() << ",";
1660  }
1661  }
1662  os << ::toString(ra_exe_unit.estimator == nullptr);
1663  os << std::to_string(ra_exe_unit.scan_limit);
1664  return os.str();
1665 }
std::vector< Analyzer::Expr * > target_exprs
const std::list< std::shared_ptr< Analyzer::Expr > > groupby_exprs
std::string to_string(char const *&&v)
const JoinQualsPerNestingLevel join_quals
std::string toString(const ExecutorDeviceType &device_type)
const std::shared_ptr< Analyzer::Estimator > estimator
std::list< std::shared_ptr< Analyzer::Expr > > quals
std::list< std::shared_ptr< const InputColDescriptor > > input_col_descs
std::list< std::shared_ptr< Analyzer::Expr > > simple_quals

+ Here is the call graph for this function:

+ Here is the caller graph for this function:

std::unique_ptr<llvm::Module> read_llvm_module_from_bc_file ( const std::string &  udf_ir_filename,
llvm::LLVMContext &  ctx 
)

Definition at line 1526 of file NativeCodegen.cpp.

References run_benchmark_import::args.

Referenced by Executor::update_extension_modules().

1528  {
1529  llvm::SMDiagnostic err;
1530 
1531  auto buffer_or_error = llvm::MemoryBuffer::getFile(bc_filename);
1532  CHECK(!buffer_or_error.getError()) << "bc_filename=" << bc_filename;
1533  llvm::MemoryBuffer* buffer = buffer_or_error.get().get();
1534 
1535  auto owner = llvm::parseBitcodeFile(buffer->getMemBufferRef(), context);
1536  CHECK(!owner.takeError());
1537  CHECK(owner->get());
1538  return std::move(owner.get());
1539 }
#define CHECK(condition)
Definition: Logger.h:291

+ Here is the caller graph for this function:

std::unique_ptr<llvm::Module> read_llvm_module_from_ir_file ( const std::string &  udf_ir_filename,
llvm::LLVMContext &  ctx,
bool  is_gpu = false 
)

Definition at line 1541 of file NativeCodegen.cpp.

Referenced by Executor::update_extension_modules().

1544  {
1545  llvm::SMDiagnostic parse_error;
1546 
1547  llvm::StringRef file_name_arg(udf_ir_filename);
1548 
1549  auto owner = llvm::parseIRFile(file_name_arg, parse_error, ctx);
1550  if (!owner) {
1551  throw_parseIR_error(parse_error, udf_ir_filename, is_gpu);
1552  }
1553 
1554  if (is_gpu) {
1555  llvm::Triple gpu_triple(owner->getTargetTriple());
1556  if (!gpu_triple.isNVPTX()) {
1557  LOG(WARNING)
1558  << "Expected triple nvptx64-nvidia-cuda for NVVM IR of loadtime UDFs but got "
1559  << gpu_triple.str() << ". Disabling the NVVM IR module.";
1560  return std::unique_ptr<llvm::Module>();
1561  }
1562  }
1563  return owner;
1564 }
#define LOG(tag)
Definition: Logger.h:285
void throw_parseIR_error(const llvm::SMDiagnostic &parse_error, std::string src="", const bool is_gpu=false)

+ Here is the caller graph for this function:

std::unique_ptr<llvm::Module> read_llvm_module_from_ir_string ( const std::string &  udf_ir_string,
llvm::LLVMContext &  ctx,
bool  is_gpu = false 
)

Definition at line 1566 of file NativeCodegen.cpp.

Referenced by Executor::update_extension_modules().

1569  {
1570  llvm::SMDiagnostic parse_error;
1571 
1572  auto buf = std::make_unique<llvm::MemoryBufferRef>(udf_ir_string,
1573  "Runtime UDF/UDTF LLVM/NVVM IR");
1574 
1575  auto owner = llvm::parseIR(*buf, parse_error, ctx);
1576  if (!owner) {
1577  LOG(IR) << "read_llvm_module_from_ir_string:\n"
1578  << udf_ir_string << "\nEnd of LLVM/NVVM IR";
1579  throw_parseIR_error(parse_error, "", /* is_gpu= */ is_gpu);
1580  }
1581 
1582  if (is_gpu) {
1583  llvm::Triple gpu_triple(owner->getTargetTriple());
1584  if (!gpu_triple.isNVPTX()) {
1585  LOG(IR) << "read_llvm_module_from_ir_string:\n"
1586  << udf_ir_string << "\nEnd of NNVM IR";
1587  LOG(WARNING) << "Expected triple nvptx64-nvidia-cuda for NVVM IR but got "
1588  << gpu_triple.str()
1589  << ". Executing runtime UDF/UDTFs on GPU will be disabled.";
1590  return std::unique_ptr<llvm::Module>();
1591  ;
1592  }
1593  }
1594  return owner;
1595 }
#define LOG(tag)
Definition: Logger.h:285
void throw_parseIR_error(const llvm::SMDiagnostic &parse_error, std::string src="", const bool is_gpu=false)

+ Here is the caller graph for this function:

temporary_tables_ ( nullptr  )

Variable Documentation

false

Definition at line 79 of file Execute.cpp.

bool g_allow_query_step_cpu_retry {true}
size_t g_approx_quantile_buffer {1000}
size_t g_approx_quantile_centroids {300}
size_t g_auto_resultset_caching_threshold {size_t(1) << 20}
size_t g_big_group_threshold {g_default_max_groups_buffer_entry_guess}

Definition at line 110 of file Execute.cpp.

Referenced by RelAlgExecutor::executeWorkUnit().

double g_bump_allocator_step_reduction {0.75}

Definition at line 121 of file Execute.cpp.

Referenced by create_dev_group_by_buffers().

bool g_cache_string_hash

Definition at line 52 of file StringDictionary.cpp.

size_t g_constrained_by_in_threshold {10}

Definition at line 108 of file Execute.cpp.

Referenced by QueryRewriter::rewriteConstrainedByInImpl().

size_t g_cpu_sub_task_size {500'000}
unsigned g_dynamic_watchdog_time_limit {10000}
bool g_enable_automatic_ir_metadata {true}
bool g_enable_bump_allocator {false}
bool g_enable_cpu_sub_tasks {false}

Definition at line 82 of file Execute.cpp.

Referenced by CommandLineOptions::fillAdvancedOptions(), and Executor::launchKernels().

bool g_enable_dev_table_functions {false}
bool g_enable_direct_columnarization {true}
bool g_enable_distance_rangejoin {true}
bool g_enable_filter_function {true}

Definition at line 84 of file Execute.cpp.

Referenced by CommandLineOptions::fillAdvancedOptions().

bool g_enable_geo_ops_on_uncompressed_coords {true}
bool g_enable_hashjoin_many_to_many {false}

Definition at line 104 of file Execute.cpp.

Referenced by CommandLineOptions::fillOptions(), and rewrite_overlaps_conjunction().

bool g_enable_lazy_fetch {true}
bool g_enable_left_join_filter_hoisting {true}
size_t g_enable_parallel_linearization
Initial value:
{
10000}

Definition at line 144 of file Execute.cpp.

Referenced by ColumnFetcher::linearizeVarLenArrayColFrags().

bool g_enable_rf_prop_table_functions {true}

Definition at line 115 of file Execute.cpp.

bool g_enable_smem_group_by
bool g_enable_smem_grouped_non_count_agg
Initial value:
{
true}

Definition at line 135 of file Execute.cpp.

Referenced by CommandLineOptions::fillAdvancedOptions().

bool g_enable_smem_non_grouped_agg
Initial value:
{
true}

Definition at line 138 of file Execute.cpp.

Referenced by CommandLineOptions::fillAdvancedOptions().

bool g_enable_string_functions

Definition at line 40 of file RelAlgTranslator.cpp.

bool g_enable_window_functions {true}
float g_filter_push_down_high_frac {-1.0f}
float g_filter_push_down_low_frac {-1.0f}
size_t g_filter_push_down_passing_row_ubound {0}
size_t g_gpu_smem_threshold
Initial value:
{
4096}

Definition at line 130 of file Execute.cpp.

Referenced by CommandLineOptions::fillAdvancedOptions().

size_t g_hashtable_cache_total_bytes {size_t(1) << 32}

Definition at line 152 of file Execute.cpp.

Referenced by CommandLineOptions::parse_command_line().

bool g_inner_join_fragment_skipping {true}

Definition at line 91 of file Execute.cpp.

Referenced by Executor::createKernels(), and CommandLineOptions::fillOptions().

size_t g_max_cacheable_hashtable_size_bytes {size_t(1) << 31}

Definition at line 153 of file Execute.cpp.

Referenced by CommandLineOptions::parse_command_line().

size_t g_max_cacheable_query_resultset_size_bytes {size_t(1) << 31}
size_t g_max_memory_allocation_size {2000000000}
size_t g_min_memory_allocation_size
Initial value:
{
256}

Definition at line 117 of file Execute.cpp.

Referenced by create_dev_group_by_buffers(), and CommandLineOptions::fillAdvancedOptions().

bool g_null_div_by_zero {false}
bool g_optimize_cuda_block_and_grid_sizes {false}
bool g_optimize_row_initialization {true}
size_t g_overlaps_max_table_size_bytes {1024 * 1024 * 1024}
double g_overlaps_target_entries_per_bin {1.3}
unsigned g_pending_query_interrupt_freq {1000}
size_t g_query_resultset_cache_total_bytes {size_t(1) << 32}
double g_running_query_interrupt_freq {0.1}
bool g_strip_join_covered_quals {false}
bool g_use_estimator_result_cache {true}
size_t g_watchdog_none_encoded_string_translation_limit {1000000UL}
std::unique_ptr<llvm::Module> udf_cpu_module
std::unique_ptr<llvm::Module> udf_gpu_module