Column-oriented GPU-accelerated Database Management System
CoGaDB
|
The global namespace of the programming tasks, to avoid name claches with other libraries. More...
Namespaces | |
namespace | gpu |
namespace | optimizer |
namespace | query_processing |
namespace | SQL |
namespace | unit_tests |
namespace | util |
Classes | |
class | BitVectorCompressedColumn |
This class represents a bit vector compressed column with type T, is the base class for all compressed typed column classes. More... | |
class | DeltaCompressedColumn |
class | DeltaCompressedColumn< std::string > |
class | DictionaryCompressedColumn |
This class represents a dictionary compressed column with type T, is the base class for all compressed typed column classes. More... | |
class | RLECompressedColumn |
class | ColumnBase |
This class represents a generic column, is the base class for all column classes and allows a uniform handling of columns. More... | |
class | Column |
class | ColumnBaseTyped |
This class represents a column with type T, is the base class for all typed column classes and allows a uniform handling of columns of a certain type T. More... | |
class | CompressedColumn |
This class represents a compressed column with type T, is the base class for all compressed typed column classes and allows a uniform handling of compressed columns of a certain type T. More... | |
class | LookupArray |
A LookupArray is a LookupColumn which is applied on a materialized column (of the table that is indexed by the Lookup column) and hence has a Type. This class represents a column with type T, which is essentially a tid list describing which values of a typed materialized column are included in the LookupArray. More... | |
class | Test |
class | Test< std::string > |
class | BaseTable |
class | TBB_Body_PrefixSum |
class | DataDictionary |
class | GPU_Column_Cache |
class | RowTable |
class | RowValueColumn |
Interface for column based access to the early materialized table RowTable. More... | |
class | RuntimeConfiguration |
class | Predicate |
struct | KNF_Selection_Expression |
class | Table |
class | LookupColumn |
class | LookupTable |
class | CommandLineInterpreter |
class | BufferManager |
struct | BufferObject |
Abstract object with holds a Page and more information of it. Holds also Pointer to previous or next pages, which holds also data of the same column. This double linked list will be created by BufferManager. Iterate with prev() and next(). For debugging, printStatus() prints the page-status-byte of this and all next pages. More... | |
struct | Header |
class | Page |
Representation of a Page (content from file). Each page holds data from one column. However, all data at one page will be of same type. More... | |
class | RowPage |
Representation of a set of rows stored as bytes. More... | |
class | HardwareDetector |
struct | min_obj |
struct | max_obj |
Typedefs | |
typedef std::string | sstring |
typedef unsigned int | uint |
typedef unsigned char | uchar |
typedef std::vector< TID > | PositionList |
typedef shared_pointer_namespace::shared_ptr < PositionList > | PositionListPtr |
typedef std::pair < PositionListPtr, PositionListPtr > | PositionListPair |
typedef shared_pointer_namespace::shared_ptr < PositionListPair > | PositionListPairPtr |
typedef ColumnBase::ColumnPtr | ColumnPtr |
makes a smart pointer to a ColumnBase Object visible in the namespace | |
typedef std::vector< ColumnPtr > | ColumnVector |
typedef shared_pointer_namespace::shared_ptr < ColumnVector > | ColumnVectorPtr |
typedef CompressedColumn< int > | CompressedIntegerColumn |
typedef CompressedColumn< float > | CompressedFloatColumn |
typedef CompressedColumn< double > | CompressedDoubleColumn |
typedef CompressedColumn < std::string > | CompressedStringColumn |
typedef unsigned int | TID |
typedef std::pair< TID, TID > | TID_Pair |
typedef std::pair < AttributeType, std::string > | Attribut |
typedef std::list< Attribut > | TableSchema |
typedef std::vector< boost::any > | Tuple |
typedef BaseTable::TablePtr | TablePtr |
typedef std::vector< int > | Flags |
typedef boost::shared_ptr< Flags > | FlagsPtr |
typedef std::pair< std::string, AggregationMethod > | ColumnAggregation |
typedef RowTable::RowTablePtr | RowTablePtr |
typedef KNF_Selection_Expression::Disjunction | Disjunction |
typedef shared_pointer_namespace::shared_ptr < Table > | MaterializedTablePtr |
typedef shared_pointer_namespace::shared_ptr < LookupColumn > | LookupColumnPtr |
typedef std::vector < LookupColumnPtr > | LookupColumnVector |
typedef shared_pointer_namespace::shared_ptr < LookupColumnVector > | LookupColumnVectorPtr |
typedef LookupTable::LookupTablePtr | LookupTablePtr |
typedef shared_pointer_namespace::shared_ptr < BufferObject > | BuffObjPtr |
typedef shared_pointer_namespace::shared_ptr < Page > | PagePtr |
typedef shared_pointer_namespace::shared_ptr < RowPage > | RowPagePtr |
typedef hype::DeviceSpecification | DeviceSpecification |
typedef HardwareDetector::DeviceSpecifications | DeviceSpecifications |
typedef uint64_t | Timestamp |
Enumerations | |
enum | AttributeType { INT, FLOAT, VARCHAR, BOOLEAN, INT, FLOAT, VARCHAR, BOOLEAN } |
enum | ComputeDevice { CPU, GPU, CPU, GPU } |
enum | AggregationMethod { SUM, MIN, MAX, SUM, MIN, MAX } |
enum | ValueComparator { LESSER, GREATER, EQUAL, LESSER, GREATER, EQUAL, LESSER_EQUAL, GREATER_EQUAL } |
enum | SortOrder { ASCENDING, DESCENDING, ASCENDING, DESCENDING } |
enum | Operation { SELECTION, PROJECTION, JOIN, GROUPBY, SORT, COPY, AGGREGATION, FULL_SCAN, INDEX_SCAN, SELECTION, PROJECTION, JOIN, GROUPBY, SORT, COPY, AGGREGATION, FULL_SCAN, INDEX_SCAN } |
enum | JoinAlgorithm { SORT_MERGE_JOIN, NESTED_LOOP_JOIN, HASH_JOIN, SORT_MERGE_JOIN, SORT_MERGE_JOIN_2, NESTED_LOOP_JOIN, HASH_JOIN } |
enum | MaterializationStatus { MATERIALIZE, LOOKUP, MATERIALIZE, LOOKUP } |
enum | ParallelizationMode { SERIAL, PARALLEL, SERIAL, PARALLEL } |
enum | DebugMode { quiet = 1, verbose = 0, debug = 0, print_time_measurement = 0, quiet = 1, verbose = 0, debug = 0, print_time_measurement = 0 } |
enum | AttributeType { INT, FLOAT, VARCHAR, BOOLEAN, INT, FLOAT, VARCHAR, BOOLEAN } |
enum | ComputeDevice { CPU, GPU, CPU, GPU } |
enum | AggregationMethod { SUM, MIN, MAX, SUM, MIN, MAX } |
enum | ValueComparator { LESSER, GREATER, EQUAL, LESSER, GREATER, EQUAL, LESSER_EQUAL, GREATER_EQUAL } |
enum | PredicateType { ValueValuePredicate, ValueConstantPredicate } |
enum | SortOrder { ASCENDING, DESCENDING, ASCENDING, DESCENDING } |
enum | Operation { SELECTION, PROJECTION, JOIN, GROUPBY, SORT, COPY, AGGREGATION, FULL_SCAN, INDEX_SCAN, SELECTION, PROJECTION, JOIN, GROUPBY, SORT, COPY, AGGREGATION, FULL_SCAN, INDEX_SCAN } |
enum | JoinAlgorithm { SORT_MERGE_JOIN, NESTED_LOOP_JOIN, HASH_JOIN, SORT_MERGE_JOIN, SORT_MERGE_JOIN_2, NESTED_LOOP_JOIN, HASH_JOIN } |
enum | MaterializationStatus { MATERIALIZE, LOOKUP, MATERIALIZE, LOOKUP } |
enum | ParallelizationMode { SERIAL, PARALLEL, SERIAL, PARALLEL } |
enum | ColumnAlgebraOperation { ADD, SUB, MUL, DIV } |
enum | PositionListOperation { POSITIONLIST_INTERSECTION, POSITIONLIST_UNION } |
enum | DebugMode { quiet = 1, verbose = 0, debug = 0, print_time_measurement = 0, quiet = 1, verbose = 0, debug = 0, print_time_measurement = 0 } |
enum | { WALK_OK = 0, WALK_BADPATTERN, WALK_NAMETOOLONG, WALK_BADIO } |
Functions | |
std::string | rle_encode_string (const std::string s) |
const ColumnPtr | createColumn (AttributeType type, const std::string &name) |
Column factory function, creates an empty materialized column. | |
PositionListPtr | computePositionListUnion (PositionListPtr tids1, PositionListPtr tids2) |
computes the union of two position lists, e.g., to compute a logical OR in a complex selection, the tid lists resulting from several selections need to be united | |
PositionListPtr | computePositionListIntersection (PositionListPtr tids1, PositionListPtr tids2) |
computes the union of two position lists, e.g., to compute a logical AND in a complex selection, the tid lists resulting from several selections need to be intersected | |
template<class T > | |
void | selection_thread (unsigned int thread_id, unsigned int number_of_threads, const T &value, const ValueComparator comp, ColumnBaseTyped< T > *col, PositionListPtr result_tids) |
int | TBB_Prefix_Sum (std::vector< int > &y, const std::vector< int > &x, unsigned int number_of_threads) |
template<typename T > | |
void | selection_thread_set_flag_array (ColumnBaseTyped< T > *col, unsigned int thread_id, FlagsPtr flags, unsigned int number_of_threads, const T &value_for_comparison, const ValueComparator comp) |
template<typename T > | |
void | selection_thread_write_result_to_output_array (ColumnBaseTyped< T > *col, unsigned int thread_id, FlagsPtr flags, std::vector< int > *prefix_sum_array, PositionListPtr result_tids, unsigned int number_of_threads) |
ColumnPtr | createLookupArrayForColumn (ColumnPtr col, PositionListPtr tids_) |
PositionListPtr | getPositonListfromLookupArray (ColumnPtr col) |
const TableSchema | mergeTableSchemas (const TableSchema &schema1, const std::string &join_attributname_table1, const TableSchema &schema2, const std::string &join_attributname_table2) |
int | CUDA_device_check (int gpudevice) |
int | check_for_CUDA_devices () |
unsigned int | getNumberofGPUMultiprocessors () |
unsigned int | getTotalGPUMemorySizeInByte () |
unsigned int | getFreeGPUMemorySizeInByte () |
void | printGPUStatus () |
const std::vector< std::pair < unsigned int, unsigned int > > | gpu_join_tids (std::vector< int > &join_column1, std::vector< int > &join_column2) |
const LookupTablePtr | createLookupTableforUnaryOperation (const std::string &lookup_table_name, const TablePtr table, PositionListPtr ids) |
const TablePtr | loadTable (const std::string &table_name) |
bool | storeTable (const TablePtr tab) |
bool | loadTables () |
std::vector< TablePtr > & | getGlobalTableList () |
const TablePtr | getTablebyName (const std::string &name) |
bool | LoadDatabase () |
const std::vector< std::string > | getFilesinDirectory (std::string dname) |
bool | is_regular_file (const std::string &path) |
std::ostream & | operator<< (std::ostream &os, const boost::any &v) |
template<class T > | |
std::ostream & | operator<< (std::ostream &os, const std::vector< T > &v) |
A overload of std::vector<T> for operator <<, so that vector objects can be printed in CoGaDB by using operator <<. | |
template<> | |
std::ostream & | operator<< (std::ostream &os, const Tuple &v) |
Total template specialization for operator <<, so that different semantic can be implemented in contrast to std::vector<T>. This overload is a convinience function, so that Tuple objects can be printed by using operator <<. | |
template<typename T , typename U , typename BinaryOperator > | |
std::pair< ColumnPtr, ColumnPtr > | reduce_by_keys (shared_pointer_namespace::shared_ptr< ColumnBaseTyped< U > > keys, shared_pointer_namespace::shared_ptr< ColumnBaseTyped< T > > values, BinaryOperator binary_op) |
template<typename T , typename U > | |
std::pair< ColumnPtr, ColumnPtr > | reduce_by_keys (shared_pointer_namespace::shared_ptr< ColumnBaseTyped< U > > keys, shared_pointer_namespace::shared_ptr< ColumnBaseTyped< T > > values, AggregationMethod agg_meth) |
bool | Unittest_Create_Star_Schema_Benchmark_Database (const std::string &path_to_files) |
bool | SSB_Q11 () |
bool | SSB_Q12 () |
bool | SSB_Q13 () |
bool | SSB_Q21 () |
bool | SSB_Q22 () |
bool | SSB_Q23 () |
bool | SSB_Q31 () |
bool | SSB_Q32 () |
bool | SSB_Q33 () |
bool | SSB_Q34 () |
bool | SSB_Q41 () |
bool | SSB_Q42 () |
bool | SSB_Q43 () |
Timestamp | getTimestamp () |
void | fatalError (const std::string &message) |
bool | Unittest_Create_TPCH_Database (const std::string &path_to_files) |
int | compareTupleValues (vector< ColumnPtr > &grouping_columns, int j, int k) |
vector< ColumnPtr > | finalizeGroupingColumns (vector< ColumnPtr > grouping_column_ptrs, PositionListPtr position_list) |
void | column_template_instatiation () |
void | column_base_typed_template_instatiation () |
bool | printStatusOfGPUCache () |
bool | simple_SSB_Query_Selection () |
bool | simple_SSB_Query_Join () |
bool | simple_SSB_Query_Aggregation () |
bool | simple_SSB_Queries () |
bool | complex_tpch_queries () |
bool | printDatabaseSchema () |
bool | toggleQueryChopping () |
bool | help () |
bool | setVariable (const std::string &input) |
bool | setDefaultDevice (const std::string &input) |
bool | setDefaultParallelizationModeTwoPhasePhysicalOptimization (const std::string &input) |
bool | printVariableValue (const std::string &input) |
Variables | |
const char | one = '1' |
const char | zero = '0' |
The global namespace of the programming tasks, to avoid name claches with other libraries.
typedef std::pair< AttributeType, std::string > CoGaDB::Attribut |
typedef shared_pointer_namespace::shared_ptr<BufferObject> CoGaDB::BuffObjPtr |
typedef std::pair<std::string,AggregationMethod> CoGaDB::ColumnAggregation |
makes a smart pointer to a ColumnBase Object visible in the namespace
typedef std::vector< ColumnPtr > CoGaDB::ColumnVector |
typedef shared_pointer_namespace::shared_ptr< ColumnVector > CoGaDB::ColumnVectorPtr |
typedef CompressedColumn< double > CoGaDB::CompressedDoubleColumn |
typedef CompressedColumn< float > CoGaDB::CompressedFloatColumn |
typedef CompressedColumn< int > CoGaDB::CompressedIntegerColumn |
typedef CompressedColumn< std::string > CoGaDB::CompressedStringColumn |
typedef std::vector<int> CoGaDB::Flags |
typedef boost::shared_ptr<Flags> CoGaDB::FlagsPtr |
typedef shared_pointer_namespace::shared_ptr<LookupColumn> CoGaDB::LookupColumnPtr |
typedef std::vector<LookupColumnPtr> CoGaDB::LookupColumnVector |
typedef shared_pointer_namespace::shared_ptr<LookupColumnVector> CoGaDB::LookupColumnVectorPtr |
typedef shared_pointer_namespace::shared_ptr<Table> CoGaDB::MaterializedTablePtr |
typedef shared_pointer_namespace::shared_ptr<Page> CoGaDB::PagePtr |
SharedPointer to a Page
typedef std::vector< TID > CoGaDB::PositionList |
typedef std::pair< PositionListPtr, PositionListPtr > CoGaDB::PositionListPair |
typedef shared_pointer_namespace::shared_ptr< PositionListPair > CoGaDB::PositionListPairPtr |
typedef shared_pointer_namespace::shared_ptr< PositionList > CoGaDB::PositionListPtr |
typedef shared_pointer_namespace::shared_ptr<RowPage> CoGaDB::RowPagePtr |
typedef std::string CoGaDB::sstring |
typedef BaseTable::TablePtr CoGaDB::TablePtr |
typedef std::list< Attribut > CoGaDB::TableSchema |
typedef unsigned int CoGaDB::TID |
typedef std::pair< TID, TID > CoGaDB::TID_Pair |
typedef uint64_t CoGaDB::Timestamp |
typedef std::vector< boost::any > CoGaDB::Tuple |
typedef unsigned char CoGaDB::uchar |
typedef unsigned int CoGaDB::uint |
enum CoGaDB::DebugMode |
enum CoGaDB::DebugMode |
enum CoGaDB::Operation |
enum CoGaDB::Operation |
enum CoGaDB::SortOrder |
enum CoGaDB::SortOrder |
int CoGaDB::check_for_CUDA_devices | ( | ) |
void CoGaDB::column_template_instatiation | ( | ) |
int CoGaDB::compareTupleValues | ( | vector< ColumnPtr > & | grouping_columns, |
int | j, | ||
int | k | ||
) |
bool CoGaDB::complex_tpch_queries | ( | ) |
References hype::queryprocessing::LogicalQueryPlan< Type >::convertToPhysicalQueryPlan(), CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), GREATER, CoGaDB::RuntimeConfiguration::instance(), LESSER, LOOKUP, and hype::queryprocessing::LogicalQueryPlan< Type >::print().
PositionListPtr CoGaDB::computePositionListIntersection | ( | PositionListPtr | tids1, |
PositionListPtr | tids2 | ||
) |
computes the union of two position lists, e.g., to compute a logical AND in a complex selection, the tid lists resulting from several selections need to be intersected
Referenced by CoGaDB::query_processing::physical_operator::CPU_PositionList_Operator::execute().
PositionListPtr CoGaDB::computePositionListUnion | ( | PositionListPtr | tids1, |
PositionListPtr | tids2 | ||
) |
computes the union of two position lists, e.g., to compute a logical OR in a complex selection, the tid lists resulting from several selections need to be united
Referenced by CoGaDB::query_processing::physical_operator::CPU_PositionList_Operator::execute().
const ColumnPtr CoGaDB::createColumn | ( | AttributeType | type, |
const std::string & | name | ||
) |
Column factory function, creates an empty materialized column.
References BOOLEAN, FLOAT, INT, and VARCHAR.
Referenced by CoGaDB::Table::Table(), and CoGaDB::RowValueColumn< T >::toColumn().
ColumnPtr CoGaDB::createLookupArrayForColumn | ( | ColumnPtr | col, |
PositionListPtr | tids_ | ||
) | [inline] |
References BOOLEAN, FLOAT, INT, CoGaDB::ColumnBaseTyped< T >::type(), and VARCHAR.
Referenced by CoGaDB::query_processing::physical_operator::CPU_column_constant_filter_operator::execute(), CoGaDB::query_processing::physical_operator::GPU_column_constant_filter_operator::execute(), CoGaDB::query_processing::physical_operator::ColumnComparatorOperation::execute(), and CoGaDB::query_processing::physical_operator::CPU_PositionList_Operator::execute().
const LookupTablePtr CoGaDB::createLookupTableforUnaryOperation | ( | const std::string & | lookup_table_name, |
const TablePtr | table, | ||
PositionListPtr | ids | ||
) |
References CoGaDB::LookupTable::aggregate(), and quiet.
Referenced by CoGaDB::BaseTable::AddConstantValueColumnOperation(), CoGaDB::unit_tests::basicGPUacceleratedQueryTest(), CoGaDB::BaseTable::ColumnAlgebraOperation(), CoGaDB::BaseTable::ColumnConstantOperation(), CoGaDB::BaseTable::createResultTable(), CoGaDB::BaseTable::crossjoin(), and CoGaDB::BaseTable::join().
int CoGaDB::CUDA_device_check | ( | int | gpudevice | ) |
void CoGaDB::fatalError | ( | const std::string & | message | ) |
vector<ColumnPtr> CoGaDB::finalizeGroupingColumns | ( | vector< ColumnPtr > | grouping_column_ptrs, |
PositionListPtr | position_list | ||
) |
const std::vector< std::string > CoGaDB::getFilesinDirectory | ( | std::string | dname | ) |
References WALK_BADIO, and WALK_OK.
Referenced by CoGaDB::Table::load(), loadTable(), and loadTables().
unsigned int CoGaDB::getFreeGPUMemorySizeInByte | ( | ) |
Referenced by CoGaDB::GPU_Column_Cache::getGPUColumn(), and CoGaDB::GPU_Column_Cache::printStatus().
std::vector< TablePtr > & CoGaDB::getGlobalTableList | ( | ) |
Referenced by CoGaDB::unit_tests::addConstantColumnTest(), CoGaDB::unit_tests::basicQueryTest(), CoGaDB::unit_tests::ColumnorientedQueryPlanTest(), CoGaDB::unit_tests::complexSelectionTest(), CoGaDB::unit_tests::crossjoinTest(), CoGaDB::SQL::ParseTree::CreateTable::execute(), CoGaDB::DataDictionary::getAttributeType(), CoGaDB::DataDictionary::getColumnsforColumnName(), getTablebyName(), loadTables(), printDatabaseSchema(), and CoGaDB::unit_tests::TableBasedColumnConstantOperatorTest().
unsigned int CoGaDB::getNumberofGPUMultiprocessors | ( | ) |
PositionListPtr CoGaDB::getPositonListfromLookupArray | ( | ColumnPtr | col | ) | [inline] |
References BOOLEAN, FLOAT, CoGaDB::LookupArray< T >::getPositionList(), INT, CoGaDB::ColumnBaseTyped< T >::type(), and VARCHAR.
Referenced by CoGaDB::query_processing::physical_operator::CPU_PositionList_Operator::execute(), CoGaDB::BaseTable::selection(), and CoGaDB::query_processing::two_phase_physical_optimization_selection().
const TablePtr CoGaDB::getTablebyName | ( | const std::string & | name | ) |
References getGlobalTableList().
Referenced by CoGaDB::SQL::ParseTree::InsertInto::execute(), and CoGaDB::optimizer::getListOfAvailableAttributes().
Referenced by CoGaDB::SQL::commandlineExec(), CoGaDB::BaseTable::crossjoin(), CoGaDB::BaseTable::join(), CoGaDB::unit_tests::JoinPerformanceTest(), CoGaDB::RowTable::load(), loadTable(), CoGaDB::unit_tests::memory_benchmark(), CoGaDB::ColumnBaseTyped< T >::parallel_hash_join(), CoGaDB::BaseTable::projection(), hype::queryprocessing::PhysicalQueryPlan< Type >::run(), hype::queryprocessing::UnaryOperator< ColumnPtr, ColumnPtr >::run(), hype::queryprocessing::N_AryOperator< OperatorInputType, OperatorOutputType >::run(), hype::queryprocessing::BinaryOperator< TablePtr, TablePtr, TablePtr >::run(), hype::queryprocessing::LogicalQueryPlan< Type >::runChoppedPlan(), CoGaDB::BaseTable::selection(), CoGaDB::unit_tests::selectionTest(), simple_SSB_Queries(), CoGaDB::BaseTable::sort(), Unittest_Create_Star_Schema_Benchmark_Database(), and Unittest_Create_TPCH_Database().
unsigned int CoGaDB::getTotalGPUMemorySizeInByte | ( | ) |
Referenced by CoGaDB::GPU_Column_Cache::getGPUColumn(), CoGaDB::GPU_Column_Cache::instance(), and CoGaDB::GPU_Column_Cache::printStatus().
const std::vector<std::pair<unsigned int,unsigned int> > CoGaDB::gpu_join_tids | ( | std::vector< int > & | join_column1, |
std::vector< int > & | join_column2 | ||
) |
bool CoGaDB::help | ( | ) |
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().
bool CoGaDB::is_regular_file | ( | const std::string & | path | ) |
bool CoGaDB::LoadDatabase | ( | ) | [inline] |
const TablePtr CoGaDB::loadTable | ( | const std::string & | table_name | ) |
References debug, getFilesinDirectory(), getTimestamp(), CoGaDB::RuntimeConfiguration::instance(), quiet, and verbose.
Referenced by loadTables().
bool CoGaDB::loadTables | ( | ) |
References getFilesinDirectory(), getGlobalTableList(), CoGaDB::RuntimeConfiguration::instance(), is_regular_file(), and loadTable().
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and LoadDatabase().
const TableSchema CoGaDB::mergeTableSchemas | ( | const TableSchema & | schema1, |
const std::string & | join_attributname_table1, | ||
const TableSchema & | schema2, | ||
const std::string & | join_attributname_table2 | ||
) |
Referenced by CoGaDB::BaseTable::crossjoin(), and CoGaDB::BaseTable::join().
std::ostream& CoGaDB::operator<< | ( | std::ostream & | os, |
const boost::any & | v | ||
) | [inline] |
std::ostream& CoGaDB::operator<< | ( | std::ostream & | os, |
const std::vector< T > & | v | ||
) | [inline] |
A overload of std::vector<T> for operator <<, so that vector objects can be printed in CoGaDB by using operator <<.
std::ostream& CoGaDB::operator<< | ( | std::ostream & | os, |
const Tuple & | v | ||
) | [inline] |
Total template specialization for operator <<, so that different semantic can be implemented in contrast to std::vector<T>. This overload is a convinience function, so that Tuple objects can be printed by using operator <<.
bool CoGaDB::printDatabaseSchema | ( | ) |
References getGlobalTableList().
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().
void CoGaDB::printGPUStatus | ( | ) |
Referenced by CoGaDB::BaseTable::ColumnAlgebraOperation(), CoGaDB::BaseTable::ColumnConstantOperation(), and CoGaDB::BaseTable::selection().
bool CoGaDB::printStatusOfGPUCache | ( | ) |
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().
bool CoGaDB::printVariableValue | ( | const std::string & | input | ) |
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().
std::pair<ColumnPtr,ColumnPtr> CoGaDB::reduce_by_keys | ( | shared_pointer_namespace::shared_ptr< ColumnBaseTyped< U > > | keys, |
shared_pointer_namespace::shared_ptr< ColumnBaseTyped< T > > | values, | ||
BinaryOperator | binary_op | ||
) |
References CoGaDB::Column< T >::insert().
Referenced by CoGaDB::BaseTable::groupby(), and reduce_by_keys().
std::pair<ColumnPtr,ColumnPtr> CoGaDB::reduce_by_keys | ( | shared_pointer_namespace::shared_ptr< ColumnBaseTyped< U > > | keys, |
shared_pointer_namespace::shared_ptr< ColumnBaseTyped< T > > | values, | ||
AggregationMethod | agg_meth | ||
) |
std::string CoGaDB::rle_encode_string | ( | const std::string | s | ) |
Referenced by CoGaDB::RLECompressedColumn< T >::insert().
void CoGaDB::selection_thread | ( | unsigned int | thread_id, |
unsigned int | number_of_threads, | ||
const T & | value, | ||
const ValueComparator | comp, | ||
ColumnBaseTyped< T > * | col, | ||
PositionListPtr | result_tids | ||
) |
References EQUAL, GREATER, GREATER_EQUAL, LESSER, LESSER_EQUAL, and quiet.
void CoGaDB::selection_thread_set_flag_array | ( | ColumnBaseTyped< T > * | col, |
unsigned int | thread_id, | ||
FlagsPtr | flags, | ||
unsigned int | number_of_threads, | ||
const T & | value_for_comparison, | ||
const ValueComparator | comp | ||
) |
References EQUAL, GREATER, GREATER_EQUAL, LESSER, LESSER_EQUAL, and quiet.
void CoGaDB::selection_thread_write_result_to_output_array | ( | ColumnBaseTyped< T > * | col, |
unsigned int | thread_id, | ||
FlagsPtr | flags, | ||
std::vector< int > * | prefix_sum_array, | ||
PositionListPtr | result_tids, | ||
unsigned int | number_of_threads | ||
) |
bool CoGaDB::setDefaultDevice | ( | const std::string & | input | ) |
References ANY_DEVICE, CPU_ONLY, GPU_ONLY, CoGaDB::RuntimeConfiguration::instance(), and CoGaDB::RuntimeConfiguration::setGlobalDeviceConstraint().
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().
bool CoGaDB::setDefaultParallelizationModeTwoPhasePhysicalOptimization | ( | const std::string & | input | ) |
References CoGaDB::RuntimeConfiguration::instance(), PARALLEL, SERIAL, and CoGaDB::RuntimeConfiguration::setParallelizationModeForTwoPhasePhysicalOptimizationQueryPlans().
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().
bool CoGaDB::setVariable | ( | const std::string & | input | ) |
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().
bool CoGaDB::simple_SSB_Queries | ( | ) |
References CoGaDB::CommandLineInterpreter::getline(), getTimestamp(), input(), SSB_Q11(), SSB_Q12(), SSB_Q13(), SSB_Q21(), SSB_Q22(), SSB_Q23(), SSB_Q31(), SSB_Q32(), SSB_Q33(), SSB_Q34(), SSB_Q41(), SSB_Q42(), and SSB_Q43().
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().
bool CoGaDB::simple_SSB_Query_Aggregation | ( | ) |
References ASCENDING, hype::queryprocessing::LogicalQueryPlan< Type >::convertToPhysicalQueryPlan(), EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), CoGaDB::RuntimeConfiguration::instance(), LOOKUP, MATERIALIZE, MUL, hype::queryprocessing::LogicalQueryPlan< Type >::print(), and SUM.
bool CoGaDB::simple_SSB_Query_Join | ( | ) |
References hype::queryprocessing::LogicalQueryPlan< Type >::convertToPhysicalQueryPlan(), CPU_ONLY, EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), CoGaDB::RuntimeConfiguration::instance(), LOOKUP, and hype::queryprocessing::LogicalQueryPlan< Type >::print().
bool CoGaDB::simple_SSB_Query_Selection | ( | ) |
References hype::queryprocessing::LogicalQueryPlan< Type >::convertToPhysicalQueryPlan(), CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), GREATER, CoGaDB::RuntimeConfiguration::instance(), LOOKUP, and hype::queryprocessing::LogicalQueryPlan< Type >::print().
bool CoGaDB::SSB_Q11 | ( | ) |
References ASCENDING, CPU_ONLY, EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), GREATER_EQUAL, CoGaDB::RuntimeConfiguration::instance(), LESSER, LESSER_EQUAL, LOOKUP, MUL, CoGaDB::query_processing::optimize_and_execute(), and SUM.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and simple_SSB_Queries().
bool CoGaDB::SSB_Q12 | ( | ) |
References ASCENDING, CPU_ONLY, CoGaDB::KNF_Selection_Expression::disjunctions, EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), GREATER_EQUAL, CoGaDB::RuntimeConfiguration::instance(), LESSER_EQUAL, LOOKUP, MUL, CoGaDB::query_processing::optimize_and_execute(), SUM, and ValueConstantPredicate.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and simple_SSB_Queries().
bool CoGaDB::SSB_Q13 | ( | ) |
References ASCENDING, CPU_ONLY, CoGaDB::KNF_Selection_Expression::disjunctions, EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), GREATER_EQUAL, CoGaDB::RuntimeConfiguration::instance(), LESSER_EQUAL, LOOKUP, MUL, CoGaDB::query_processing::optimize_and_execute(), SUM, and ValueConstantPredicate.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and simple_SSB_Queries().
bool CoGaDB::SSB_Q21 | ( | ) |
References ASCENDING, CPU_ONLY, EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), CoGaDB::RuntimeConfiguration::instance(), LOOKUP, CoGaDB::query_processing::optimize_and_execute(), and SUM.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and simple_SSB_Queries().
bool CoGaDB::SSB_Q22 | ( | ) |
References ASCENDING, CPU_ONLY, CoGaDB::KNF_Selection_Expression::disjunctions, EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), GREATER_EQUAL, CoGaDB::RuntimeConfiguration::instance(), LESSER_EQUAL, LOOKUP, CoGaDB::query_processing::optimize_and_execute(), SUM, and ValueConstantPredicate.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and simple_SSB_Queries().
bool CoGaDB::SSB_Q23 | ( | ) |
References ASCENDING, CPU_ONLY, EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), CoGaDB::RuntimeConfiguration::instance(), LOOKUP, CoGaDB::query_processing::optimize_and_execute(), and SUM.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and simple_SSB_Queries().
bool CoGaDB::SSB_Q31 | ( | ) |
References ASCENDING, CPU_ONLY, CoGaDB::KNF_Selection_Expression::disjunctions, EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), GREATER_EQUAL, CoGaDB::RuntimeConfiguration::instance(), LESSER_EQUAL, LOOKUP, CoGaDB::query_processing::optimize_and_execute(), SUM, and ValueConstantPredicate.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and simple_SSB_Queries().
bool CoGaDB::SSB_Q32 | ( | ) |
References ASCENDING, CPU_ONLY, CoGaDB::KNF_Selection_Expression::disjunctions, EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), GREATER_EQUAL, CoGaDB::RuntimeConfiguration::instance(), LESSER_EQUAL, LOOKUP, CoGaDB::query_processing::optimize_and_execute(), SUM, and ValueConstantPredicate.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and simple_SSB_Queries().
bool CoGaDB::SSB_Q33 | ( | ) |
References ASCENDING, CPU_ONLY, CoGaDB::KNF_Selection_Expression::disjunctions, EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), GREATER_EQUAL, CoGaDB::RuntimeConfiguration::instance(), LESSER_EQUAL, LOOKUP, CoGaDB::query_processing::optimize_and_execute(), SUM, and ValueConstantPredicate.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and simple_SSB_Queries().
bool CoGaDB::SSB_Q34 | ( | ) |
References ASCENDING, CPU_ONLY, CoGaDB::KNF_Selection_Expression::disjunctions, EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), CoGaDB::RuntimeConfiguration::instance(), LOOKUP, CoGaDB::query_processing::optimize_and_execute(), SUM, and ValueConstantPredicate.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and simple_SSB_Queries().
bool CoGaDB::SSB_Q41 | ( | ) |
References ASCENDING, CPU_ONLY, CoGaDB::KNF_Selection_Expression::disjunctions, EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), CoGaDB::RuntimeConfiguration::instance(), LOOKUP, CoGaDB::query_processing::optimize_and_execute(), SUB, SUM, and ValueConstantPredicate.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and simple_SSB_Queries().
bool CoGaDB::SSB_Q42 | ( | ) |
References ASCENDING, CPU_ONLY, CoGaDB::KNF_Selection_Expression::disjunctions, EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), CoGaDB::RuntimeConfiguration::instance(), LOOKUP, CoGaDB::query_processing::optimize_and_execute(), SUB, SUM, and ValueConstantPredicate.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and simple_SSB_Queries().
bool CoGaDB::SSB_Q43 | ( | ) |
References ASCENDING, CPU_ONLY, CoGaDB::KNF_Selection_Expression::disjunctions, EQUAL, CoGaDB::RuntimeConfiguration::getGlobalDeviceConstraint(), CoGaDB::RuntimeConfiguration::instance(), LOOKUP, CoGaDB::query_processing::optimize_and_execute(), SUB, SUM, and ValueConstantPredicate.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and simple_SSB_Queries().
bool CoGaDB::storeTable | ( | const TablePtr | tab | ) |
References CoGaDB::RuntimeConfiguration::instance().
Referenced by Unittest_Create_Star_Schema_Benchmark_Database(), and Unittest_Create_TPCH_Database().
int CoGaDB::TBB_Prefix_Sum | ( | std::vector< int > & | y, |
const std::vector< int > & | x, | ||
unsigned int | number_of_threads | ||
) | [inline] |
References CoGaDB::TBB_Body_PrefixSum::get_sum().
Referenced by CoGaDB::ColumnBaseTyped< T >::lock_free_parallel_selection().
bool CoGaDB::toggleQueryChopping | ( | ) |
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().
bool CoGaDB::Unittest_Create_Star_Schema_Benchmark_Database | ( | const std::string & | path_to_files | ) |
References FLOAT, getTimestamp(), INT, storeTable(), and VARCHAR.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().
bool CoGaDB::Unittest_Create_TPCH_Database | ( | const std::string & | path_to_files | ) |
References FLOAT, getTimestamp(), INT, storeTable(), and VARCHAR.
Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().
const char CoGaDB::one = '1' |