Class List

Here are the classes, structs, unions and interfaces with brief descriptions:
__TBB_malloc_proxy_caller
tbb::interface5::concurrent_hash_map< Key, T, HashCompare, Allocator >::accessorAllows write access to elements and combines data access, locking, and garbage collection
tbb::affinity_partitionerAn affinity partitioner
tbb::internal::affinity_partitioner_base_v3Defines entry point for affinity partitioner into tbb run-time library
tbb::interface6::aggregatorBasic aggregator interface
tbb::interface6::aggregator_ext< handler_type >Aggregator base class and expert interface
tbb::interface6::aggregator_operation
tbb::aligned_space< T, N >Block of space aligned sufficiently to construct an array T with N elements
tbb::internal::allocate_additional_child_of_proxy
allocator_base
tbb::atomic< T >
tbb::atomic< void * >Specialization for atomic<void*>, for sake of not allowing arithmetic or operator->
tbb::internal::atomic_backoffClass that implements exponential backoff
atomic_impl
tbb::internal::atomic_selector< 1 >
tbb::internal::atomic_selector< 2 >
tbb::internal::atomic_selector< 4 >
tbb::internal::atomic_selector< 8 >
tbb::auto_partitionerAn auto partitioner
tbb::bad_last_allocException for concurrent containers
tbb::interface6::internal::basic_handler
tbb::interface6::internal::basic_operation< Body >
tbb::interface6::internal::basic_operation_base
tbb::blocked_range< Value >A range over which to iterate
tbb::blocked_range2d< RowValue, ColValue >A 2-dimensional range that models the Range concept
tbb::blocked_range3d< PageValue, RowValue, ColValue >A 3-dimensional range that models the Range concept
tbb::flow::interface6::broadcast_node< T >Forwards messages of type T to all successors
tbb::interface5::concurrent_hash_map< Key, T, HashCompare, Allocator >::bucket_accessorBucket accessor is to find, rehash, acquire a lock, and access a bucket
tbb::flow::interface6::buffer_node< T, A >Forwards messages in arbitrary order
tbb::flow::interface6::buffer_node< T, A >::buffer_operation
tbb::cache_aligned_allocator< T >
tbb::cache_aligned_allocator< void >Analogous to std::allocator<void>, as defined in ISO C++ Standard, Section 20.4.1
tbb::captured_exceptionThis class is used by TBB to propagate information about unhandled exceptions into the root thread
tbb::combinable< T >Thread-local storage with optional reduction
tbb::concurrent_bounded_queue< T, A >A high-performance thread-safe blocking concurrent bounded queue
tbb::interface5::concurrent_hash_map< Key, T, HashCompare, Allocator >
tbb::interface6::concurrent_lru_cache< key_type, value_type, value_functor_type >
tbb::interface5::concurrent_priority_queue< T, Compare, A >Concurrent priority queue
tbb::strict_ppl::concurrent_queue< T, A >A high-performance thread-safe non-blocking concurrent queue
tbb::deprecated::concurrent_queue< T, A >A high-performance thread-safe blocking concurrent bounded queue
tbb::interface5::concurrent_unordered_map< Key, T, Hasher, Key_equality, Allocator >
tbb::interface5::concurrent_unordered_map_traits< Key, T, Hash_compare, Allocator, Allow_multimapping >
tbb::interface5::concurrent_unordered_multimap< Key, T, Hasher, Key_equality, Allocator >
tbb::interface5::concurrent_unordered_multiset< Key, Hasher, Key_equality, Allocator >
tbb::interface5::concurrent_unordered_set< Key, Hasher, Key_equality, Allocator >
tbb::interface5::concurrent_unordered_set_traits< Key, Hash_compare, Allocator, Allow_multimapping >
tbb::concurrent_vector< T, A >
concurrent_vector_base
tbb::interface5::concurrent_hash_map< Key, T, HashCompare, Allocator >::const_accessorCombines data access, locking, and garbage collection
tbb::flow::interface6::continue_msgAn empty class used for messages that mean "I'm done"
tbb::flow::interface6::continue_node< Output >Implements an executable node that supports continue_msg -> Output
tbb::flow::interface6::continue_receiverBase class for receivers of completion messages
tbb::internal::critical_section_v4
tbb::empty_taskTask that does nothing. Useful for synchronization
tbb::interface6::enumerable_thread_specific< T, Allocator, ETS_key_type >
tbb::filter
tbb::interface6::filter_t< T, U >Class representing a chain of type-safe pipeline filters
tbb::final_scan_tagUsed to indicate that the final scan is being performed
tbb::interface6::fixed_pool
tbb::interface6::flattened2d< Container >
tbb::interface6::flow_controlInput_filter control to signal end-of-input for parallel_pipeline
tbb::flow::interface6::function_node< Input, Output, graph_buffer_policy, Allocator >Implements a function node that supports Input -> Output
tbb::flow::interface6::function_node< Input, Output, queueing, Allocator >Implements a function node that supports Input -> Output
tbb::internal::function_task< F >
tbb::flow::interface6::graphThe graph class
tbb::flow::interface6::graph_iterator< GraphContainerType, GraphNodeType >
tbb::flow::interface6::graph_nodeThe base of all graph nodes
tbb::improper_lockException for PPL locks
tbb::tick_count::interval_tRelative time interval
tbb::invalid_multiple_schedulingException for repeated scheduling of the same task_handle
tbb::flow::interface6::join_node< OutputTuple, queueing >
tbb::flow::interface6::join_node< OutputTuple, reserving >
tbb::flow::interface6::join_node< OutputTuple, tag_matching >
tbb::flow::interface6::limiter_node< T >Forwards messages only if the threshold has not been reached
tbb::internal::machine_load_store
tbb::internal::machine_load_store< T, 8 >
tbb::internal::machine_load_store_relaxed< T, S >
tbb::internal::machine_load_store_relaxed< T, 8 >
tbb::internal::machine_load_store_seq_cst< T, S >
tbb::internal::machine_load_store_seq_cst< T, 8 >
tbb::interface6::memory_pool< Alloc >Thread-safe growable pool allocator for variable-size requests
tbb::interface6::memory_pool_allocator< T, P >
tbb::interface6::memory_pool_allocator< void, P >Analogous to std::allocator<void>, as defined in ISO C++ Standard, Section 20.4.1
rml::MemPoolPolicy
tbb::missing_waitException for missing wait on structured_task_group
tbb::movable_exception< ExceptionData >Template that can be used to implement exception that transfers arbitrary ExceptionData to the root thread
multifunction_input
tbb::flow::interface6::multifunction_node< Input, Output, graph_buffer_policy, Allocator >Implements a function node that supports Input -> (set of outputs)
tbb::flow::interface6::multifunction_node< Input, Output, queueing, Allocator >
tbb::mutexWrapper around the platform's native reader-writer lock
no_copy
tbb::interface5::concurrent_hash_map< Key, T, HashCompare, Allocator >::node
tbb::null_mutexA mutex which does nothing
tbb::null_rw_mutexA rw mutex which does nothing
tbb::flow::interface6::or_node< InputTuple >
tbb::flow::interface6::overwrite_node< T >
tbb::parallel_do_feeder< Item >
tbb::parallel_while< Body >
tbb::internal::partition_type_baseProvides backward-compatible methods for partition objects without affinity
tbb::pipelineA processing pipeline that applies filters to items
tbb::pre_scan_tagUsed to indicate that the initial scan is being performed
tbb::flow::interface6::priority_queue_node< T, Compare, A >Forwards messages in priority order
tbb::flow::interface6::queue_node< T, A >Forwards messages in FIFO order
tbb::queuing_mutexQueuing mutex with local-only spinning
tbb::queuing_rw_mutexQueuing reader-writer mutex with local-only spinning
tbb::interface5::reader_writer_lockWriter-preference reader-writer lock with local-only spinning on readers
tbb::cache_aligned_allocator< void >::rebind< U >
tbb::interface6::memory_pool_allocator< T, P >::rebind< U >
tbb::zero_allocator< T, Allocator >::rebind< U >
tbb::zero_allocator< void, Allocator >::rebind< U >
tbb::cache_aligned_allocator< T >::rebind< U >
tbb::tbb_allocator< void >::rebind< U >
tbb::tbb_allocator< T >::rebind< U >
tbb::interface6::memory_pool_allocator< void, P >::rebind< U >
tbb::scalable_allocator< T >::rebind< U >
tbb::scalable_allocator< void >::rebind< U >
tbb::flow::interface6::receiver< T >Pure virtual template class that defines a receiver of messages of type T
tbb::recursive_mutex
tbb::internal::reverse< T >
tbb::interface6::runtime_loaderLoad TBB at runtime
tbb::scalable_allocator< T >Meets "allocator" requirements of ISO C++ Standard, Section 20.1.5
tbb::scalable_allocator< void >Analogous to std::allocator<void>, as defined in ISO C++ Standard, Section 20.4.1
tbb::spin_mutex::scoped_lockRepresents acquisition of a mutex
tbb::spin_rw_mutex_v3::scoped_lockThe scoped locking pattern
tbb::queuing_rw_mutex::scoped_lockThe scoped locking pattern
tbb::recursive_mutex::scoped_lockThe scoped locking pattern
tbb::queuing_mutex::scoped_lockThe scoped locking pattern
tbb::interface5::reader_writer_lock::scoped_lockThe scoped lock pattern for write locks
tbb::internal::critical_section_v4::scoped_lock
tbb::mutex::scoped_lockThe scoped locking pattern
tbb::null_mutex::scoped_lockRepresents acquisition of a mutex
tbb::null_rw_mutex::scoped_lockRepresents acquisition of a mutex
tbb::interface5::reader_writer_lock::scoped_lock_readThe scoped lock pattern for read locks
tbb::flow::interface6::sender< T >Pure virtual template class that defines a sender of messages of type T
tbb::flow::interface6::sequencer_node< T, A >Forwards messages in sequence order
tbb::simple_partitionerA simple partitioner
tbb::flow::interface6::source_node< Output >An executable node that acts as a source, i.e. it has no predecessors
tbb::spin_mutexA lock that occupies a single byte
tbb::spin_rw_mutex_v3Fast, unfair, spinning reader-writer lock with backoff and writer-preference
tbb::splitDummy type that distinguishes splitting constructor from copy constructor
tbb::flow::interface6::split_node< TupleType, Allocator >Split_node: accepts a tuple as input, forwards each element of the tuple to its
tbb::internal::STATIC_ASSERTION_FAILED< false >
tbb::structured_task_group
tbb::taskBase class for user-defined tasks
tbb::interface6::task_arena
tbb::interface5::internal::task_baseBase class for methods that became static in TBB 3.0
tbb::task_group
tbb::internal::task_group_base
tbb::task_group_contextUsed to form groups of tasks
tbb::task_handle< F >
tbb::internal::task_handle_task< F >
tbb::task_listA list of children
tbb::task_scheduler_init
tbb::interface6::task_scheduler_observer
tbb::internal::task_scheduler_observer_v3
tbb::tbb_allocator< T >
tbb::tbb_allocator< void >Analogous to std::allocator<void>, as defined in ISO C++ Standard, Section 20.4.1
tbb::tbb_exceptionInterface to be implemented by all exceptions TBB recognizes and propagates across the threads
tbb::internal::tbb_exception_ptrException container that preserves the exact copy of the original exception
tbb::tbb_hash_compare< Key >Hash_compare that is default argument for concurrent_hash_map
tbb::thread_bound_filterA stage in a pipeline served by a user thread
tbb::tick_countAbsolute timestamp
tbb::internal::type_with_alignment< 1 >
tbb::internal::type_with_alignment< 16 >
tbb::internal::type_with_alignment< 2 >
tbb::internal::type_with_alignment< 32 >
tbb::internal::type_with_alignment< 4 >
tbb::internal::type_with_alignment< 64 >
tbb::internal::type_with_alignment< 8 >
tbb::user_abortException for user-initiated abort
tbb::interface5::concurrent_unordered_map_traits< Key, T, Hash_compare, Allocator, Allow_multimapping >::value_compare
tbb::internal::work_around_alignment_bug< Size, T >Work around for bug in GNU 3.2 and MSVC compilers
tbb::flow::interface6::write_once_node< T >
tbb::zero_allocator< T, Allocator >Meets "allocator" requirements of ISO C++ Standard, Section 20.1.5
tbb::zero_allocator< void, Allocator >Analogous to std::allocator<void>, as defined in ISO C++ Standard, Section 20.4.1

Copyright © 2005-2013 Intel Corporation. All Rights Reserved.

Intel, Pentium, Intel Xeon, Itanium, Intel XScale and VTune are registered trademarks or trademarks of Intel Corporation or its subsidiaries in the United States and other countries.

* Other names and brands may be claimed as the property of others.