Column-oriented GPU-accelerated Database Management System
CoGaDB
CoGaDB Namespace Reference

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< TIDPositionList
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< ColumnPtrColumnVector
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, TIDTID_Pair
typedef std::pair
< AttributeType, std::string > 
Attribut
typedef std::list< AttributTableSchema
typedef std::vector< boost::any > Tuple
typedef BaseTable::TablePtr TablePtr
typedef std::vector< int > Flags
typedef boost::shared_ptr< FlagsFlagsPtr
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, ColumnPtrreduce_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, ColumnPtrreduce_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< ColumnPtrfinalizeGroupingColumns (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'

Detailed Description

The global namespace of the programming tasks, to avoid name claches with other libraries.


Typedef Documentation

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 std::vector<int> CoGaDB::Flags
typedef boost::shared_ptr<Flags> CoGaDB::FlagsPtr
typedef shared_pointer_namespace::shared_ptr<LookupColumn> CoGaDB::LookupColumnPtr
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 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 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

Enumeration Type Documentation

anonymous enum
Enumerator:
WALK_OK 
WALK_BADPATTERN 
WALK_NAMETOOLONG 
WALK_BADIO 
Enumerator:
SUM 
MIN 
MAX 
SUM 
MIN 
MAX 
Enumerator:
SUM 
MIN 
MAX 
SUM 
MIN 
MAX 
Enumerator:
INT 
FLOAT 
VARCHAR 
BOOLEAN 
INT 
FLOAT 
VARCHAR 
BOOLEAN 
Enumerator:
INT 
FLOAT 
VARCHAR 
BOOLEAN 
INT 
FLOAT 
VARCHAR 
BOOLEAN 
Enumerator:
ADD 
SUB 
MUL 
DIV 
Enumerator:
CPU 
GPU 
CPU 
GPU 
Enumerator:
CPU 
GPU 
CPU 
GPU 
Enumerator:
quiet 
verbose 
debug 
print_time_measurement 
quiet 
verbose 
debug 
print_time_measurement 
Enumerator:
quiet 
verbose 
debug 
print_time_measurement 
quiet 
verbose 
debug 
print_time_measurement 
Enumerator:
SORT_MERGE_JOIN 
NESTED_LOOP_JOIN 
HASH_JOIN 
SORT_MERGE_JOIN 
SORT_MERGE_JOIN_2 
NESTED_LOOP_JOIN 
HASH_JOIN 
Enumerator:
SORT_MERGE_JOIN 
NESTED_LOOP_JOIN 
HASH_JOIN 
SORT_MERGE_JOIN 
SORT_MERGE_JOIN_2 
NESTED_LOOP_JOIN 
HASH_JOIN 
Enumerator:
MATERIALIZE 
LOOKUP 
MATERIALIZE 
LOOKUP 
Enumerator:
MATERIALIZE 
LOOKUP 
MATERIALIZE 
LOOKUP 
Enumerator:
SELECTION 
PROJECTION 
JOIN 
GROUPBY 
SORT 
COPY 
AGGREGATION 
FULL_SCAN 
INDEX_SCAN 
SELECTION 
PROJECTION 
JOIN 
GROUPBY 
SORT 
COPY 
AGGREGATION 
FULL_SCAN 
INDEX_SCAN 
Enumerator:
SELECTION 
PROJECTION 
JOIN 
GROUPBY 
SORT 
COPY 
AGGREGATION 
FULL_SCAN 
INDEX_SCAN 
SELECTION 
PROJECTION 
JOIN 
GROUPBY 
SORT 
COPY 
AGGREGATION 
FULL_SCAN 
INDEX_SCAN 
Enumerator:
SERIAL 
PARALLEL 
SERIAL 
PARALLEL 
Enumerator:
SERIAL 
PARALLEL 
SERIAL 
PARALLEL 
Enumerator:
POSITIONLIST_INTERSECTION 
POSITIONLIST_UNION 
Enumerator:
ValueValuePredicate 
ValueConstantPredicate 
Enumerator:
ASCENDING 
DESCENDING 
ASCENDING 
DESCENDING 
Enumerator:
ASCENDING 
DESCENDING 
ASCENDING 
DESCENDING 
Enumerator:
LESSER 
GREATER 
EQUAL 
LESSER 
GREATER 
EQUAL 
LESSER_EQUAL 
GREATER_EQUAL 
Enumerator:
LESSER 
GREATER 
EQUAL 
LESSER 
GREATER 
EQUAL 
LESSER_EQUAL 
GREATER_EQUAL 

Function Documentation

int CoGaDB::compareTupleValues ( vector< ColumnPtr > &  grouping_columns,
int  j,
int  k 
)

References debug, quiet, and verbose.

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().

Here is the caller graph for this function:

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().

Here is the caller graph for this function:

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().

Here is the caller graph for this function:

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().

Here is the caller graph for this function:

Referenced by CoGaDB::GPU_Column_Cache::getGPUColumn(), and CoGaDB::GPU_Column_Cache::printStatus().

Here is the caller graph for this function:

const TablePtr CoGaDB::getTablebyName ( const std::string &  name)

References getGlobalTableList().

Referenced by CoGaDB::SQL::ParseTree::InsertInto::execute(), and CoGaDB::optimizer::getListOfAvailableAttributes().

Here is the call graph for this function:

Here is the caller graph for this function:

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().

Here is the caller graph for this function:

bool CoGaDB::is_regular_file ( const std::string &  path)

Referenced by loadTables().

Here is the caller graph for this function:

bool CoGaDB::LoadDatabase ( ) [inline]

References loadTables().

Here is the call graph for this function:

const TablePtr CoGaDB::loadTable ( const std::string &  table_name)

References debug, getFilesinDirectory(), getTimestamp(), CoGaDB::RuntimeConfiguration::instance(), quiet, and verbose.

Referenced by loadTables().

Here is the call graph for this function:

Here is the caller graph for this function:

References getFilesinDirectory(), getGlobalTableList(), CoGaDB::RuntimeConfiguration::instance(), is_regular_file(), and loadTable().

Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter(), and LoadDatabase().

Here is the call graph for this function:

Here is the caller graph for this function:

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().

Here is the caller graph for this function:

std::ostream& CoGaDB::operator<< ( std::ostream &  os,
const boost::any &  v 
) [inline]
template<class T >
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 <<.

template<>
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 <<.

References getGlobalTableList().

Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().

Here is the call graph for this function:

Here is the caller graph for this function:

Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().

Here is the caller graph for this function:

bool CoGaDB::printVariableValue ( const std::string &  input)

Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().

Here is the caller graph for this function:

template<typename T , typename U , typename BinaryOperator >
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().

Here is the call graph for this function:

Here is the caller graph for this function:

template<typename T , typename U >
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 
)

