logo

BlazingSQL v0.19 documentation

Contents:

  • Getting started
  • BlazingSQL Engine
    • Technology Stack
    • Python User Interface
    • Relational algebra
    • BlazingSQL Execution Graph
    • Kernels
    • Caches
    • Task Executor
    • Memory Management
    • Communication
    • Interops
    • I/O
    • Data Structures
  • Use cases
    • Industry solutions
      • Urban planning
      • Healthcare
    • Data science solutions
    • GPU Accelerated Data Science
  • API Reference
    • Python API Reference
      • BlazingContext()
        • blazingsql.BlazingContext
        • blazingsql.BlazingContext.create_table
        • blazingsql.BlazingContext.drop_table
        • blazingsql.BlazingContext.describe_table
        • blazingsql.BlazingContext.list_tables
        • blazingsql.BlazingContext.partition
        • blazingsql.BlazingContext.add_remove_table
        • blazingsql.BlazingContext.sql
        • blazingsql.BlazingContext.explain
        • blazingsql.BlazingContext.fetch
        • blazingsql.BlazingContext.status
        • blazingsql.BlazingContext.do_progress_bar
        • blazingsql.BlazingContext.get_free_memory
        • blazingsql.BlazingContext.get_max_memory_used
        • blazingsql.BlazingContext.reset_max_memory_used
      • Storage Plugins
        • blazingsql.BlazingContext.gs
        • blazingsql.BlazingContext.hdfs
        • blazingsql.BlazingContext.localfs
        • blazingsql.BlazingContext.s3
        • blazingsql.BlazingContext.show_filesystems
      • Create tables
        • Query Hive Tables
        • Query Apache ORC Files
        • Query Apache Parquet Files
        • Query pandas DataFrames
        • Query cuDF DataFrames
        • Query dask_cudf DataFrames
        • Query Plain Text Files
    • SQL API Reference
      • Data types
      • Querying data
      • Converting data types
      • Aggregating data
      • Functions and operators
        • Operators
        • Conditional functions
        • Mathematical functions
        • String functions
        • Date and timestamp functions
      • Joining data
      • Analytic functions
    • C++ API Reference
      • Namespace blazingdb
      • Namespace blazingdb::manager
      • Namespace blazingdb::transport
      • Namespace comm
      • Namespace comm::detail
      • Namespace ctpl
      • Namespace ctpl::detail
      • Namespace dbg_macro
      • Namespace dbg_macro::detail_detector
      • Namespace fmt::literals
      • Namespace interops
      • Namespace io
      • Namespace ral
      • Namespace ral::batch
      • Namespace ral::cache
      • Namespace ral::communication
      • Namespace ral::communication::messages
      • Namespace ral::distribution
      • Namespace ral::distribution::@40
      • Namespace ral::execution
      • Namespace ral::frame
      • Namespace ral::io
      • Namespace ral::io::@127
      • Namespace ral::io::@134
      • Namespace ral::io::sql_tools
      • Namespace ral::memory
      • Namespace ral::operators
      • Namespace ral::operators::@141
      • Namespace ral::parser
      • Namespace ral::parser::detail
      • Namespace ral::processor
      • Namespace ral::processor::@66
      • Namespace ral::processor::strings
      • Namespace ral::skip_data
      • Namespace ral::skip_data::@146
      • Namespace ral::utilities
      • Namespace std::chrono_literals
      • Namespace strings
      • Namespace strings::detail
      • Namespace strings::detail::@161
      • Struct ColumnTransport
      • Struct ColumnTransport::MetaData
      • Struct BlazingMissingMetadataException
      • Struct blazing_ucp_tag
      • Struct ucp_progress_manager::request_struct
      • Struct ucx_request
      • Template Struct detector
      • Template Struct detector< Default, void_t< Op< Args… > >, Op, Args… >
      • Struct nonesuch
      • Template Struct has_begin_end_size
      • Struct node
      • Struct tree_processor
      • Struct cache_settings
      • Struct graph::Edge
      • Struct graph_progress
      • Template Struct port_helper
      • Template Struct port_helper< PORT >
      • Template Struct port_helper< PORT, PORTNAME, PORTNAMES… >
      • Struct task_result
      • Struct callb
      • Struct cudf_string_col
      • Struct data_handle
      • Struct mysql_columns_info
      • Struct mysql_table_info
      • Struct sql_datasource
      • Struct sql_info
      • Struct operator_info
      • Struct sqlite_columns_info
      • Struct sqlite_table_info
      • Struct blazing_allocation
      • Struct blazing_allocation_chunk
      • Struct blazing_chunked_column_info
      • Struct expr_output_type_visitor
      • Struct cast_to_str_functor
      • Class blazing_context_ref_counter
      • Class blazing_device_memory_resource
      • Class blazing_disk_memory_resource
      • Class blazing_host_memory_resource
      • Class Context
      • Class Node
      • Class Status
      • Class BlazingMemoryResource
      • Class CodeTimer
      • Class buffer_transport
      • Class graphs_info
      • Class message_listener
      • Class message_receiver
      • Class message_sender
      • Class node
      • Class tcp_buffer_transport
      • Class tcp_message_listener
      • Class ucp_progress_manager
      • Class ucx_buffer_transport
      • Class ucx_message_listener
      • Template Class Queue
      • Template Class thread_pool
      • Class DataParser
      • Class DebugOutput
      • Class internal_blazing_device_memory_resource
      • Class internal_blazing_host_memory_resource
      • Class BatchSequence
      • Class BatchSequenceBypass
      • Class BindableTableScan
      • Class ComputeAggregateKernel
      • Class ComputeWindowKernel
      • Class DistributeAggregateKernel
      • Class Filter
      • Class JoinPartitionKernel
      • Class LimitKernel
      • Class MergeAggregateKernel
      • Class MergeStreamKernel
      • Class OutputKernel
      • Class OverlapAccumulatorKernel
      • Class OverlapGeneratorKernel
      • Class PartitionKernel
      • Class PartitionSingleNodeKernel
      • Class PartwiseJoin
      • Class Print
      • Class Projection
      • Class SortAndSampleKernel
      • Class TableScan
      • Class UnionKernel
      • Class CacheData
      • Class CacheDataIO
      • Class CacheDataLocalFile
      • Class CacheMachine
      • Class ConcatCacheData
      • Class ConcatenatingCacheMachine
      • Class CPUCacheData
      • Class distributing_kernel
      • Class GPUCacheData
      • Class graph
      • Class kernel
      • Class kpair
      • Class message
      • Class MetadataDictionary
      • Class port
      • Template Class WaitingQueue
      • Class AddressExchanger
      • Class AddressExchangerForReceiver
      • Class AddressExchangerForSender
      • Class CommunicationData
      • Class ErrorHandling
      • Class UcpWorkerAddress
      • Class executor
      • Class priority
      • Class task
      • Class BlazingColumn
      • Class BlazingColumnOwner
      • Class BlazingColumnView
      • Class BlazingHostTable
      • Class BlazingTable
      • Class BlazingTableView
      • Class abstractsql_data_provider
      • Class abstractsql_parser
      • Class arrow_parser
      • Class csv_parser
      • Class data_loader
      • Class data_parser
      • Class data_provider
      • Class gdf_data_provider
      • Class gdf_parser
      • Class json_parser
      • Class mysql_data_provider
      • Class mysql_parser
      • Class orc_parser
      • Class parquet_parser
      • Class postgresql_data_provider
      • Class postgresql_parser
      • Class Schema
      • Class default_predicate_transformer
      • Class sqlite_data_provider
      • Class sqlite_parser
      • Class uri_data_provider
      • Class allocation_pool
      • Class base_allocator
      • Class buffer_providers
      • Class host_allocator
      • Class pinned_allocator
      • Class MemoryMonitor
      • Class function_evaluator_transformer
      • Enum _error
      • Enum AggregateKind
      • Enum blazing_protocol
      • Enum status_code
      • Enum column_index
      • Enum operator_type
      • Enum CacheDataType
      • Enum CacheType
      • Enum kernel_type
      • Enum kstatus
      • Enum task_status
      • Enum blazing_column_type
      • Enum DataType
      • Enum format_char_type
      • Enum timestamp_parse_component
      • Enum timestamp_units
      • Function BlazingRMMFinalize
      • Function BlazingRMMInitialize
      • Function bypassingProject(std::string, std::vector<std::string>)
      • Function bypassingProject(std::string, std::vector<std::string>)
      • Function clean_calcite_expression(const std::string&)
      • Function clean_calcite_expression(const std::string&)
      • Function clean_window_function_expressions(const std::vector<std::string>&, size_t)
      • Function clean_window_function_expressions(const std::vector<std::string>&, size_t)
      • Function clear_graphs
      • Function comm::deserialize_from_gpu_raw_buffers
      • Template Function comm::detail::from_byte_vector
      • Function comm::detail::get_metadata_and_transports_and_buffer_sizes_from_bytes
      • Function comm::detail::serialize_metadata_and_transports_and_buffer_sizes
      • Template Function comm::detail::to_byte_vector
      • Template Function comm::detail::vector_from_byte_vector
      • Template Function comm::detail::vector_to_byte_vector
      • Function comm::poll_for_frames
      • Function comm::recv_begin_callback_c
      • Function concat_strings
      • Function convert_concat_expression_into_multiple_binary_concat_ops(std::string)
      • Function convert_concat_expression_into_multiple_binary_concat_ops(std::string)
      • Function count_string_occurrence(std::string, std::string)
      • Function count_string_occurrence(std::string, std::string)
      • Function create_logger
      • Template Function dbg_macro::prettyPrint(std::ostream&, const T&)
      • Function dbg_macro::prettyPrint(std::ostream&, const bool&)
      • Function dbg_macro::prettyPrint(std::ostream&, const char&)
      • Template Function dbg_macro::prettyPrint(std::ostream&, P *const&)
      • Template Function dbg_macro::prettyPrint(std::ostream&, const char(&))
      • Function dbg_macro::prettyPrint(std::ostream&, const char *const&)
      • Template Function dbg_macro::prettyPrint(std::ostream&, Container const&)
      • Function dbg_macro::prettyPrint(std::ostream&, const std::string&)
      • Template Function dbg_macro::type_name
      • Function dbg_macro::type_name< std::string >
      • Template Function dbg_macro::type_name_impl
      • Function expand_if_logical_op(std::string)
      • Function expand_if_logical_op(std::string)
      • Function extract_table_name(std::string)
      • Function extract_table_name(std::string)
      • Function fill_minus_op_with_zero(std::string)
      • Function fill_minus_op_with_zero(std::string)
      • Function finalize
      • Function finalize_C
      • Function find_closing_char
      • Function fix_column_aliases(const std::vector<std::string>&, std::string)
      • Function fix_column_aliases(const std::vector<std::string>&, std::string)
      • Function fix_column_names_duplicated
      • Function generate_graph(std::vector<ral::io::data_loader>, std::vector<ral::io::Schema>, std::vector<std::string>, std::vector<std::string>, std::string, Context&, const std::string&)
      • Function generate_graph(std::vector<ral::io::data_loader>, std::vector<ral::io::Schema>, std::vector<std::string>, std::vector<std::string>, std::string, Context&, const std::string&)
      • Function get_aggregation_operation_string(std::string)
      • Function get_aggregation_operation_string(std::string)
      • Function get_all_str_values_in_the_same_col
      • Function get_all_values_in_the_same_col
      • Function get_bounds_from_window_expression(const std::string&)
      • Function get_bounds_from_window_expression(const std::string&)
      • Function get_cols_to_apply_window_and_cols_to_apply_agg(const std::string&)
      • Function get_cols_to_apply_window_and_cols_to_apply_agg(const std::string&)
      • Function get_execute_graph_results(std::shared_ptr<ral::cache::graph>)
      • Function get_execute_graph_results(std::shared_ptr<ral::cache::graph>)
      • Function get_expressions_from_expression_list(std::string&, bool)
      • Function get_expressions_from_expression_list(std::string&, bool)
      • Function get_first_over_expression_from_logical_plan(const std::string&, const std::string&)
      • Function get_first_over_expression_from_logical_plan(const std::string&, const std::string&)
      • Function get_frame_type_from_over_clause(const std::string&)
      • Function get_frame_type_from_over_clause(const std::string&)
      • Function get_index(const std::string&)
      • Function get_index(const std::string&)
      • Function get_ip
      • Function get_loaders_and_schemas
      • Function get_max_integer_scalar(cudf::data_type)
      • Function get_max_integer_scalar(cudf::data_type)
      • Function get_minmax_metadata(std::vector<cudf::io::parsed_orc_statistics>&, size_t, int)
      • Function get_minmax_metadata(std::vector<cudf::io::parsed_orc_statistics>&, size_t, int)
      • Function get_minmax_metadata(std::vector<std::unique_ptr<parquet::ParquetFileReader>>&, size_t, int)
      • Function get_minmax_metadata(std::vector<std::unique_ptr<parquet::ParquetFileReader>>&, size_t, int)
      • Function get_named_expression(const std::string&, const std::string&)
      • Function get_named_expression(const std::string&, const std::string&)
      • Function get_output_type(operator_type)
      • Function get_output_type(operator_type, cudf::type_id)
      • Function get_output_type(operator_type, cudf::type_id, cudf::type_id)
      • Function get_output_type(operator_type, cudf::type_id)
      • Function get_output_type(operator_type, cudf::type_id, cudf::type_id)
      • Function get_output_type(operator_type)
      • Function get_over_expression(std::string)
      • Function get_over_expression(std::string)
      • Function get_physical_plan(std::string, Context&)
      • Function get_physical_plan(std::string, Context&)
      • Function get_projections(const std::string&)
      • Function get_projections(const std::string&)
      • Function get_query_part(std::string)
      • Function get_query_part(std::string)
      • Function get_scalar_from_string(const std::string&, cudf::data_type, bool)
      • Function get_scalar_from_string(const std::string&, cudf::data_type, bool)
      • Function get_string_between_outer_parentheses(std::string)
      • Function get_string_between_outer_parentheses(std::string)
      • Function get_table_index(std::vector<std::string>, std::string)
      • Function get_table_index(std::vector<std::string>, std::string)
      • Function get_tokens_in_reverse_order(const std::string&)
      • Function get_tokens_in_reverse_order(const std::string&)
      • Function get_typed_vector_content(cudf::type_id, std::vector<int64_t>&)
      • Function get_typed_vector_content(cudf::type_id, std::vector<int64_t>&)
      • Function get_typed_vector_str_content
      • Function getExecuteGraphResult
      • Function getFreeMemory
      • Function getMaxMemoryUsed
      • Function getProductDetails
      • Function getTableScanInfo(std::string&, std::vector<std::string>&, std::vector<std::string>&, std::vector<std::vector<int>>&)
      • Function getTableScanInfo(std::string&, std::vector<std::string>&, std::vector<std::string>&, std::vector<std::vector<int>>&)
      • Function getTableScanInfo(std::string)
      • Function handler
      • Function inferFolderPartitionMetadata
      • Function initialize
      • Function initialize_C
      • Function interops::add_expression_to_interpreter_plan
      • Function interops::perform_interpreter_operation
      • Function io::read_from_socket
      • Function io::write_to_socket
      • Function is_accumulate_overlaps(std::string)
      • Function is_accumulate_overlaps(std::string)
      • Function is_aggregate(std::string)
      • Function is_aggregate(std::string)
      • Function is_aggregate_and_sample
      • Function is_aggregate_merge
      • Function is_aggregate_partition
      • Function is_avg_window_function(std::string)
      • Function is_avg_window_function(std::string)
      • Function is_binary_operator(operator_type)
      • Function is_binary_operator(operator_type)
      • Function is_bindable_scan(std::string)
      • Function is_bindable_scan(std::string)
      • Function is_bool(const std::string&)
      • Function is_bool(const std::string&)
      • Function is_compute_aggregate(std::string)
      • Function is_compute_aggregate(std::string)
      • Function is_date(const std::string&)
      • Function is_date(const std::string&)
      • Function is_date_with_bar(const std::string&)
      • Function is_date_with_bar(const std::string&)
      • Function is_date_with_dash(const std::string&)
      • Function is_date_with_dash(const std::string&)
      • Function is_decimal_or_empty_dtype
      • Function is_distribute_aggregate(std::string)
      • Function is_distribute_aggregate(std::string)
      • Function is_filter(std::string)
      • Function is_filter(std::string)
      • Function is_filtered_bindable_scan(std::string)
      • Function is_filtered_bindable_scan(std::string)
      • Function is_first_value_window(std::string)
      • Function is_first_value_window(std::string)
      • Function is_generate_overlaps(std::string)
      • Function is_generate_overlaps(std::string)
      • Function is_hour(const std::string&)
      • Function is_hour(const std::string&)
      • Function is_inequality(const std::string&)
      • Function is_inequality(const std::string&)
      • Function is_join(const std::string&)
      • Function is_join(const std::string&)
      • Function is_join_expression(const std::string&)
      • Function is_join_expression(const std::string&)
      • Function is_join_partition(const std::string&)
      • Function is_join_partition(const std::string&)
      • Function is_lag_or_lead_aggregation(std::string)
      • Function is_lag_or_lead_aggregation(std::string)
      • Function is_last_value_window(std::string)
      • Function is_last_value_window(std::string)
      • Function is_limit(std::string)
      • Function is_limit(std::string)
      • Function is_literal(const std::string&)
      • Function is_literal(const std::string&)
      • Function is_logical_scan(std::string)
      • Function is_logical_scan(std::string)
      • Function is_merge(std::string)
      • Function is_merge(std::string)
      • Function is_merge_aggregate(std::string)
      • Function is_merge_aggregate(std::string)
      • Function is_null(const std::string&)
      • Function is_null(const std::string&)
      • Function is_nullary_operator(operator_type)
      • Function is_nullary_operator(operator_type)
      • Function is_number(const std::string&)
      • Function is_number(const std::string&)
      • Function is_operator_token(const std::string&)
      • Function is_operator_token(const std::string&)
      • Function is_pairwise_join(const std::string&)
      • Function is_pairwise_join(const std::string&)
      • Function is_partition(std::string)
      • Function is_partition(std::string)
      • Function is_project(std::string)
      • Function is_project(std::string)
      • Function is_scan(std::string)
      • Function is_scan(std::string)
      • Function is_single_node_partition(std::string)
      • Function is_single_node_partition(std::string)
      • Function is_sort(std::string)
      • Function is_sort(std::string)
      • Function is_sort_and_sample(std::string)
      • Function is_sort_and_sample(std::string)
      • Function is_SQL_data_type(const std::string&)
      • Function is_SQL_data_type(const std::string&)
      • Function is_string(const std::string&)
      • Function is_string(const std::string&)
      • Function is_sum_window_function(std::string)
      • Function is_sum_window_function(std::string)
      • Function is_timestamp(const std::string&)
      • Function is_timestamp(const std::string&)
      • Function is_timestamp_ms(const std::string&)
      • Function is_timestamp_ms(const std::string&)
      • Function is_timestamp_ms_with_bar(const std::string&)
      • Function is_timestamp_ms_with_bar(const std::string&)
      • Function is_timestamp_ms_with_dash(const std::string&)
      • Function is_timestamp_ms_with_dash(const std::string&)
      • Function is_timestamp_ns(const std::string&)
      • Function is_timestamp_ns(const std::string&)
      • Function is_timestamp_ns_with_bar(const std::string&)
      • Function is_timestamp_ns_with_bar(const std::string&)
      • Function is_timestamp_ns_with_dash(const std::string&)
      • Function is_timestamp_ns_with_dash(const std::string&)
      • Function is_timestamp_us(const std::string&)
      • Function is_timestamp_us(const std::string&)
      • Function is_timestamp_us_with_bar(const std::string&)
      • Function is_timestamp_us_with_bar(const std::string&)
      • Function is_timestamp_us_with_dash(const std::string&)
      • Function is_timestamp_us_with_dash(const std::string&)
      • Function is_timestamp_with_bar(const std::string&)
      • Function is_timestamp_with_bar(const std::string&)
      • Function is_timestamp_with_dash(const std::string&)
      • Function is_timestamp_with_dash(const std::string&)
      • Function is_timestamp_with_decimals(const std::string&)
      • Function is_timestamp_with_decimals(const std::string&)
      • Function is_timestamp_with_decimals_and_bar(const std::string&)
      • Function is_timestamp_with_decimals_and_bar(const std::string&)
      • Function is_timestamp_with_decimals_and_dash(const std::string&)
      • Function is_timestamp_with_decimals_and_dash(const std::string&)
      • Function is_type_bool(cudf::type_id)
      • Function is_type_bool(cudf::type_id)
      • Function is_type_float(cudf::type_id)
      • Function is_type_float(cudf::type_id)
      • Function is_type_integer(cudf::type_id)
      • Function is_type_integer(cudf::type_id)
      • Function is_type_string(cudf::type_id)
      • Function is_type_string(cudf::type_id)
      • Function is_type_timestamp(cudf::type_id)
      • Function is_type_timestamp(cudf::type_id)
      • Function is_unary_operator(operator_type)
      • Function is_unary_operator(operator_type)
      • Function is_union(std::string)
      • Function is_union(std::string)
      • Function is_var_column(const std::string&)
      • Function is_var_column(const std::string&)
      • Function is_window_compute(std::string)
      • Function is_window_compute(std::string)
      • Function is_window_function(std::string)
      • Function is_window_function(std::string)
      • Function isEmptyFile
      • Function log_level_str_to_enum
      • Function make_cudf_column_from_vector(cudf::data_type, std::basic_string<char>&, unsigned long)
      • Function make_cudf_column_from_vector(cudf::data_type, std::basic_string<char>&, unsigned long)
      • Function make_dummy_metadata_table_from_col_names(std::vector<std::string>)
      • Function make_dummy_metadata_table_from_col_names(std::vector<std::string>)
      • Function make_empty_column
      • Function map_to_operator_type(const std::string&)
      • Function map_to_operator_type(const std::string&)
      • Function parseMetadata
      • Function parseMetadata_C
      • Function parseSchema
      • Function parseSchema_C
      • Function printLoggerHeader
      • Function ral::batch::get_projections_wrapper
      • Function ral::batch::parseExpressionToGetTypeAndCondition
      • Function ral::batch::parseJoinConditionToColumnIndices
      • Function ral::batch::parseJoinConditionToEqualityTypes
      • Function ral::batch::reordering_columns_due_to_right_join
      • Function ral::batch::split_inequality_join_into_join_and_filter
      • Function ral::cache::create_cache_machine
      • Function ral::cache::create_cache_machines
      • Function ral::cache::get_kernel_type_name
      • Template Function ral::cache::kick_port_helper
      • Function ral::cache::randomString
      • Function ral::cache::unique_message_id
      • Template Function ral::communication::CheckError(const bool, const std::string&, Callable&&)
      • Function ral::communication::CheckError(const bool, const std::string&)
      • Function ral::communication::CreatetUcpWorker
      • Function ral::communication::CreateUcpContext
      • Function ral::communication::CreateUcpEp
      • Function ral::communication::failure_handler
      • Function ral::communication::GetUcpWorkerAddress
      • Function ral::communication::messages::deserialize_from_gpu_raw_buffers
      • Function ral::communication::messages::serialize_gpu_message_to_gpu_containers
      • Function ral::communication::messages::serialize_gpu_message_to_host_table
      • Function ral::communication::request_init
      • Function ral::distribution::generatePartitionPlans
      • Function ral::distribution::getPartitionPlan
      • Function ral::distribution::getPivotPointsTable
      • Function ral::distribution::partitionData
      • Function ral::distribution::sortedMerger
      • Function ral::frame::createEmptyBlazingTable(std::vector<cudf::type_id>, std::vector<std::string>)
      • Function ral::frame::createEmptyBlazingTable(std::vector<cudf::data_type>, std::vector<std::string>)
      • Function ral::frame::cudfTableViewToBlazingColumns
      • Template Function ral::io::build_fixed_width_cudf_col
      • Function ral::io::build_jdbc_mysql_connection
      • Function ral::io::build_str_cudf_col
      • Function ral::io::date_to_string
      • Function ral::io::date_to_ymd
      • Function ral::io::execute_mysql_query
      • Function ral::io::execute_sqlite_query
      • Function ral::io::get_mysql_columns_info
      • Function ral::io::get_mysql_table_info
      • Function ral::io::get_sqlite_columns_info
      • Function ral::io::get_sqlite_table_info
      • Function ral::io::getCsvReaderOptions
      • Function ral::io::getDataTypeName
      • Function ral::io::getJsonReaderOptions
      • Function ral::io::getOrcReaderOptions
      • Function ral::io::getSqlInfo
      • Function ral::io::in
      • Function ral::io::inferDataType
      • Function ral::io::inferFileType
      • Function ral::io::init
      • Function ral::io::map_contains
      • Function ral::io::mysql_is_cudf_string
      • Function ral::io::ord
      • Function ral::io::parse_mysql_column_type
      • Function ral::io::parse_mysql_column_types
      • Function ral::io::parse_postgresql_column_type
      • Function ral::io::parse_sqlite_column_type
      • Function ral::io::postgresql_is_cudf_string
      • Template Function ral::io::set_sql_predicate_pushdown
      • Template Function ral::io::set_sql_projections
      • Function ral::io::sql_tools::generate_predicate
      • Function ral::io::sql_tools::get_default_operators
      • Function ral::io::sql_tools::in_order
      • Function ral::io::sql_tools::parse_blazingsql_predicate
      • Function ral::io::sql_tools::transform_predicate
      • Function ral::io::sql_tools::transpile_predicate
      • Function ral::io::sqlite_is_cudf_string
      • Function ral::io::sqlite_is_string_col_type
      • Function ral::io::time_to_hms
      • Function ral::io::timestamp_to_string
      • Function ral::io::timestamp_to_tm
      • Function ral::io::to_bool
      • Function ral::io::to_int
      • Function ral::io::to_map
      • Function ral::io::to_vector_int
      • Function ral::io::to_vector_string
      • Function ral::memory::convert_gpu_buffers_to_chunks
      • Function ral::memory::empty_pools
      • Function ral::memory::set_allocation_pools
      • Function ral::operators::aggregator_to_string
      • Function ral::operators::compute_aggregations_with_groupby
      • Function ral::operators::compute_aggregations_without_groupby
      • Function ral::operators::compute_groupby_without_aggregations
      • Function ral::operators::compute_total_samples
      • Function ral::operators::generate_partition_plan
      • Function ral::operators::get_aggregation_operation
      • Function ral::operators::get_aggregation_output_type
      • Function ral::operators::get_group_columns
      • Function ral::operators::get_limit_rows_when_relational_alg_is_simple
      • Function ral::operators::get_right_sorts_vars
      • Function ral::operators::get_sort_vars
      • Function ral::operators::get_vars_to_orders
      • Function ral::operators::get_vars_to_partition
      • Function ral::operators::get_vars_to_partition_and_order
      • Function ral::operators::has_limit_only
      • Function ral::operators::limit_table
      • Function ral::operators::logicalSort
      • Function ral::operators::makeCudfAggregation
      • Function ral::operators::merge
      • Function ral::operators::modGroupByParametersPostComputeAggregations
      • Function ral::operators::parseGroupByExpression
      • Function ral::operators::partition_table
      • Function ral::operators::sample
      • Function ral::operators::sort
      • Function ral::parser::detail::infer_type_from_literal_token
      • Function ral::parser::detail::type_from_type_token
      • Function ral::processor::applyBooleanFilter
      • Function ral::processor::check_if_has_nulls
      • Function ral::processor::evaluate_expressions
      • Function ral::processor::get_current_date_or_timestamp
      • Function ral::processor::is_logical_filter
      • Function ral::processor::process_distribution_table
      • Function ral::processor::process_filter
      • Function ral::processor::process_project
      • Function ral::processor::strings::evaluate_string_case_when_else
      • Function ral::processor::strings::evaluate_string_functions
      • Function ral::processor::strings::like_expression_to_regex_str
      • Function ral::processor::strings::map_trim_flag_to_strip_type
      • Function ral::skip_data::apply_skip_data_rules
      • Function ral::skip_data::drop_value
      • Function ral::skip_data::get_id
      • Function ral::skip_data::is_exclusion_unary_op
      • Function ral::skip_data::is_unsupported_binary_op
      • Function ral::skip_data::process_skipdata_for_table
      • Function ral::skip_data::split
      • Function ral::utilities::blazing_table_view_schema_to_string
      • Function ral::utilities::checkIfConcatenatingStringsWillOverflow(const std::vector<std::unique_ptr<BlazingTable>>&)
      • Function ral::utilities::checkIfConcatenatingStringsWillOverflow(const std::vector<BlazingTableView>&)
      • Template Function ral::utilities::column_to_vector
      • Function ral::utilities::concatTables(std::vector<std::unique_ptr<BlazingTable>>)
      • Function ral::utilities::concatTables(const std::vector<BlazingTableView>&)
      • Function ral::utilities::create_empty_table(const std::vector<std::string>&, const std::vector<cudf::data_type>&, std::vector<size_t>)
      • Function ral::utilities::create_empty_table(const std::vector<cudf::type_id>&)
      • Function ral::utilities::create_empty_table(const BlazingTableView&)
      • Function ral::utilities::get_common_type
      • Function ral::utilities::get_common_types
      • Function ral::utilities::getLimitedRows
      • Function ral::utilities::normalize_types
      • Function ral::utilities::print_blazing_table_view
      • Function ral::utilities::print_blazing_table_view_schema
      • Function ral::utilities::transform_length_to_end
      • Function ral::utilities::transform_start_to_zero_based_indexing
      • Function ral::utilities::type_string
      • Template Function ral::utilities::vector_to_column
      • Function registerFileSystem
      • Function registerFileSystemGCS
      • Function registerFileSystemGCS_C
      • Function registerFileSystemHDFS
      • Function registerFileSystemHDFS_C
      • Function registerFileSystemLocal
      • Function registerFileSystemLocal_C
      • Function registerFileSystemS3
      • Function registerFileSystemS3_C
      • Function remove_over_expr(std::string)
      • Function remove_over_expr(std::string)
      • Function remove_quotes_from_timestamp_literal(const std::string&)
      • Function remove_quotes_from_timestamp_literal(const std::string&)
      • Function replace_calcite_regex(const std::string&)
      • Function replace_calcite_regex(const std::string&)
      • Function replace_count_expr_with_right_index(std::string, size_t)
      • Function replace_count_expr_with_right_index(std::string, size_t)
      • Function replace_is_not_distinct_as_calcite(std::string)
      • Function replace_is_not_distinct_as_calcite(std::string)
      • Function replace_sum0_expr_with_right_index(std::string, size_t)
      • Function replace_sum0_expr_with_right_index(std::string, size_t)
      • Function resetMaxMemoryUsed
      • Function runGenerateGraph
      • Function runGeneratePhysicalGraph
      • Function runSkipData
      • Function set_min_max(std::vector<int64_t>&, cudf::io::column_statistics&, int)
      • Function set_min_max(std::vector<std::vector<int64_t>>&, cudf::io::column_statistics&, int)
      • Function set_min_max(std::vector<std::vector<int64_t>>&, int, parquet::Type::type, parquet::ConvertedType::type, std::shared_ptr<parquet::Statistics>&)
      • Function set_min_max(std::vector<std::vector<int64_t>>&, int, parquet::Type::type, parquet::ConvertedType::type, std::shared_ptr<parquet::Statistics>&)
      • Function set_min_max_string
      • Function start_execute_graph(std::shared_ptr<ral::cache::graph>)
      • Function start_execute_graph(std::shared_ptr<ral::cache::graph>)
      • Function startExecuteGraph
      • Function statistic_to_dtype
      • Function str_to_timestamp_scalar_with_day_format
      • Function str_to_timestamp_scalar_with_decimal_format
      • Function str_to_timestamp_scalar_with_second_format
      • Function strings::detail::str_to_timestamp_scalar
      • Function strings::str_to_timestamp_scalar
      • Function to_dtype(cudf::io::statistics_type)
      • Function to_dtype(parquet::Type::type, parquet::ConvertedType::type)
      • Function type_statistic_valid
      • Function update_join_and_filter_expressions_from_is_not_distinct_expr(const std::string&)
      • Function update_join_and_filter_expressions_from_is_not_distinct_expr(const std::string&)
      • Function visitPartitionFolder
      • Function window_expression_contains_bounds(std::string)
      • Function window_expression_contains_bounds(std::string)
      • Function window_expression_contains_bounds_by_range(std::string)
      • Function window_expression_contains_bounds_by_range(std::string)
      • Function window_expression_contains_multiple_diff_over_clauses(std::string)
      • Function window_expression_contains_multiple_diff_over_clauses(std::string)
      • Function window_expression_contains_order_by(std::string)
      • Function window_expression_contains_order_by(std::string)
      • Function window_expression_contains_partition_by(std::string)
      • Function window_expression_contains_partition_by(std::string)
      • Variable ASCENDING_ORDER_SORT_TEXT
      • Variable BINDABLE_SCAN_TEXT
      • Variable column_bytes
      • Variable column_names
      • Variable column_types
      • Variable comm::acknownledge_tag_mask
      • Variable comm::begin_tag_mask
      • Variable comm::instance
      • Variable comm::instance_mutex
      • Variable comm::message_tag_mask
      • Variable DESCENDING_ORDER_SORT_TEXT
      • Variable drop_value_
      • Variable FILE_RETRY_DELAY
      • Variable initialize_lock
      • Variable initialized
      • Variable item_type
      • Variable items
      • Variable length
      • Variable LOGICAL_ACCUMULATE_OVERLAPS_TEXT
      • Variable LOGICAL_AGGREGATE_TEXT
      • Variable LOGICAL_COMPUTE_AGGREGATE_TEXT
      • Variable LOGICAL_COMPUTE_WINDOW_TEXT
      • Variable LOGICAL_DISTRIBUTE_AGGREGATE_TEXT
      • Variable LOGICAL_FILTER_TEXT
      • Variable LOGICAL_GENERATE_OVERLAPS_TEXT
      • Variable LOGICAL_JOIN_PARTITION_TEXT
      • Variable LOGICAL_JOIN_TEXT
      • Variable LOGICAL_LIMIT_TEXT
      • Variable LOGICAL_MERGE_AGGREGATE_TEXT
      • Variable LOGICAL_MERGE_TEXT
      • Variable LOGICAL_PARTITION_TEXT
      • Variable LOGICAL_PARTWISE_JOIN_TEXT
      • Variable LOGICAL_PROJECT_TEXT
      • Variable LOGICAL_SCAN_TEXT
      • Variable LOGICAL_SINGLE_NODE_PARTITION_TEXT
      • Variable LOGICAL_SORT_AND_SAMPLE_TEXT
      • Variable LOGICAL_SORT_TEXT
      • Variable LOGICAL_UNION_TEXT
      • Variable NUMBER_RETRIES
      • Variable ral::batch::BOTH_OVERLAP_TYPE
      • Variable ral::batch::CROSS_JOIN
      • Variable ral::batch::DONE_OVERLAP_STATUS
      • Variable ral::batch::FALSE
      • Variable ral::batch::FOLLOWING_OVERLAP_TYPE
      • Variable ral::batch::FOLLOWING_REQUEST
      • Variable ral::batch::FOLLOWING_RESPONSE
      • Variable ral::batch::INCOMPLETE_OVERLAP_STATUS
      • Variable ral::batch::INNER_JOIN
      • Variable ral::batch::LEFT_JOIN
      • Variable ral::batch::LEFT_TABLE_IDX
      • Variable ral::batch::OUTER_JOIN
      • Variable ral::batch::PRECEDING_OVERLAP_TYPE
      • Variable ral::batch::PRECEDING_REQUEST
      • Variable ral::batch::PRECEDING_RESPONSE
      • Variable ral::batch::RIGHT_JOIN
      • Variable ral::batch::RIGHT_TABLE_IDX
      • Variable ral::batch::TASK_ARG_OP_TYPE
      • Variable ral::batch::TASK_ARG_OVERLAP_SIZE
      • Variable ral::batch::TASK_ARG_OVERLAP_TYPE
      • Variable ral::batch::TASK_ARG_REMOVE_FOLLOWING_OVERLAP
      • Variable ral::batch::TASK_ARG_REMOVE_PRECEDING_OVERLAP
      • Variable ral::batch::TASK_ARG_SOURCE_BATCH_INDEX
      • Variable ral::batch::TASK_ARG_TARGET_BATCH_INDEX
      • Variable ral::batch::TASK_ARG_TARGET_NODE_INDEX
      • Variable ral::batch::TRUE
      • Variable ral::batch::UNKNOWN_OVERLAP_STATUS
      • Variable ral::cache::ADD_TO_SPECIFIC_CACHE_METADATA_LABEL
      • Variable ral::cache::AVG_BYTES_PER_ROW_METADATA_LABEL
      • Variable ral::cache::CACHE_ID_METADATA_LABEL
      • Variable ral::cache::CACHE_LEVEL_AUTO
      • Variable ral::cache::CACHE_LEVEL_CPU
      • Variable ral::cache::CACHE_LEVEL_DISK
      • Variable ral::cache::CACHE_LEVEL_GPU
      • Variable ral::cache::JOIN_LEFT_BYTES_METADATA_LABEL
      • Variable ral::cache::JOIN_RIGHT_BYTES_METADATA_LABEL
      • Variable ral::cache::KERNEL_ID_METADATA_LABEL
      • Variable ral::cache::MESSAGE_ID
      • Variable ral::cache::OVERLAP_MESSAGE_TYPE
      • Variable ral::cache::OVERLAP_SIZE
      • Variable ral::cache::OVERLAP_SOURCE_NODE_INDEX
      • Variable ral::cache::OVERLAP_STATUS
      • Variable ral::cache::OVERLAP_TARGET_BATCH_INDEX
      • Variable ral::cache::OVERLAP_TARGET_NODE_INDEX
      • Variable ral::cache::PARTITION_COUNT
      • Variable ral::cache::QUERY_ID_METADATA_LABEL
      • Variable ral::cache::RAL_ID_METADATA_LABEL
      • Variable ral::cache::SENDER_WORKER_ID_METADATA_LABEL
      • Variable ral::cache::TOTAL_TABLE_ROWS_METADATA_LABEL
      • Variable ral::cache::UNIQUE_MESSAGE_ID
      • Variable ral::cache::WORKER_IDS_METADATA_LABEL
      • Variable ral::communication::err_handling_opt
      • Variable ral::io::mysql_string_types_hints
      • Variable ral::io::postgresql_string_type_hints
      • Variable ral::operators::ASCENDING_ORDER_SORT_TEXT
      • Variable ral::operators::DESCENDING_ORDER_SORT_TEXT
      • Variable units
      • Variable value
      • Define ACK_BUFFER_SIZE
      • Define BLAZING_ALIGNMENT
      • Define BLAZINGDB_RAL_SRC_IO_DATA_PARSER_METADATA_COMMON_METADATA_CPP_H_
      • Define BLAZINGDB_RAL_SRC_IO_DATA_PARSER_METADATA_ORC_METADATA_CPP_H_
      • Define BLAZINGDB_RAL_SRC_IO_DATA_PARSER_METADATA_PARQUET_METADATA_CPP_H_
      • Define BZ_INTERFACE
      • Define checkError
      • Define debug_log
      • Define DefineClassName
      • Define RAISE_ERROR
      • Define RAL_EXPECTS
      • Define RAL_FAIL
      • Define RAL_STRINGIFY
      • Define STRINGIFY_DETAIL
      • Define UC_INLINE
      • Typedef blazingdb::manager::Node
      • Typedef cudaStream_t
      • Typedef CudfColumn
      • Typedef CudfColumnView
      • Typedef CudfTable
      • Typedef CudfTable
      • Typedef CudfTableView
      • Typedef CudfTableView
      • Typedef dbg_macro::detail_detector::void_t
      • Typedef dbg_macro::detect_begin_t
      • Typedef dbg_macro::detect_end_t
      • Typedef dbg_macro::detect_size_t
      • Typedef dbg_macro::is_detected
      • Typedef error_code_t
      • Typedef interops::column_index_type
      • Typedef ral::batch::Context
      • Typedef ral::batch::frame_type
      • Typedef ral::cache::Context
      • Typedef ral::cache::kernel_pair
      • Typedef ral::communication::messages::ColumnTransport
      • Typedef ral::communication::messages::gpu_raw_buffer_container
      • Typedef ral::communication::messages::Node
      • Typedef ral::distribution::BlazingTable
      • Typedef ral::distribution::BlazingTableView
      • Typedef ral::distribution::Context
      • Typedef ral::distribution::Node
      • Typedef ral::distribution::NodeColumn
      • Typedef ral::distribution::NodeColumnView
      • Typedef ral::frame::ColumnTransport
      • Typedef ral::memory::Buffer
