CDune::AddPtrTypeEvaluator< T > | TypeEvaluator to turn a type T into a pointer to T |
CDune::AddPtrTypeEvaluator< T & > | |
CDune::AddRefTypeEvaluator< T > | TypeEvaluator to turn a type T into a reference to T |
CDune::MathOverloads::ADLTag | Tag to make sure the functions in this namespace can be found by ADL |
CDune::Simd::Overloads::ADLTag< i, bool > | Tag used to force late-binding lookup in Dune::Simd::Overloads |
CDune::Simd::Overloads::ADLTag< 0 > | |
►CDune::Simd::Overloads::ADLTag< i-1 > | |
CDune::Simd::Overloads::ADLTag< i > | |
CDune::AlignedBase< align, Impl > | CRTP base mixin class to check alignment |
►CDune::AlignedBase< align, AlignedNumber< T, align > > | |
CDune::AlignedNumberImpl::AlignedNumber< T, align > | Aligned wrappers for arithmetic types |
CDune::AllSet< TA > | A set containing everything |
►Cstd::array< T > | STL class |
CDune::LoopSIMD< T, S, A > | |
CDune::ArrayList< T, N, A > | A dynamically growing random access list |
CDune::ArrayList< Dune::IndexPair, 100 > | |
CDune::ArrayList< Dune::IndexPair, N > | |
CDune::ArrayList< IndexPair< TG, TL >, N, std::allocator< Dune::IndexPair< TG, TL > > > | |
CDune::ArrayList< T, N, A > | |
CDune::At< N > | Reverse element access |
CDune::AtType< N, Tuple > | Type for reverse element access |
►CDune::AutonomousValueType< T > | Type free of internal references that T can be converted to |
CDune::AutonomousValueType< T & > | Specialization to remove lvalue references |
CDune::AutonomousValueType< T && > | Specialization to remove rvalue references |
CDune::AutonomousValueType< const T > | Specialization to remove const qualifiers |
CDune::AutonomousValueType< volatile T > | Specialization to remove volatile qualifiers |
CDune::AutonomousValueType< volatile const T > | Specialization to remove both const and volatile qualifiers |
►CDune::AutonomousValueType< Simd::VcImpl::Proxy< V >::value_type > | |
CDune::AutonomousValueType< Simd::VcImpl::Proxy< V > > | Specialization of AutonomousValue for Vc proxies |
CDune::AutonomousValueType< std::vector< bool >::reference > | Specialization for the proxies of vector<bool> |
CDune::BidirectionalIteratorFacade< T, V, R, D > | Facade class for stl conformant bidirectional iterators |
►CDune::BidirectionalIteratorFacade< ContainerWrapperIterator< CW, T, R >, T, R, int > | |
CDune::ContainerWrapperIterator< CW, T, R > | Iterator class for sparse vector-like containers |
CDune::bigunsignedint< k > | Portable very large unsigned integers |
►CDune::BitSetVectorConstReference< block_size, Alloc > | A proxy class that acts as a const reference to a single bitset in a BitSetVector |
CDune::BitSetVectorReference< block_size, Alloc > | A proxy class that acts as a mutable reference to a single bitset in a BitSetVector |
►Cstd::bool_constant | |
CDune::IsCallable< F(Args...), R > | Check if a type is callable with ()-operator and given arguments |
CDune::impl::Buffer< T > | |
CDune::impl::Buffer< R > | |
CDune::impl::Buffer< T & > | |
CDune::impl::Buffer< void > | |
CDune::BufferedCommunicator | A communicator that uses buffers to gather and scatter the data to be send or received |
CDune::Cloneable | An interface class for cloneable objects |
CDune::CollectiveIterator< T, A > | A collective iterator for moving over the remote indices for all processes collectively |
CDune::Combine< TI1, TI2, TA > | A set combining two other sets |
CDune::common_bits< current, mask > | Activate if current and mask have common bits switched on |
CDune::CommPolicy< V > | Default policy used for communicating an indexed type |
CDune::CommPolicy< V >::CommPolicy< VariableBlockVector< FieldVector< K, n >, A > > | |
CDune::Communication< Communicator > | Collective communication interface and sequential default implementation |
CDune::Communication< MPI_Comm > | Specialization of Communication for MPI |
►Cstd::conjunction | |
CDune::Std::conjunction< B > | Forms the logical conjunction of the type traits B.. |
CDune::const_reference< R > | Get the 'const' version of a reference to a mutable object |
CDune::const_reference< BitSetVectorConstReference< block_size, Alloc > > | |
CDune::const_reference< BitSetVectorReference< block_size, Alloc > > | |
CDune::const_reference< const R & > | |
CDune::const_reference< const R > | |
CDune::const_reference< DiagonalRowVector< K, n > > | |
CDune::const_reference< DiagonalRowVectorConst< K, n > > | |
CDune::const_reference< R & > | |
CDune::CommPolicy< V >::CopyGatherScatter< T > | GatherScatter default implementation that just copies data |
►CDune::DebugStreamState | Intermediate class to implement tie-operation of DebugStream |
CDune::DebugStream< thislevel, dlevel, alevel, activator > | Generic class to implement debug output streams |
►CdecltypeImpl::isTupleOrDerivedstd::declval | |
CDune::IsTupleOrDerived< T > | Check if T derived from a std::tuple<...> |
CDune::FloatCmp::DefaultEpsilon< T, style > | Mapping from a value type and a compare style to a default epsilon |
CDune::FloatCmp::DefaultEpsilon< T, absolute > | |
CDune::FloatCmp::DefaultEpsilon< T, relativeStrong > | |
CDune::FloatCmp::DefaultEpsilon< T, relativeWeak > | |
CDune::DenseMatrix< MAT > | A dense n x m matrix |
►CDune::DenseMatrix< DynamicMatrix< K > > | |
CDune::DynamicMatrix< K > | Construct a matrix with a dynamic size |
►CDune::DenseMatrix< FieldMatrix< K, ROWS, COLS > > | |
CDune::FieldMatrix< K, ROWS, COLS > | A dense n x m matrix |
CDune::DenseMatrix< ScalarMatrixView< K > > | |
CDune::DenseMatrixAssigner< DenseMatrix, RHS > | You have to specialize this structure for any type that should be assignable to a DenseMatrix |
CDune::DenseMatrixAssigner< DenseMatrix, DiagonalMatrix< field, N > > | |
CDune::DenseMatVecTraits< T > | |
CDune::DenseMatVecTraits< DynamicMatrix< K > > | |
CDune::DenseMatVecTraits< DynamicVector< K, Allocator > > | |
CDune::DenseMatVecTraits< FieldMatrix< K, ROWS, COLS > > | |
CDune::DenseMatVecTraits< FieldVector< K, SIZE > > | |
►CDune::DenseVector< V > | Interface for a class of dense vectors over a given field |
CDune::DynamicVector< K, Allocator > | Construct a vector with a dynamic size |
CDune::DenseVector< DynamicVector< K, std::allocator< K > > > | |
►CDune::DenseVector< FieldVector< K, SIZE > > | |
CDune::FieldVector< K, n > | |
CDune::FieldVector< K, COLS > | |
CDune::FieldVector< K, SIZE > | Vector space out of a tensor product of fields |
CDune::DenseVector< ScalarVectorView< K > > | |
CDune::DiagonalMatrix< K, n > | A diagonal matrix of static size |
CDune::DiagonalMatrixWrapper< DiagonalMatrixType > | |
►CDune::DiagonalRowVectorConst< K, n > | |
CDune::DiagonalRowVector< K, DiagonalMatrixType::rows > | |
CDune::DiagonalRowVector< K, n > | |
►Cstd::disjunction | |
CDune::Std::disjunction< B > | Forms the logical disjunction of the type traits B.. |
CDune::Empty | Just an empty class |
CDune::EmptySet< TA > | An empty set |
►Cstd::enable_if | |
CDune::EnableIfInterOperable< T1, T2, Type > | Enable typedef if two types are interoperable |
CDune::Simd::EndMark | Final element marker for RebindList |
CDune::EnumItem< TA, item > | A set consisting only of one item |
CDune::EnumRange< TA, from, end > | A set representing a range including the borders |
CDune::FloatCmp::EpsilonType< T > | Mapping of value type to epsilon type |
CDune::FloatCmp::EpsilonType< FieldVector< T, n > > | Specialization of EpsilonType for Dune::FieldVector |
CDune::FloatCmp::EpsilonType< std::vector< T, A > > | Specialization of EpsilonType for std::vector |
►Cstd::exception | STL class |
►CDune::Exception | Base class for Dune-Exceptions |
CDune::HelpRequest | Exception thrown if the user wants to see help string |
►CDune::IOError | Default exception class for I/O errors |
CDune::CommPolicy< V >::CommunicationError | Error thrown if there was a problem with the communication |
CDune::DebugStreamError | Standard exception for the debugstream |
►CDune::InvalidStateException | Default exception if a function was called while the object is not in a valid state for that function |
CDune::InterfaceBuilder::RemoteIndicesStateError | |
CDune::InvalidFutureException | This exception is thrown when ready() , wait() or get() is called on an invalid future. A future is valid until get() is called and if it is not default-constructed and it was not moved from |
CDune::InvalidIndexSetState | Exception indicating that the index set is not in the expected state |
►CDune::MathError | Default exception class for mathematical errors |
CDune::FMatrixError | Error thrown if operations of a FieldMatrix fail |
CDune::NotImplemented | Default exception for dummy implementations |
►CDune::ParallelError | Default exception if an error in the parallel communication of the program occurred |
CDune::MPIGuardError | This exception is thrown if the MPIGuard detects an error on a remote process |
►CDune::RangeError | Default exception class for range errors |
CDune::ParameterTreeParserError | Report parser error while reading ParameterTree |
CDune::RemoteIndexListModifier< T, A, mode >::InvalidPosition | |
►CDune::SystemError | Default exception class for OS errors |
CDune::OutOfMemoryError | Default exception if memory allocation fails |
CDune::ExceptionHook | Base class to add a hook to the Dune::Exception |
CDune::Factorial< m > | |
CDune::Factorial< 0 > | End of recursion of factorial via specialization |
CDune::FakeMPIHelper | A fake mpi helper |
►Cstd::false_type | |
CDune::AlwaysFalse< T > | Template which always yields a false value |
CDune::IsIterable< T, typename > | Typetrait to check that a class has begin() and end() members |
CDune::IsTypeList< T > | Check if given type is a TypeList |
CDune::IsVector< T, class > | |
►CDune::Simd::VcImpl::IsMask< V, SFINAE > | Specialized to true for Vc mask types |
CDune::Simd::VcImpl::IsVector< V, SFINAE > | Specialized to true for Vc vector and mask types |
CDune::Simd::VcImpl::IsVectorizable< T > | |
CDune::FieldTraits< T > | |
CDune::FieldTraits< const T > | |
CDune::FieldTraits< DenseMatrix< M > > | |
CDune::FieldTraits< DenseVector< V > > | |
CDune::FieldTraits< DiagonalMatrix< K, n > > | |
CDune::FieldTraits< DynamicMatrix< K > > | |
CDune::FieldTraits< DynamicVector< K, Allocator > > | |
CDune::FieldTraits< FieldMatrix< K, ROWS, COLS > > | |
CDune::FieldTraits< FieldVector< K, SIZE > > | |
CDune::FieldTraits< std::complex< T > > | |
CDune::FieldTraits< std::remove_const_t< K > > | |
CDune::FieldTraits< std::vector< T > > | |
CDune::FieldTraits< T[N] > | |
CDune::CommPolicy< V >::FieldVector< K, n > | |
CDune::FlattenTuple< Tuple > | Flatten a std::tuple of std::tuple's |
CDune::FloatCmpOps< T, cstyle_, rstyle_ > | Class encapsulating a default epsilon |
CDune::FMatrixPrecision< ctype > | Precisions for calculations with FieldMatrix and FieldVector |
CDune::ForEachType< TE, T > | Helper template to clone the type definition of a std::tuple with the storage types replaced by a user-defined rule |
CDune::ForEachType< TE, std::tuple< Args... > > | |
►CDune::ForwardIteratorFacade< T, V, R, D > | Base class for stl conformant forward iterators |
CDune::SLListIterator< RemoteIndex, Allocator > | |
CDune::SLListModifyIterator< RemoteIndex, Allocator > | |
►CDune::ForwardIteratorFacade< SLListConstIterator< T, A >, const T, const T &, std::size_t > | |
CDune::SLListConstIterator< T, A > | A constant iterator for the SLList |
CDune::ForwardIteratorFacade< SLListIterator< RemoteIndex, Allocator >, RemoteIndex, RemoteIndex &, std::size_t > | |
►CDune::ForwardIteratorFacade< SLListIterator< T, A >, T, T &, std::size_t > | |
CDune::SLListIterator< T, A > | A mutable iterator for the SLList |
CDune::ForwardIteratorFacade< SLListModifyIterator< RemoteIndex, Allocator >, RemoteIndex, RemoteIndex &, std::size_t > | |
►CDune::ForwardIteratorFacade< SLListModifyIterator< T, A >, T, T &, std::size_t > | |
CDune::SLListModifyIterator< T, A > | A mutable iterator for the SLList |
►CDune::Function< Domain, Range > | Base class template for function classes |
CDune::VirtualFunction< Domain, Range > | |
CDune::Function< const Domain &, Range & > | |
►CDune::Function< const DomainType &, RangeType & > | |
CDune::VirtualFunction< DomainType, RangeType > | Virtual base class template for function classes |
CDune::Future< T > | Type-erasure for future-like objects. A future-like object is a object satisfying the interface of FutureBase |
CDune::Generic_MPI_Op< Type, BinaryFunction, Enable > | |
CDune::GlobalLookupIndexSet< I > | Decorates an index set with the possibility to find a global index that is mapped to a specific local |
CDune::greater_or_equal< current, threshold > | Greater or equal template test |
CDune::Concept::HasFixedSize | |
CDune::hash< T > | Functor for hashing objects of type T |
CDune::Std::identity | A function object type whose operator() returns its argument unchanged |
CDune::ImplementationDefined | Dummy struct used for documentation purposes |
CDune::Indent | Utility class for handling nested indentation in output |
►Cindex_constant | |
CDune::Simd::Overloads::LaneCount< class, class > | Should be derived from a Dune::index_constant |
CDune::Simd::Overloads::LaneCount< AlignedNumber< T, align > > | |
CDune::Simd::Overloads::LaneCount< LoopSIMD< T, S, A > > | |
CDune::Simd::Overloads::LaneCount< V, std::enable_if_t< VcImpl::IsVector< V >::value > > | Should be derived from an Dune::index_constant |
CDune::IndexPair< TG, TL > | A pair consisting of a global and local index |
CDune::IndexSetSortFunctor< TG, TL > | |
CDune::IndicesSyncer< T > | Class for recomputing missing indices of a distributed index set |
CDune::SimdImpl::Inserter< T > | |
CDune::IntegerSequenceEntry< IntegerSequence, index > | Get entry of std::integer_sequence |
►Cstd::integral_constant | |
CDune::HasNaN< T > | Whether this type has a value of NaN |
CDune::IsNumber< T > | Whether this type acts as a scalar in the context of (hierarchically blocked) containers |
CDune::IsNumber< GMPField< precision > > | |
CDune::IsNumber< LoopSIMD< T, S, A > > | |
CDune::IsNumber< Vc::SimdArray< T, N, V, Wt > > | |
CDune::IsNumber< Vc::Vector< T, Abi > > | |
CDune::SizeOf< T > | Compute size of variadic type list |
CDune::TypeListSize< TypeList< T... > > | Get size of TypeList |
CDune::IntegralRange< T > | Dynamic integer range for use in range-based for loops |
►CDune::InterfaceBuilder | Base class of all classes representing a communication interface |
CDune::Interface | Communication interface between remote and local indices |
CDune::InterfaceInformation | Information describing an interface |
CDune::ios_base_all_saver | Utility class for storing and resetting stream attributes |
►Cstd::is_same | |
CDune::IsEmptyTypeList< T > | Check if given type is an empty TypeList |
CDune::IsType< T >::Predicate< U > | The actual predicate |
CDune::IsCallable< D, R > | Check if a type is callable with ()-operator and given arguments |
CDune::IsFieldVectorSizeCorrect< C, SIZE > | TMP to check the size of a DenseVectors statically, if possible |
CDune::IsFieldVectorSizeCorrect< FieldVector< T, SIZE >, SIZE > | |
CDune::IsFieldVectorSizeCorrect< FieldVector< T, SIZE1 >, SIZE > | |
►CImpl::IsIndexable | |
CDune::IsIndexable< T, I > | Type trait to determine whether an instance of T has an operator[](I), i.e. whether it can be indexed with an index of type I |
►CImpl::IsIntegralConstant | |
CDune::IsIntegralConstant< T > | Check if T is an std::integral_constant<I, i> |
CDune::IsInteroperable< T1, T2 > | Checks whether two types are interoperable |
►CImpl::IsTuple | |
CDune::IsTuple< T > | Check if T is a std::tuple<...> |
CDune::IsType< T > | Generator for predicates accepting one particular type |
CDune::MathImpl::isUnorderedImpl | |
CDune::CollectiveIterator< T, A >::iterator | Iterator over the valid underlying iterators |
CDune::IteratorRange< Iterator > | Simple range between a begin and an end iterator |
CDune::IteratorTransformationTag | Tag to enable iterator based transformations in TransformedRangeView |
CDune::JoinTuples< Head, Tail > | Join two std::tuple's |
CDune::LocalIndex | An index present on the local process |
CDune::LocalIndexComparator< T > | |
CDune::LocalIndexComparator< ParallelLocalIndex< T > > | |
CDune::lru< Key, Tp, Traits > | LRU Cache Container |
►CDune::MallocAllocator< T > | Allocators implementation which simply calls malloc/free |
CDune::AlignedAllocator< T, Alignment > | Allocators which guarantee alignment of the memory |
CDune::Max< Type > | |
CDune::MetaType< T > | A type that refers to another type |
CDune::Min< Type > | |
►Cmpf_class | |
CDune::GMPField< precision > | Number class for high precision floating point number using the GMP library mpf_class implementation |
CDune::MPIData< T, Enable > | |
CDune::MPIData< P, std::enable_if_t< std::is_same< std::remove_const_t< P >, MPIPack >::value > > | |
CDune::MPIData< T, std::void_t< std::tuple< decltype(std::declval< T >().data()), decltype(std::declval< T >().size()), typename std::decay_t< T >::value_type > > > | |
CDune::MPIData< void > | |
CDune::MPIFuture< R, S > | Provides a future-like object for MPI communication. It contains the object that will be received and might contain also a sending object, which must be hold (keep alive) until the communication has been completed |
CDune::MPIGuard | Detects a thrown exception and communicates to all other processes |
CDune::MPIHelper | A real mpi helper |
CDune::MPIPack | |
CDune::MPITraits< T > | A traits class describing the mapping of types onto MPI_Datatypes |
CDune::MPITraits< IndexPair< TG, ParallelLocalIndex< TA > > > | |
CDune::MPITraits< ParallelLocalIndex< T > > | |
CDune::mutable_reference< R > | Get the 'mutable' version of a reference to a const object |
CDune::mutable_reference< BitSetVectorConstReference< block_size, Alloc > > | |
CDune::mutable_reference< BitSetVectorReference< block_size, Alloc > > | |
CDune::mutable_reference< const R & > | |
CDune::mutable_reference< const R > | |
CDune::mutable_reference< DiagonalRowVector< K, n > > | |
CDune::mutable_reference< DiagonalRowVectorConst< K, n > > | |
CDune::mutable_reference< R & > | |
CDune::NegateSet< S > | The negation of a set. An item is contained in the set if and only if it is not contained in the negated set |
►Cstd::negation | |
CDune::Std::negation< B > | Forms the logical negation of the type traits B.. |
CDune::No_Comm | |
CDune::Std::nonesuch | Type representing a lookup failure by std::detected_or and friends |
CDune::null_deleter< T > | Implements the Deleter concept of shared_ptr without deleting anything |
CDune::NullPointerInitialiser< T > | A helper template that initializes a std::tuple consisting of pointers to nullptr |
CDune::NullPointerInitialiser< std::tuple< Args... > > | |
CDune::OwnerOverlapCopyCommunication< T1, T2 > | |
CDune::ParallelIndexSet< TG, TL, N > | Manager class for the mapping between local indices and globally unique indices |
CDune::ParallelIndexSet< TG, TL, N > | |
CDune::ParallelLocalIndex< T > | An index present on the local process with an additional attribute flag |
CDune::ParameterizedObjectFactory< Signature, KeyT > | A factory class for parameterized objects |
CDune::ParameterizedObjectFactory< TypeT(Args...), KeyT > | |
CDune::ParameterTree | Hierarchical structure of string parameters |
CDune::ParameterTreeParser | Parsers to set up a ParameterTree from various input sources |
CDune::ParameterTree::Parser< bool > | |
CDune::ParameterTree::Parser< FieldVector< T, n > > | |
CDune::ParameterTree::Parser< std::array< T, n > > | |
CDune::ParameterTree::Parser< std::basic_string< char, traits, Allocator > > | |
CDune::ParameterTree::Parser< std::bitset< n > > | |
CDune::ParameterTree::Parser< std::vector< T, A > > | |
CDune::PointerPairDeletor< Tuple > | Deletes all objects pointed to in a std::tuple of pointers |
CDune::Pool< T, s > | A memory pool of objects |
CDune::Pool< T, size > | |
CDune::PoolAllocator< T, s > | An allocator managing a pool of objects for reuse |
CDune::PoolAllocator< void, s > | |
CDune::Power< p > | Compute power for a run-time base and a compile-time integer exponent |
CDune::PriorityTag< priority > | Helper class for tagging priorities |
CDune::PriorityTag< 0 > | Helper class for tagging priorities |
CDune::PromotionTraits< T1, T2 > | Compute type of the result of an arithmetic operation involving two different number types |
CDune::PromotionTraits< GMPField< precision >, GMPField< precision > > | |
CDune::PromotionTraits< GMPField< precision >, T > | |
CDune::PromotionTraits< GMPField< precision1 >, GMPField< precision2 > > | |
CDune::PromotionTraits< T, GMPField< precision > > | |
CDune::PromotionTraits< T1, T1 > | |
CDune::PropertyMapTraits< PM > | |
CDune::PropertyMapTraits< const T * > | |
CDune::PropertyMapTraits< T * > | |
CDune::PropertyMapTypeSelector< T, C > | Selector for the property map type |
CDune::Simd::VcImpl::Proxy< V > | A reference-like proxy for elements of random-access vectors |
CDune::PseudoFuture< T > | A wrapper-class for a object which is ready immediately |
CDune::PseudoFuture< void > | |
CDune::PushBackTuple< Tuple, T > | Helper template to append a type to a std::tuple |
CDune::PushBackTuple< typename std::tuple< Args... >, T > | |
CDune::PushFrontTuple< Tuple, T > | Helper template to prepend a type to a std::tuple |
CDune::PushFrontTuple< typename std::tuple< Args... >, T > | |
►CDune::RandomAccessIteratorFacade< T, V, R, D > | Base class for stl conformant forward iterators |
CDune::ConstArrayListIterator< IndexPair< TG, TL >, N, std::allocator< Dune::IndexPair< TG, TL > > > | |
CDune::ConstArrayListIterator< T, N, A > | A constant random access iterator for the Dune::ArrayList class |
CDune::DenseIterator< C, T, R > | Generic iterator class for dense vector and matrix implementations |
►CRandomAccessIteratorFacade | |
CDune::GenericIterator< C, T, R, D, IteratorFacade > | Generic class for stl-conforming iterators for container classes with operator[] |
►CDune::RandomAccessIteratorFacade< ArrayListIterator< T, N, A >, A::value_type, A::value_type &, A::difference_type > | |
►CDune::ArrayListIterator< T, N, A > | A random access iterator for the Dune::ArrayList class |
CDune::ParallelIndexSet< TG, TL, N >::iterator | The iterator over the pairs |
CDune::RandomAccessIteratorFacade< ConstArrayListIterator< IndexPair< TG, TL >, N, std::allocator< Dune::IndexPair< TG, TL > > >, const A::value_type, A::value_type const &, A::difference_type > | |
CDune::RandomAccessIteratorFacade< ConstArrayListIterator< T, N, A >, const A::value_type, A::value_type const &, A::difference_type > | |
CDune::RandomAccessIteratorFacade< DenseIterator< C, T, T & >, T, T &, std::ptrdiff_t > | |
►CDune::RAPropertyMapHelper< Reference, PropertyMap > | |
CDune::IteratorPropertyMap< RAI, IM, T, R > | Adapter to turn a random access iterator into a property map |
►CDune::RAPropertyMapHelper< const T::value_type::second_type &, ConstAssociativePropertyMap< T > > | |
CDune::ConstAssociativePropertyMap< T > | An adaptor to turn an unique associative container into a property map |
►CDune::RAPropertyMapHelper< std::size_t, IdentityMap > | |
CDune::IdentityMap | A property map that applies the identity function to integers |
►CDune::RAPropertyMapHelper< T::value_type::second_type &, AssociativePropertyMap< T > > | |
CDune::AssociativePropertyMap< T > | An adapter to turn an unique associative container into a property map |
CDune::RAPropertyMapHelper< typename std::iterator_traits< RAI >::reference, IteratorPropertyMap< RAI, IM, typename std::iterator_traits< RAI >::value_type, typename std::iterator_traits< RAI >::reference > > | |
►CDune::ReadablePropertyMapTag | Tag for the category of readable property maps |
►CDune::ReadWritePropertyMapTag | Tag for the category of readable and writable property maps |
CDune::LvaluePropertyMapTag | Tag for the category of lvalue property maps |
CDune::AlignedAllocator< T, Alignment >::rebind< U > | |
CDune::MallocAllocator< T >::rebind< U > | |
CDune::PoolAllocator< T, s >::rebind< U > | Rebind the allocator to another type |
CDune::PoolAllocator< void, s >::rebind< U > | |
CDune::Simd::Overloads::RebindType< S, class, class > | Should have a member type type |
CDune::Simd::Overloads::RebindType< bool, V, std::enable_if_t< VcImpl::IsVector< V >::value &&!VcImpl::IsMask< V >::value > > | Should have a member type type |
CDune::Simd::Overloads::RebindType< S, M, std::enable_if_t< VcImpl::IsMask< M >::value &&VcImpl::IsVectorizable< S >::value &&!std::is_same< S, Scalar< typename M::Vector > >::value > > | Should have a member type type |
CDune::Simd::Overloads::RebindType< S, V, std::enable_if_t< VcImpl::IsVector< V >::value &&!VcImpl::IsMask< V >::value &&VcImpl::IsVectorizable< S >::value &&!std::is_same< S, Scalar< V > >::value > > | Should have a member type type |
CDune::Simd::Overloads::RebindType< S, V, std::enable_if_t< VcImpl::IsVector< V >::value &&!VcImpl::IsVectorizable< S >::value &&!std::is_same< S, bool >::value &&!std::is_same< S, Scalar< V > >::value > > | Should have a member type type |
CDune::Simd::Overloads::RebindType< Scalar< typename M::Vector >, M, std::enable_if_t< VcImpl::IsMask< M >::value > > | Should have a member type type |
CDune::Simd::Overloads::RebindType< Simd::Scalar< V >, V, std::enable_if_t< VcImpl::IsVector< V >::value > > | Should have a member type type |
CDune::Simd::Overloads::RebindType< U, AlignedNumber< T, align > > | |
CDune::Simd::Overloads::RebindType< U, LoopSIMD< T, S, A > > | |
CDune::ReduceTuple< F, Tuple, Seed, N > | Apply reduce with meta binary function to template |
CDune::ReduceTuple< F, Tuple, Seed, 0 > | Apply reduce with meta binary function to template |
CDune::Concept::Refines< BaseConcepts > | Base class for refined concepts |
CDune::RemoteIndex< T1, T2 > | Information about an index residing on another processor |
CDune::RemoteIndexListModifier< T, A, mode > | Modifier for adding and/or deleting remote indices from the remote index list |
CDune::RemoteIndices< T, A > | The indices present on remote processes |
CDune::ReservedVector< T, n > | A Vector class with statically reserved memory |
CDune::Simd::Overloads::ScalarType< V, class > | Should have a member type type |
CDune::Simd::Overloads::ScalarType< AlignedNumber< T, align > > | |
CDune::Simd::Overloads::ScalarType< LoopSIMD< T, S, A > > | |
CDune::Simd::Overloads::ScalarType< V, std::enable_if_t< VcImpl::IsVector< V >::value > > | Should have a member type type |
CDune::Selection< TS, TG, TL, N > | A cached selection of indices |
CDune::SelectionIterator< TS, TG, TL, N > | A const iterator over an uncached selection |
CDune::SimdIndexTypeTraits< V, typename > | |
CDune::SimdMaskTypeTraits< V, typename > | |
CDune::SimdScalarTypeTraits< T > | |
CDune::SimdScalarTypeTraits< AlignedNumber< T, align > > | Deduce the underlying scalar data type of an AlignedNumber |
CDune::Singleton< T > | An adapter to turn a class into a singleton |
CDune::SizeOne | Flag for marking indexed data structures where data at each index is of the same size |
CDune::SLList< T, A > | A single linked list |
CDune::SLList< GlobalIndex, Allocator > | |
CDune::SLList< RemoteIndex, Allocator > | |
CDune::SLList< T, A > | |
CDune::StandardMathematicalConstants< T > | Standard implementation of MathematicalConstants |
►CDune::StandardMathematicalConstants< Field > | |
CDune::MathematicalConstants< Field > | Provides commonly used mathematical constants |
CDune::StaticIntegralRange< T, to, from > | Static integer range for use in range-based for loops |
CDune::StaticPower< b, p > | Calculates b^p at compile time |
CDune::StreamWrap | |
►CTE | |
CDune::TransformTupleFunctor< TE, Args >::TypeEvaluator< T > | |
CDune::Timer | A simple stop watch |
CDune::ParameterTree::Parser< bool >::ToLower | |
CDune::Function< Domain, Range >::Traits | Traits class containing raw types |
CDune::TransformedRangeView< R, F, T > | A range transforming the values of another range on-the-fly |
CDune::TransformTupleFunctor< TE, Args > | |
►Ctrue | |
CDune::IsTupleOrDerived< T > | Check if T derived from a std::tuple<...> |
►Cstd::true_type | |
CDune::AlwaysTrue< T > | Template which always yields a true value |
CDune::IsNumber< AlignedNumberImpl::AlignedNumber< T, align > > | |
CDune::IsNumber< bigunsignedint< k > > | Declare big unsigned int is a number |
CDune::IsTypeList< TypeList< T... > > | Check if given type is a TypeList. |
CDune::IsVector< T, std::void_t< typename T::field_type > > | |
CDune::Simd::VcImpl::IsMask< Vc::Mask< T, A > > | |
CDune::Simd::VcImpl::IsMask< Vc::SimdMaskArray< T, n, V, m > > | |
CDune::Simd::VcImpl::IsVector< Vc::SimdArray< T, n, V, m > > | |
CDune::Simd::VcImpl::IsVector< Vc::Vector< T, A > > | |
CDune::Simd::VcImpl::IsVectorizable< double > | |
CDune::Simd::VcImpl::IsVectorizable< float > | |
CDune::Simd::VcImpl::IsVectorizable< std::int16_t > | |
CDune::Simd::VcImpl::IsVectorizable< std::int32_t > | |
CDune::Simd::VcImpl::IsVectorizable< std::uint16_t > | |
CDune::Simd::VcImpl::IsVectorizable< std::uint32_t > | |
►Cstd::tuple | |
CDune::TupleVector< T > | A class augmenting std::tuple by element access via operator[] |
CDune::TupleAccessTraits< T > | |
CDune::TupleAccessTraits< T & > | |
CDune::TupleAccessTraits< T * > | |
►Cstd::conditional::type | |
CDune::FirstPredicateIndex< Tuple, IsType< T >::template Predicate, 0 > | |
►Cstd::conditional::type | |
►CDune::FirstPredicateIndex< Tuple, Predicate, start, size > | Finding the index of a certain type in a std::tuple |
CDune::FirstTypeIndex< Tuple, T, start > | Find the first occurrence of a type in a std::tuple |
CDune::TypeListElement< i, T > | |
CDune::TypeListElement< i, TypeList< T... > > | Get element of TypeList |
CDune::TypeListSize< T > | |
CDune::UncachedSelection< TS, TG, TL, N > | An uncached selection of indices |
CDune::Simd::UnitTest | |
CDune::ValueTransformationTag | Tag to enable value based transformations in TransformedRangeView |
CDune::CommPolicy< V >::VariableBlockVector< B, A > | |
CDune::VariableSize | Flag for marking indexed data structures where the data at each index may be a variable multiple of another type |
CDune::VariableSizeCommunicator< Allocator > | A buffered communicator where the amount of data sent does not have to be known a priori |
►Cstd::vector< T > | STL class |
CDune::BitSetVector< block_size, Allocator > | A dynamic array of blocks of booleans |
►CDune::WritablePropertyMapTag | Tag for the category of writable property maps |
CDune::ReadWritePropertyMapTag | Tag for the category of readable and writable property maps |