References MAX, MIN, reduce_by_keys(), and SUM.

Here is the call graph for this function:

std::string CoGaDB::rle_encode_string ( const std::string  s)

Referenced by CoGaDB::RLECompressedColumn< T >::insert().

Here is the caller graph for this function:

template<class T >
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 
)
template<typename T >
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 
)
template<typename T >
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().

Here is the call graph for this function:

Here is the caller graph for this function:

bool CoGaDB::setVariable ( const std::string &  input)

Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().

Here is the caller graph for this function:

bool CoGaDB::storeTable ( const TablePtr  tab)

References CoGaDB::RuntimeConfiguration::instance().

Referenced by Unittest_Create_Star_Schema_Benchmark_Database(), and Unittest_Create_TPCH_Database().

Here is the call graph for this function:

Here is the caller graph for this function:

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().

Here is the call graph for this function:

Here is the caller graph for this function:

Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().

Here is the caller graph for this function:

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().

Here is the call graph for this function:

Here is the caller graph for this function:

bool CoGaDB::Unittest_Create_TPCH_Database ( const std::string &  path_to_files)

References FLOAT, getTimestamp(), INT, storeTable(), and VARCHAR.

Referenced by CoGaDB::CommandLineInterpreter::CommandLineInterpreter().

Here is the call graph for this function:

Here is the caller graph for this function:


Variable Documentation

 All Classes Namespaces Files Functions Variables Typedefs Enumerations Enumerator Friends Defines