Theme by the Executable Book Project
Contents
  • Definition ( engine/src/execution_graph/logic_controllers/BatchProcessing.h )
  • Includes
  • Included By
  • Namespaces
  • Classes
  • Typedefs

File BatchProcessing.h¶

↰ Parent directory (engine/src/execution_graph/logic_controllers)

Contents

  • Definition (engine/src/execution_graph/logic_controllers/BatchProcessing.h)

  • Includes

  • Included By

  • Namespaces

  • Classes

  • Typedefs

Definition (engine/src/execution_graph/logic_controllers/BatchProcessing.h)¶

Includes¶

  • CacheMachine.h (File CacheMachine.h)

  • execution_graph/logic_controllers/LogicPrimitives.h (File LogicPrimitives.h)

  • execution_graph/logic_controllers/taskflow/kernel.h (File kernel.h)

  • io/DataLoader.h (File DataLoader.h)

  • io/Schema.h (File Schema.h)

  • mutex

  • taskflow/graph.h (File graph.h)

Included By¶

  • File BatchOrderByProcessing.h

  • File BatchAggregationProcessing.h

  • File BatchJoinProcessing.h

  • File BatchUnionProcessing.h

  • File BatchWindowFunctionProcessing.h

  • File BatchProcessing.cpp

  • File graph.cpp

Namespaces¶

  • Namespace ral

  • Namespace ral::batch

Classes¶

  • Class BatchSequence

  • Class BatchSequenceBypass

  • Class BindableTableScan

  • Class Filter

  • Class OutputKernel

  • Class Print

  • Class Projection

  • Class TableScan

Typedefs¶

  • Typedef ral::batch::frame_type

By BlazingDB, Inc.
© Copyright 2020, BlazingDB, Inc.