►NDune | Dune namespace |
►NAlignedNumberImpl | |
CAlignedNumber | Aligned wrappers for arithmetic types |
►NConcept | Namespace for concepts |
CHasFixedSize | |
CRefines | Base class for refined concepts |
►NFloatCmp | |
CDefaultEpsilon | Mapping from a value type and a compare style to a default epsilon |
CDefaultEpsilon< T, absolute > | |
CDefaultEpsilon< T, relativeStrong > | |
CDefaultEpsilon< T, relativeWeak > | |
CEpsilonType | Mapping of value type to epsilon type |
CEpsilonType< FieldVector< T, n > > | Specialization of EpsilonType for Dune::FieldVector |
CEpsilonType< std::vector< T, A > > | Specialization of EpsilonType for std::vector |
►Nimpl | |
CBuffer | |
CBuffer< T & > | |
CBuffer< void > | |
►NMathImpl | |
CisUnorderedImpl | |
►NMathOverloads | Namespace for customization of math functions with Dune-Semantics |
CADLTag | Tag to make sure the functions in this namespace can be found by ADL |
►NSimd | Namespace for vectorization interface functions used by library developers |
►NOverloads | Namespace for the overloads and specializations that make up a SIMD implementation |
CADLTag | Tag used to force late-binding lookup in Dune::Simd::Overloads |
CADLTag< 0 > | |
CADLTag< i > | |
CLaneCount | Should be derived from a Dune::index_constant |
CLaneCount< AlignedNumber< T, align > > | |
CLaneCount< LoopSIMD< T, S, A > > | |
CLaneCount< V, std::enable_if_t< VcImpl::IsVector< V >::value > > | Should be derived from an Dune::index_constant |
CRebindType | Should have a member type type |
CRebindType< bool, V, std::enable_if_t< VcImpl::IsVector< V >::value &&!VcImpl::IsMask< V >::value > > | Should have a member type type |
CRebindType< 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 |
CRebindType< 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 |
CRebindType< 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 |
CRebindType< Scalar< typename M::Vector >, M, std::enable_if_t< VcImpl::IsMask< M >::value > > | Should have a member type type |
CRebindType< Simd::Scalar< V >, V, std::enable_if_t< VcImpl::IsVector< V >::value > > | Should have a member type type |
CRebindType< U, AlignedNumber< T, align > > | |
CRebindType< U, LoopSIMD< T, S, A > > | |
CScalarType | Should have a member type type |
CScalarType< AlignedNumber< T, align > > | |
CScalarType< LoopSIMD< T, S, A > > | |
CScalarType< V, std::enable_if_t< VcImpl::IsVector< V >::value > > | Should have a member type type |
►NVcImpl | |
CIsMask | Specialized to true for Vc mask types |
CIsMask< Vc::Mask< T, A > > | |
CIsMask< Vc::SimdMaskArray< T, n, V, m > > | |
CIsVector | Specialized to true for Vc vector and mask types |
CIsVector< Vc::SimdArray< T, n, V, m > > | |
CIsVector< Vc::Vector< T, A > > | |
CIsVectorizable | |
CIsVectorizable< double > | |
CIsVectorizable< float > | |
CIsVectorizable< std::int16_t > | |
CIsVectorizable< std::int32_t > | |
CIsVectorizable< std::uint16_t > | |
CIsVectorizable< std::uint32_t > | |
CProxy | A reference-like proxy for elements of random-access vectors |
CEndMark | Final element marker for RebindList |
CUnitTest | |
►NSimdImpl | |
CInserter | |
►NStd | Namespace for features backported from new C++ standards |
Cconjunction | Forms the logical conjunction of the type traits B.. |
Cdisjunction | Forms the logical disjunction of the type traits B.. |
Cidentity | A function object type whose operator() returns its argument unchanged |
Cnegation | Forms the logical negation of the type traits B.. |
Cnonesuch | Type representing a lookup failure by std::detected_or and friends |
CAddPtrTypeEvaluator | TypeEvaluator to turn a type T into a pointer to T |
CAddPtrTypeEvaluator< T & > | |
CAddRefTypeEvaluator | TypeEvaluator to turn a type T into a reference to T |
►CAlignedAllocator | Allocators which guarantee alignment of the memory |
Crebind | |
CAlignedBase | CRTP base mixin class to check alignment |
CAllSet | A set containing everything |
CAlwaysFalse | Template which always yields a false value |
CAlwaysTrue | Template which always yields a true value |
CArrayList | A dynamically growing random access list |
CArrayListIterator | A random access iterator for the Dune::ArrayList class |
CAssociativePropertyMap | An adapter to turn an unique associative container into a property map |
CAt | Reverse element access |
CAtType | Type for reverse element access |
CAutonomousValueType | Type free of internal references that T can be converted to |
CAutonomousValueType< const T > | Specialization to remove const qualifiers |
CAutonomousValueType< Simd::VcImpl::Proxy< V > > | Specialization of AutonomousValue for Vc proxies |
CAutonomousValueType< std::vector< bool >::reference > | Specialization for the proxies of vector<bool> |
CAutonomousValueType< T & > | Specialization to remove lvalue references |
CAutonomousValueType< T && > | Specialization to remove rvalue references |
CAutonomousValueType< volatile const T > | Specialization to remove both const and volatile qualifiers |
CAutonomousValueType< volatile T > | Specialization to remove volatile qualifiers |
CBidirectionalIteratorFacade | Facade class for stl conformant bidirectional iterators |
Cbigunsignedint | Portable very large unsigned integers |
CBitSetVector | A dynamic array of blocks of booleans |
CBitSetVectorConstReference | A proxy class that acts as a const reference to a single bitset in a BitSetVector |
CBitSetVectorReference | A proxy class that acts as a mutable reference to a single bitset in a BitSetVector |
CBufferedCommunicator | A communicator that uses buffers to gather and scatter the data to be send or received |
CCloneable | An interface class for cloneable objects |
►CCollectiveIterator | A collective iterator for moving over the remote indices for all processes collectively |
Citerator | Iterator over the valid underlying iterators |
CCombine | A set combining two other sets |
Ccommon_bits | Activate if current and mask have common bits switched on |
►CCommPolicy | Default policy used for communicating an indexed type |
CCommPolicy< VariableBlockVector< FieldVector< K, n >, A > > | |
CCommunicationError | Error thrown if there was a problem with the communication |
CCopyGatherScatter | GatherScatter default implementation that just copies data |
CFieldVector | |
CVariableBlockVector | |
CCommunication | Collective communication interface and sequential default implementation |
CCommunication< MPI_Comm > | Specialization of Communication for MPI |
Cconst_reference | Get the 'const' version of a reference to a mutable object |
Cconst_reference< BitSetVectorConstReference< block_size, Alloc > > | |
Cconst_reference< BitSetVectorReference< block_size, Alloc > > | |
Cconst_reference< const R & > | |
Cconst_reference< const R > | |
Cconst_reference< DiagonalRowVector< K, n > > | |
Cconst_reference< DiagonalRowVectorConst< K, n > > | |
Cconst_reference< R & > | |
CConstArrayListIterator | A constant random access iterator for the Dune::ArrayList class |
CConstAssociativePropertyMap | An adaptor to turn an unique associative container into a property map |
CContainerWrapperIterator | Iterator class for sparse vector-like containers |
CDebugStream | Generic class to implement debug output streams |
CDebugStreamError | Standard exception for the debugstream |
CDebugStreamState | Intermediate class to implement tie-operation of DebugStream |
CDenseIterator | Generic iterator class for dense vector and matrix implementations |
CDenseMatrix | A dense n x m matrix |
CDenseMatrixAssigner | You have to specialize this structure for any type that should be assignable to a DenseMatrix |
CDenseMatrixAssigner< DenseMatrix, DiagonalMatrix< field, N > > | |
CDenseMatVecTraits | |
CDenseMatVecTraits< DynamicMatrix< K > > | |
CDenseMatVecTraits< DynamicVector< K, Allocator > > | |
CDenseMatVecTraits< FieldMatrix< K, ROWS, COLS > > | |
CDenseMatVecTraits< FieldVector< K, SIZE > > | |
CDenseVector | Interface for a class of dense vectors over a given field |
CDiagonalMatrix | A diagonal matrix of static size |
CDiagonalMatrixWrapper | |
CDiagonalRowVector | |
CDiagonalRowVectorConst | |
CDynamicMatrix | Construct a matrix with a dynamic size |
CDynamicVector | Construct a vector with a dynamic size |
CEmpty | Just an empty class |
CEmptySet | An empty set |
CEnableIfInterOperable | Enable typedef if two types are interoperable |
CEnumItem | A set consisting only of one item |
CEnumRange | A set representing a range including the borders |
CException | Base class for Dune-Exceptions |
CExceptionHook | Base class to add a hook to the Dune::Exception |
CFactorial | |
CFactorial< 0 > | End of recursion of factorial via specialization |
CFakeMPIHelper | A fake mpi helper |
CFieldMatrix | A dense n x m matrix |
CFieldTraits | |
CFieldTraits< const T > | |
CFieldTraits< DenseMatrix< M > > | |
CFieldTraits< DenseVector< V > > | |
CFieldTraits< DiagonalMatrix< K, n > > | |
CFieldTraits< DynamicMatrix< K > > | |
CFieldTraits< DynamicVector< K, Allocator > > | |
CFieldTraits< FieldMatrix< K, ROWS, COLS > > | |
CFieldTraits< FieldVector< K, SIZE > > | |
CFieldTraits< std::complex< T > > | |
CFieldTraits< std::vector< T > > | |
CFieldTraits< T[N] > | |
CFieldVector | Vector space out of a tensor product of fields |
CFirstPredicateIndex | Finding the index of a certain type in a std::tuple |
CFirstTypeIndex | Find the first occurrence of a type in a std::tuple |
CFlattenTuple | Flatten a std::tuple of std::tuple's |
CFloatCmpOps | Class encapsulating a default epsilon |
CFMatrixError | Error thrown if operations of a FieldMatrix fail |
CFMatrixPrecision | Precisions for calculations with FieldMatrix and FieldVector |
CForEachType | Helper template to clone the type definition of a std::tuple with the storage types replaced by a user-defined rule |
CForEachType< TE, std::tuple< Args... > > | |
CForwardIteratorFacade | Base class for stl conformant forward iterators |
►CFunction | Base class template for function classes |
CTraits | Traits class containing raw types |
CFuture | Type-erasure for future-like objects. A future-like object is a object satisfying the interface of FutureBase |
CGeneric_MPI_Op | |
CGenericIterator | Generic class for stl-conforming iterators for container classes with operator[] |
CGlobalLookupIndexSet | Decorates an index set with the possibility to find a global index that is mapped to a specific local |
CGMPField | Number class for high precision floating point number using the GMP library mpf_class implementation |
Cgreater_or_equal | Greater or equal template test |
Chash | Functor for hashing objects of type T |
CHasNaN | Whether this type has a value of NaN |
CHelpRequest | Exception thrown if the user wants to see help string |
CIdentityMap | A property map that applies the identity function to integers |
CImplementationDefined | Dummy struct used for documentation purposes |
CIndent | Utility class for handling nested indentation in output |
CIndexPair | A pair consisting of a global and local index |
CIndexSetSortFunctor | |
CIndicesSyncer | Class for recomputing missing indices of a distributed index set |
CIntegerSequenceEntry | Get entry of std::integer_sequence |
CIntegralRange | Dynamic integer range for use in range-based for loops |
CInterface | Communication interface between remote and local indices |
►CInterfaceBuilder | Base class of all classes representing a communication interface |
CRemoteIndicesStateError | |
CInterfaceInformation | Information describing an interface |
CInvalidFutureException | 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 |
CInvalidIndexSetState | Exception indicating that the index set is not in the expected state |
CInvalidStateException | Default exception if a function was called while the object is not in a valid state for that function |
CIOError | Default exception class for I/O errors |
Cios_base_all_saver | Utility class for storing and resetting stream attributes |
CIsCallable | Check if a type is callable with ()-operator and given arguments |
CIsCallable< F(Args...), R > | Check if a type is callable with ()-operator and given arguments |
CIsEmptyTypeList | Check if given type is an empty TypeList |
CIsFieldVectorSizeCorrect | TMP to check the size of a DenseVectors statically, if possible |
CIsFieldVectorSizeCorrect< FieldVector< T, SIZE >, SIZE > | |
CIsFieldVectorSizeCorrect< FieldVector< T, SIZE1 >, SIZE > | |
CIsIndexable | 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 |
CIsIntegralConstant | Check if T is an std::integral_constant<I, i> |
CIsInteroperable | Checks whether two types are interoperable |
CIsIterable | Typetrait to check that a class has begin() and end() members |
CIsNumber | Whether this type acts as a scalar in the context of (hierarchically blocked) containers |
CIsNumber< AlignedNumberImpl::AlignedNumber< T, align > > | |
CIsNumber< bigunsignedint< k > > | Declare big unsigned int is a number |
CIsNumber< GMPField< precision > > | |
CIsNumber< LoopSIMD< T, S, A > > | |
CIsNumber< Vc::SimdArray< T, N, V, Wt > > | |
CIsNumber< Vc::Vector< T, Abi > > | |
CIsTuple | Check if T is a std::tuple<...> |
CIsTupleOrDerived | Check if T derived from a std::tuple<...> |
►CIsType | Generator for predicates accepting one particular type |
CPredicate | The actual predicate |
CIsTypeList | Check if given type is a TypeList |
CIsTypeList< TypeList< T... > > | Check if given type is a TypeList. |
CIsVector | |
CIsVector< T, std::void_t< typename T::field_type > > | |
CIteratorPropertyMap | Adapter to turn a random access iterator into a property map |
CIteratorRange | Simple range between a begin and an end iterator |
CIteratorTransformationTag | Tag to enable iterator based transformations in TransformedRangeView |
CJoinTuples | Join two std::tuple's |
CLocalIndex | An index present on the local process |
CLocalIndexComparator | |
CLocalIndexComparator< ParallelLocalIndex< T > > | |
CLoopSIMD | |
Clru | LRU Cache Container |
CLvaluePropertyMapTag | Tag for the category of lvalue property maps |
►CMallocAllocator | Allocators implementation which simply calls malloc/free |
Crebind | |
CMathematicalConstants | Provides commonly used mathematical constants |
CMathError | Default exception class for mathematical errors |
CMax | |
CMetaType | A type that refers to another type |
CMin | |
CMPIData | |
CMPIData< P, std::enable_if_t< std::is_same< std::remove_const_t< P >, MPIPack >::value > > | |
CMPIData< T, std::void_t< std::tuple< decltype(std::declval< T >().data()), decltype(std::declval< T >().size()), typename std::decay_t< T >::value_type > > > | |
CMPIData< void > | |
CMPIFuture | 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 |
CMPIGuard | Detects a thrown exception and communicates to all other processes |
CMPIGuardError | This exception is thrown if the MPIGuard detects an error on a remote process |
CMPIHelper | A real mpi helper |
CMPIPack | |
CMPITraits | A traits class describing the mapping of types onto MPI_Datatypes |
CMPITraits< IndexPair< TG, ParallelLocalIndex< TA > > > | |
CMPITraits< ParallelLocalIndex< T > > | |
Cmutable_reference | Get the 'mutable' version of a reference to a const object |
Cmutable_reference< BitSetVectorConstReference< block_size, Alloc > > | |
Cmutable_reference< BitSetVectorReference< block_size, Alloc > > | |
Cmutable_reference< const R & > | |
Cmutable_reference< const R > | |
Cmutable_reference< DiagonalRowVector< K, n > > | |
Cmutable_reference< DiagonalRowVectorConst< K, n > > | |
Cmutable_reference< R & > | |
CNegateSet | The negation of a set. An item is contained in the set if and only if it is not contained in the negated set |
CNo_Comm | |
CNotImplemented | Default exception for dummy implementations |
Cnull_deleter | Implements the Deleter concept of shared_ptr without deleting anything |
CNullPointerInitialiser | A helper template that initializes a std::tuple consisting of pointers to nullptr |
CNullPointerInitialiser< std::tuple< Args... > > | |
COutOfMemoryError | Default exception if memory allocation fails |
COwnerOverlapCopyCommunication | |
CParallelError | Default exception if an error in the parallel communication of the program occurred |
►CParallelIndexSet | Manager class for the mapping between local indices and globally unique indices |
Citerator | The iterator over the pairs |
CParallelLocalIndex | An index present on the local process with an additional attribute flag |
CParameterizedObjectFactory | A factory class for parameterized objects |
CParameterizedObjectFactory< TypeT(Args...), KeyT > | |
►CParameterTree | Hierarchical structure of string parameters |
►CParser< bool > | |
CToLower | |
CParser< FieldVector< T, n > > | |
CParser< std::array< T, n > > | |
CParser< std::basic_string< char, traits, Allocator > > | |
CParser< std::bitset< n > > | |
CParser< std::vector< T, A > > | |
CParameterTreeParser | Parsers to set up a ParameterTree from various input sources |
CParameterTreeParserError | Report parser error while reading ParameterTree |
CPointerPairDeletor | Deletes all objects pointed to in a std::tuple of pointers |
CPool | A memory pool of objects |
►CPoolAllocator | An allocator managing a pool of objects for reuse |
Crebind | Rebind the allocator to another type |
►CPoolAllocator< void, s > | |
Crebind | |
CPower | Compute power for a run-time base and a compile-time integer exponent |
CPriorityTag | Helper class for tagging priorities |
CPriorityTag< 0 > | Helper class for tagging priorities |
CPromotionTraits | Compute type of the result of an arithmetic operation involving two different number types |
CPromotionTraits< GMPField< precision >, GMPField< precision > > | |
CPromotionTraits< GMPField< precision >, T > | |
CPromotionTraits< GMPField< precision1 >, GMPField< precision2 > > | |
CPromotionTraits< T, GMPField< precision > > | |
CPromotionTraits< T1, T1 > | |
CPropertyMapTraits | |
CPropertyMapTraits< const T * > | |
CPropertyMapTraits< T * > | |
CPropertyMapTypeSelector | Selector for the property map type |
CPseudoFuture | A wrapper-class for a object which is ready immediately |
CPseudoFuture< void > | |
CPushBackTuple | Helper template to append a type to a std::tuple |
CPushBackTuple< typename std::tuple< Args... >, T > | |
CPushFrontTuple | Helper template to prepend a type to a std::tuple |
CPushFrontTuple< typename std::tuple< Args... >, T > | |
CRandomAccessIteratorFacade | Base class for stl conformant forward iterators |
CRangeError | Default exception class for range errors |
CRAPropertyMapHelper | |
CReadablePropertyMapTag | Tag for the category of readable property maps |
CReadWritePropertyMapTag | Tag for the category of readable and writable property maps |
CReduceTuple | Apply reduce with meta binary function to template |
CReduceTuple< F, Tuple, Seed, 0 > | Apply reduce with meta binary function to template |
CRemoteIndex | Information about an index residing on another processor |
►CRemoteIndexListModifier | Modifier for adding and/or deleting remote indices from the remote index list |
CInvalidPosition | |
CRemoteIndices | The indices present on remote processes |
CReservedVector | A Vector class with statically reserved memory |
CSelection | A cached selection of indices |
CSelectionIterator | A const iterator over an uncached selection |
CSimdIndexTypeTraits | |
CSimdMaskTypeTraits | |
CSimdScalarTypeTraits | |
CSimdScalarTypeTraits< AlignedNumber< T, align > > | Deduce the underlying scalar data type of an AlignedNumber |
CSingleton | An adapter to turn a class into a singleton |
CSizeOf | Compute size of variadic type list |
CSizeOne | Flag for marking indexed data structures where data at each index is of the same size |
CSLList | A single linked list |
CSLListConstIterator | A constant iterator for the SLList |
CSLListIterator | A mutable iterator for the SLList |
CSLListModifyIterator | A mutable iterator for the SLList |
CStandardMathematicalConstants | Standard implementation of MathematicalConstants |
CStaticIntegralRange | Static integer range for use in range-based for loops |
CStaticPower | Calculates b^p at compile time |
CStreamWrap | |
CSystemError | Default exception class for OS errors |
CTimer | A simple stop watch |
CTransformedRangeView | A range transforming the values of another range on-the-fly |
►CTransformTupleFunctor | |
CTypeEvaluator | |
CTupleAccessTraits | |
CTupleAccessTraits< T & > | |
CTupleAccessTraits< T * > | |
CTupleVector | A class augmenting std::tuple by element access via operator[] |
CTypeListElement | |
CTypeListElement< i, TypeList< T... > > | Get element of TypeList |
CTypeListSize | |
CTypeListSize< TypeList< T... > > | Get size of TypeList |
CUncachedSelection | An uncached selection of indices |
CValueTransformationTag | Tag to enable value based transformations in TransformedRangeView |
CVariableSize | Flag for marking indexed data structures where the data at each index may be a variable multiple of another type |
CVariableSizeCommunicator | A buffered communicator where the amount of data sent does not have to be known a priori |
CVirtualFunction | Virtual base class template for function classes |
CWritablePropertyMapTag | Tag for the category of writable property maps |