OmniSciDB
a5dc49c757
|
This is the complete list of members for PerfectJoinHashTable, including all inherited members.
canAccessHashTable(bool allow_hash_table_recycling, bool invalid_cache_key, JoinType join_type) | HashJoin | static |
checkHashJoinReplicationConstraint(const shared::TableKey &table_key, const size_t shard_count, const Executor *executor) | HashJoin | static |
codegenColOrStringOper(const Analyzer::Expr *col_or_string_oper, const std::vector< StringOps_Namespace::StringOpInfo > &string_op_infos, CodeGenerator &code_generator, const CompilationOptions &co) | HashJoin | protectedstatic |
codegenHashTableLoad(const size_t table_idx) | PerfectJoinHashTable | private |
HashJoin::codegenHashTableLoad(const size_t table_idx, Executor *executor) | HashJoin | static |
codegenMatchingSet(const CompilationOptions &, const size_t) override | PerfectJoinHashTable | virtual |
HashJoin::codegenMatchingSet(const std::vector< llvm::Value * > &hash_join_idx_args_in, const bool is_sharded, const bool col_is_nullable, const bool is_bw_eq, const int64_t sub_buff_size, Executor *executor, const bool is_bucketized=false) | HashJoin | static |
codegenSlot(const CompilationOptions &, const size_t) override | PerfectJoinHashTable | virtual |
col_range_ | PerfectJoinHashTable | private |
col_var_ | PerfectJoinHashTable | private |
collectFragmentIds(const std::vector< Fragmenter_Namespace::FragmentInfo > &fragments) | HashJoin | static |
column_cache_ | PerfectJoinHashTable | private |
copyCpuHashTableToGpu(std::shared_ptr< PerfectHashTable > &cpu_hash_table, const PerfectHashTableEntryInfo hash_table_entry_info, const int device_id, Data_Namespace::DataMgr *data_mgr) | PerfectJoinHashTable | private |
countBufferOff() const noexceptoverride | PerfectJoinHashTable | virtual |
cpu_hash_table_buff_mutex_ | PerfectJoinHashTable | private |
device_count_ | PerfectJoinHashTable | private |
executor_ | PerfectJoinHashTable | private |
fetchColumnsForDevice(const std::vector< Fragmenter_Namespace::FragmentInfo > &fragments, const int device_id, DeviceAllocator *dev_buff_owner) | PerfectJoinHashTable | private |
fetchJoinColumn(const Analyzer::ColumnVar *hash_col, const std::vector< Fragmenter_Namespace::FragmentInfo > &fragment_info, const Data_Namespace::MemoryLevel effective_memory_level, const int device_id, std::vector< std::shared_ptr< Chunk_NS::Chunk >> &chunks_owner, DeviceAllocator *dev_buff_owner, std::vector< std::shared_ptr< void >> &malloc_owner, Executor *executor, ColumnCacheMap *column_cache) | HashJoin | |
freeHashBufferMemory() | HashJoin | inline |
genChunkKey(const std::vector< Fragmenter_Namespace::FragmentInfo > &fragments, const Analyzer::Expr *outer_col, const Analyzer::ColumnVar *inner_col) const | PerfectJoinHashTable | private |
generateTooManyHashEntriesErrMsg(size_t num_entries, size_t threshold, MemoryLevel memory_level) | HashJoin | inlinestatic |
getAlternativeCacheKey(AlternativeCacheKeyForPerfectHashJoin &info) | PerfectJoinHashTable | inlineprivatestatic |
getComponentBufferSize() const noexceptoverride | PerfectJoinHashTable | privatevirtual |
getCompositeKeyInfo(const std::vector< InnerOuter > &inner_outer_pairs, const Executor *executor, const std::vector< InnerOuterStringOpInfos > &inner_outer_string_op_infos_pairs={}) | HashJoin | static |
getDeviceCount() const noexceptoverride | PerfectJoinHashTable | inlinevirtual |
getEffectiveMemoryLevel(const std::vector< InnerOuter > &inner_outer_pairs) const | PerfectJoinHashTable | private |
getHashEntryInfo() const | PerfectJoinHashTable | inline |
getHashingSchemeCache() | PerfectJoinHashTable | inlinestatic |
getHashJoinArgs(llvm::Value *hash_ptr, llvm::Value *key_lvs, const Analyzer::Expr *key_col, const int shard_count, const CompilationOptions &co) | PerfectJoinHashTable | private |
getHashJoinColumn(const Analyzer::Expr *expr) | HashJoin | static |
getHashJoinType() const final | PerfectJoinHashTable | inlinevirtual |
getHashTableCache() | PerfectJoinHashTable | inlinestatic |
getHashTableForDevice(const size_t device_id) const | PerfectJoinHashTable | private |
getHashType() const noexceptoverride | PerfectJoinHashTable | inlinevirtual |
getHashTypeString(HashType ht) noexcept | HashJoin | inlinestatic |
getInnerQueryInfo(const Analyzer::ColumnVar *inner_col) const | PerfectJoinHashTable | private |
getInnerTableId() const noexceptoverride | PerfectJoinHashTable | inlinevirtual |
HashJoin::getInnerTableId(const std::vector< InnerOuter > &inner_outer_pairs) | HashJoin | inlinestatic |
getInnerTableRteIdx() const noexceptoverride | PerfectJoinHashTable | inlinevirtual |
getInstance(const std::shared_ptr< Analyzer::BinOper > qual_bin_oper, const std::vector< InputTableInfo > &query_infos, const Data_Namespace::MemoryLevel memory_level, const JoinType join_type, const HashType preferred_hash_type, const int device_count, ColumnCacheMap &column_cache, Executor *executor, const HashTableBuildDagMap &hashtable_build_dag_map, const RegisteredQueryHint &query_hints, const TableIdToNodeMap &table_id_to_node_map) | PerfectJoinHashTable | static |
getJoinHashBuffer(const ExecutorDeviceType device_type, const int device_id) const | HashJoin | inline |
getJoinHashBufferSize(const ExecutorDeviceType device_type) | HashJoin | inline |
getJoinHashBufferSize(const ExecutorDeviceType device_type, const int device_id) const | HashJoin | inline |
getMaximumNumHashEntriesCanHold(MemoryLevel memory_level, const Executor *executor, size_t rowid_size) noexcept | HashJoin | static |
getMemoryLevel() const noexceptoverride | PerfectJoinHashTable | inlinevirtual |
getNormalizedHashEntryCount() const | PerfectJoinHashTable | inline |
getRegisteredQueryHint() | PerfectJoinHashTable | inline |
getStrDictProxies(const InnerOuter &cols, const Executor *executor, const bool has_string_ops) | HashJoin | static |
getSyntheticInstance(std::string_view table1, std::string_view column1, const Catalog_Namespace::Catalog &catalog1, std::string_view table2, std::string_view column2, const Catalog_Namespace::Catalog &catalog2, const Data_Namespace::MemoryLevel memory_level, const HashType preferred_hash_type, const int device_count, ColumnCacheMap &column_cache, Executor *executor) | HashJoin | static |
getSyntheticInstance(const std::shared_ptr< Analyzer::BinOper > qual_bin_oper, const Data_Namespace::MemoryLevel memory_level, const HashType preferred_hash_type, const int device_count, ColumnCacheMap &column_cache, Executor *executor) | HashJoin | static |
getSyntheticInstance(std::vector< std::shared_ptr< Analyzer::BinOper >>, const Data_Namespace::MemoryLevel memory_level, const HashType preferred_hash_type, const int device_count, ColumnCacheMap &column_cache, Executor *executor) | HashJoin | static |
hash_entry_info_ | PerfectJoinHashTable | mutableprivate |
hash_table_cache_ | PerfectJoinHashTable | privatestatic |
hash_table_layout_cache_ | PerfectJoinHashTable | privatestatic |
hash_tables_for_device_ | HashJoin | protected |
hash_type_ | PerfectJoinHashTable | private |
hashtable_build_dag_map_ | PerfectJoinHashTable | private |
hashtable_cache_key_ | PerfectJoinHashTable | private |
hashtable_cache_meta_info_ | PerfectJoinHashTable | private |
initHashTableForDevice(const ChunkKey &chunk_key, const JoinColumn &join_column, const InnerOuter &cols, const HashType layout, const Data_Namespace::MemoryLevel effective_memory_level, const int device_id) | PerfectJoinHashTable | private |
initHashTableOnCpuFromCache(QueryPlanHash key, CacheItemType item_type, DeviceIdentifier device_identifier) | PerfectJoinHashTable | private |
inner_outer_pairs_ | PerfectJoinHashTable | private |
inner_outer_string_op_infos_ | PerfectJoinHashTable | private |
invalidateCache() | PerfectJoinHashTable | inlinestatic |
isBitwiseEq() const override | PerfectJoinHashTable | privatevirtual |
isOneToOneHashPossible(const std::vector< ColumnsForDevice > &columns_per_device) const | PerfectJoinHashTable | private |
join_type_ | PerfectJoinHashTable | private |
layoutRequiresAdditionalBuffers(HashType layout) noexcept | HashJoin | inlinestatic |
markCachedItemAsDirty(size_t table_key) | PerfectJoinHashTable | inlinestatic |
MAX_NUM_HASH_ENTRIES | HashJoin | static |
memory_level_ | PerfectJoinHashTable | private |
needs_dict_translation_ | PerfectJoinHashTable | mutableprivate |
normalizeColumnPair(const Analyzer::Expr *lhs, const Analyzer::Expr *rhs, const TemporaryTables *temporary_tables, const bool is_bbox_intersect=false) | HashJoin | static |
normalizeColumnPairs(const Analyzer::BinOper *condition, const TemporaryTables *temporary_tables) | HashJoin | static |
offsetBufferOff() const noexceptoverride | PerfectJoinHashTable | virtual |
payloadBufferOff() const noexceptoverride | PerfectJoinHashTable | virtual |
PerfectJoinHashTable(const std::shared_ptr< Analyzer::BinOper > qual_bin_oper, const Analyzer::ColumnVar *col_var, const std::vector< InputTableInfo > &query_infos, const Data_Namespace::MemoryLevel memory_level, const JoinType join_type, const HashType preferred_hash_type, const ExpressionRange &col_range, const ExpressionRange &rhs_source_col_range, const BucketizedHashEntryInfo hash_entry_info, ColumnCacheMap &column_cache, Executor *executor, const int device_count, const RegisteredQueryHint &query_hints, const HashTableBuildDagMap &hashtable_build_dag_map, const TableIdToNodeMap &table_id_to_node_map, const size_t rowid_size, const InnerOuterStringOpInfos &inner_outer_string_op_infos={}) | PerfectJoinHashTable | inlineprivate |
putHashTableOnCpuToCache(QueryPlanHash key, CacheItemType item_type, std::shared_ptr< PerfectHashTable > hashtable_ptr, DeviceIdentifier device_identifier, size_t hashtable_building_time) | PerfectJoinHashTable | private |
qual_bin_oper_ | PerfectJoinHashTable | private |
query_hints_ | PerfectJoinHashTable | private |
query_infos_ | PerfectJoinHashTable | private |
reify() | PerfectJoinHashTable | private |
reifyForDevice(const ChunkKey &hash_table_key, const ColumnsForDevice &columns_for_device, const HashType layout, const int device_id, const logger::ThreadLocalIds) | PerfectJoinHashTable | private |
rhs_source_col_range_ | PerfectJoinHashTable | private |
rowid_size_ | PerfectJoinHashTable | private |
shardCount() const | PerfectJoinHashTable | private |
str_proxy_translation_map_ | PerfectJoinHashTable | private |
str_proxy_translation_mutex_ | PerfectJoinHashTable | private |
table_id_to_node_map_ | PerfectJoinHashTable | private |
table_keys_ | PerfectJoinHashTable | private |
toSet(const ExecutorDeviceType device_type, const int device_id) const override | PerfectJoinHashTable | virtual |
toString(const ExecutorDeviceType device_type, const int device_id=0, bool raw=false) const override | PerfectJoinHashTable | virtual |
toStringFlat32(const ExecutorDeviceType device_type, const int device_id) const | HashJoin | virtual |
toStringFlat64(const ExecutorDeviceType device_type, const int device_id) const | HashJoin | virtual |
translateCompositeStrDictProxies(const CompositeKeyInfo &composite_key_info, const std::vector< InnerOuterStringOpInfos > &string_op_infos_for_keys, const Executor *executor) | HashJoin | static |
translateInnerToOuterStrDictProxies(const InnerOuter &cols, const InnerOuterStringOpInfos &inner_outer_string_op_infos, ExpressionRange &old_col_range, const Executor *executor) | HashJoin | static |
~PerfectJoinHashTable() | PerfectJoinHashTable | inlinevirtual |