 Dune | Dune namespace |
  Concept | Namespace for concepts |
   Imp | |
    TupleEntriesModelHelper | |
     AccumulateFunctor | |
   Refines | Base class for refined concepts |
  DenseMatrixHelp | |
  detail | |
   voider | |
  DynamicMatrixHelp | |
  FloatCmp | |
   Detail | |
    eq_t | |
    eq_t< T, relativeWeak > | |
    eq_t< T, relativeStrong > | |
    eq_t< T, absolute > | |
    eq_t< std::vector< T >, cstyle > | |
    eq_t< Dune::FieldVector< T, n >, cstyle > | |
    round_t | |
    round_t< I, T, cstyle, downward > | |
    round_t< I, T, cstyle, upward > | |
    round_t< I, T, cstyle, towardZero > | |
    round_t< I, T, cstyle, towardInf > | |
    round_t< std::vector< I >, std::vector< T >, cstyle, rstyle > | |
    round_t< Dune::FieldVector< I, n >, Dune::FieldVector< T, n >, cstyle, rstyle > | |
    trunc_t | |
    trunc_t< I, T, cstyle, downward > | |
    trunc_t< I, T, cstyle, upward > | |
    trunc_t< I, T, cstyle, towardZero > | |
    trunc_t< I, T, cstyle, towardInf > | |
    trunc_t< std::vector< I >, std::vector< T >, cstyle, rstyle > | |
    trunc_t< Dune::FieldVector< I, n >, Dune::FieldVector< T, n >, cstyle, rstyle > | |
   EpsilonType | Mapping of value type to epsilon type |
   EpsilonType< std::vector< T, A > > | Specialization of EpsilonType for std::vector |
   EpsilonType< FieldVector< T, n > > | Specialization of EpsilonType for Dune::FieldVector |
   DefaultEpsilon< T, relativeWeak > | |
   DefaultEpsilon< T, relativeStrong > | |
   DefaultEpsilon< T, absolute > | |
   DefaultEpsilon | Mapping from a value type and a compare style to a default epsilon |
  FMatrixHelp | |
  fvmeta | |
  Hybrid | |
   Impl | |
    StaticIntegralRange | |
    DynamicIntegralRange | |
  Imp | |
   IsTuple | |
   IsTuple< std::tuple< T...> > | |
   IsIntegralConstant | |
   IsIntegralConstant< std::integral_constant< T, t > > | |
  Impl | |
   OverloadSet | |
   OverloadSet< F0 > | |
   OrderedOverloadSet | |
   OrderedOverloadSet< F0 > | |
  Indices | Namespace with predefined compile time indices for the range [0,19] |
  Std | |
   Imp | |
   Impl | |
   MakeUniqueHelper | |
   MakeUniqueHelper< T[]> | |
   MakeUniqueHelper< T[N]> | |
   to_false_type | Template mapping a type to std::false_type |
   to_true_type | Template mapping a type to std::true_type |
   is_callable | Traits class to check if function is callable |
   is_callable< F(Args...), R > | Traits class to check if function is callable |
  AlignmentOf | Calculates the alignment requirement of a type |
  ArrayListIterator | A random access iterator for the Dune::ArrayList class |
  ConstArrayListIterator | A constant random access iterator for the Dune::ArrayList class |
  ArrayList | A dynamically growing random access list |
  MPITraits | A traits class describing the mapping of types onto MPI_Datatypes |
  bigunsignedint | Portable very large unsigned integers |
  Min | |
  Max | |
  BitSetVector | A dynamic array of blocks of booleans |
  BitSetVectorReference | A proxy class that acts as a mutable reference to a single bitset in a BitSetVector |
  BitSetVectorConstReference | A proxy class that acts as a const reference to a single bitset in a BitSetVector |
  const_reference< BitSetVectorReference< block_size, Alloc > > | |
  const_reference< BitSetVectorConstReference< block_size, Alloc > > | |
  mutable_reference< BitSetVectorReference< block_size, Alloc > > | |
  mutable_reference< BitSetVectorConstReference< block_size, Alloc > > | |
  DebugAllocator | Allocators implementation which performs different kind of memory checks |
   rebind | |
  DebugAllocator< void > | |
   rebind | |
  greater_or_equal | Greater or equal template test |
  common_bits | Activate if current and mask have common bits switched on |
  DebugStreamError | Standard exception for the debugstream |
  StreamWrap | |
  DebugStreamState | Intermediate class to implement tie-operation of DebugStream |
  DebugStream | Generic class to implement debug output streams |
  DenseMatrix | A dense n x m matrix |
  FieldTraits< DenseMatrix< M > > | |
  FieldMatrix | A dense n x m matrix |
  FieldVector | Vector space out of a tensor product of fields |
  DenseMatrixAssigner | You have to specialize this structure for any type that should be assignable to a DenseMatrix |
  FMatrixError | Error thrown if operations of a FieldMatrix fail |
  DenseVector | Interface for a class of dense vectors over a given field |
  FieldTraits< DenseVector< V > > | |
  DenseIterator | Generic iterator class for dense vector and matrix implementations |
  DiagonalRowVectorConst | |
  DiagonalRowVector | |
  DiagonalMatrixWrapper | |
  ContainerWrapperIterator | Iterator class for sparse vector-like containers |
  DiagonalMatrix | A diagonal matrix of static size |
  const_reference< DiagonalRowVector< K, n > > | |
  const_reference< DiagonalRowVectorConst< K, n > > | |
  mutable_reference< DiagonalRowVector< K, n > > | |
  mutable_reference< DiagonalRowVectorConst< K, n > > | |
  DenseMatrixAssigner< DenseMatrix, DiagonalMatrix< field, N > > | |
  ImplementationDefined | Dummy struct used for documentation purposes |
  AlwaysVoid | |
  IsVector | |
  IsVector< T, typename AlwaysVoid< typename T::field_type >::type > | |
  DynamicMatrix | Construct a matrix with a dynamic size |
  DenseMatVecTraits< DynamicMatrix< K > > | |
  FieldTraits< DynamicMatrix< K > > | |
  DynamicVector | Construct a vector with a dynamic size |
  DenseMatVecTraits< DynamicVector< K, Allocator > > | |
  FieldTraits< DynamicVector< K, Allocator > > | |
  EmptySet | An empty set |
  AllSet | A set containing everything |
  EnumItem | A set consisting only of one item |
  EnumRange | A set representing a range including the borders |
  NegateSet | The negation of a set. An item is contained in the set if and only if it is not contained in the negated set |
  Combine | A set combining two other sets |
  Exception | Base class for Dune-Exceptions |
  ExceptionHook | Base class to add a hook to the Dune::Exception |
  IOError | Default exception class for I/O errors |
  MathError | Default exception class for mathematical errors |
  RangeError | Default exception class for range errors |
  NotImplemented | Default exception for dummy implementations |
  SystemError | Default exception class for OS errors |
  OutOfMemoryError | Default exception if memory allocation fails |
  InvalidStateException | Default exception if a function was called while the object is not in a valid state for that function |
  ParallelError | Default exception if an error in the parallel communication of the programm occurred |
  FloatCmpOps | Class encapsulating a default epsilon |
  DenseMatVecTraits< FieldMatrix< K, ROWS, COLS > > | |
  FieldTraits< FieldMatrix< K, ROWS, COLS > > | |
  ForLoop | A static loop using TMP |
  FieldTraits | |
  FieldTraits< const T > | |
  FieldTraits< std::complex< T > > | |
  FieldTraits< T[N] > | |
  FieldTraits< std::vector< T > > | |
  Function | Base class template for function classes |
   Traits | Traits class containing raw types |
  VirtualFunction | Virtual base class template for function classes |
  DenseMatVecTraits< FieldVector< K, SIZE > > | |
  FieldTraits< FieldVector< K, SIZE > > | |
  IsFieldVectorSizeCorrect | TMP to check the size of a DenseVectors statically, if possible |
  IsFieldVectorSizeCorrect< FieldVector< T, SIZE >, SIZE > | |
  IsFieldVectorSizeCorrect< FieldVector< T, SIZE1 >, SIZE > | |
  Gcd | Calculator of the greatest common divisor |
  const_reference | Get the 'const' version of a reference to a mutable object |
  const_reference< const R > | |
  const_reference< R & > | |
  const_reference< const R & > | |
  mutable_reference | Get the 'mutable' version of a reference to a const object |
  mutable_reference< const R > | |
  mutable_reference< R & > | |
  mutable_reference< const R & > | |
  GenericIterator | Generic class for stl-conforming iterators for container classes with operator[] |
  GMPField | Number class for high precision floating point number using the GMP library mpf_class implementation |
  IsNumber< GMPField< precision > > | |
  hash | Functor for hashing objects of type T |
  IdentityMatrix | Read-only identity matrix |
  DenseMatrixAssigner< DenseMatrix, IdentityMatrix< field, N > > | |
  Indent | Utility class for handling nested indentation in output |
  Cloneable | An interface class for cloneable objects |
  ios_base_all_saver | Utility class for storing and resetting stream attributes |
  ForwardIteratorFacade | Base class for stl conformant forward iterators |
  BidirectionalIteratorFacade | Facade class for stl conformant bidirectional iterators |
  RandomAccessIteratorFacade | Base class for stl conformant forward iterators |
  IteratorRange | Simple range between a begin and an end iterator |
  Lcm | Calculate the least common multiple of two numbers |
  lru | LRU Cache Container |
  MallocAllocator | Allocators implementation which simply calls malloc/free |
   rebind | |
  MathematicalConstants | Provides commonly used mathematical constants |
  StandardMathematicalConstants | Standard implementation of MathematicalConstants |
  Factorial | Calculates the factorial of m at compile time |
  Factorial< 0 > | End of recursion of factorial via specialization |
  DenseMatVecTraits | |
  No_Comm | |
  CollectiveCommunication | Collective communication interface and sequential default implementation |
  SizeOne | Flag for marking indexed data structures where data at each index is of the same size |
  VariableSize | Flag for marking indexed data structures where the data at each index may be a variable multiple of another type |
  CommPolicy | Default policy used for communicating an indexed type |
   CommPolicy< VariableBlockVector< FieldVector< K, n >, A > > | |
   CommunicationError | Error thrown if there was a problem with the communication |
   CopyGatherScatter | GatherScatter default implementation that just copies data |
   FieldVector | |
   VariableBlockVector | |
  BufferedCommunicator | A communicator that uses buffers to gather and scatter the data to be send or received |
  IndexPair | A pair consisting of a global and local index |
  InvalidIndexSetState | Exception indicating that the index set is not in the expected state |
  GlobalLookupIndexSet | Decorates an index set with the possibility to find a global index that is mapped to a specific local |
  ParallelIndexSet | Manager class for the mapping between local indices and globally unique indices |
   iterator | The iterator over the pairs |
  LocalIndexComparator | |
  IndexSetSortFunctor | |
  IndicesSyncer | Class for recomputing missing indices of a distributed index set |
  InterfaceBuilder | Base class of all classes representing a communication interface |
   RemoteIndicesStateError | |
  InterfaceInformation | Information describing an interface |
  Interface | Communication interface between remote and local indices |
  LocalIndex | An index present on the local process |
  Generic_MPI_Op | |
  CollectiveCommunication< MPI_Comm > | Specialization of CollectiveCommunication for MPI |
  MPIGuardError | This exception is thrown if the MPIGuard detects an error on a remote process |
  MPIGuard | Detects a thrown exception and communicates to all other processes |
  FakeMPIHelper | A fake mpi helper |
  MPIHelper | A real mpi helper.This helper should be used for parallel programs |
  ParallelLocalIndex | An index present on the local process with an additional attribute flag |
  LocalIndexComparator< ParallelLocalIndex< T > > | |
  MPITraits< ParallelLocalIndex< T > > | |
  MPITraits< IndexPair< TG, ParallelLocalIndex< TA > > > | |
  RemoteIndices | The indices present on remote processes |
  RemoteIndex | Information about an index residing on another processor |
  RemoteIndexListModifier | Modifier for adding and/or deleting remote indices from the remote index list |
   InvalidPosition | |
  CollectiveIterator | A collective iterator for moving over the remote indices for all processes collectively |
   iterator | Iterator over the valid underlying iterators |
  OwnerOverlapCopyCommunication | |
  SelectionIterator | A const iterator over an uncached selection |
  UncachedSelection | An uncached selection of indices |
  Selection | A cached selection of indices |
  VariableSizeCommunicator | A buffered communicator where the amount of data sent does not have to be known a priori |
  ParameterTree | Hierarchical structure of string parameters |
   Parser< bool > | |
    ToLower | |
   Parser< FieldVector< T, n > > | |
   Parser< std::array< T, n > > | |
   Parser< std::basic_string< char, traits, Allocator > > | |
   Parser< std::bitset< n > > | |
   Parser< std::vector< T, A > > | |
  ParameterTreeParserError | Report parser error while reading ParameterTree |
  HelpRequest | Exception thrown if the user wants to see help string |
  ParameterTreeParser | Parsers to set up a ParameterTree from various input sources |
  Pool | A memory pool of objects |
  PoolAllocator | An allocator managing a pool of objects for reuse |
   rebind | Rebind the allocator to another type |
  PoolAllocator< void, s > | |
   rebind | |
  StaticPower | Calculates m^p at compile time |
  StaticPower< m, 0 > | End of recursion via specialization |
  Power | Compute power for a run-time mantissa and a compile-time integer exponent |
  FMatrixPrecision | Precisions for calculations with FieldMatrix and FieldVector |
  PromotionTraits | Compute type of the result of an arithmetic operation involving two different number types |
  PromotionTraits< T1, T1 > | |
  PropertyMapTraits | |
  ReadablePropertyMapTag | Tag for the category of readable property maps |
  WritablePropertyMapTag | Tag for the category of writable property maps |
  ReadWritePropertyMapTag | Tag for the category of readable and writable property maps |
  LvaluePropertyMapTag | Tag for the category of lvalue property maps |
  PropertyMapTraits< T * > | |
  PropertyMapTraits< const T * > | |
  RAPropertyMapHelper | |
  IteratorPropertyMap | Adapter to turn a random access iterator into a property map |
  AssociativePropertyMap | An adapter to turn an unique associative container into a property map |
  ConstAssociativePropertyMap | An adaptor to turn an unique associative container into a property map |
  IdentityMap | A property map that applies the identity function to integers |
  PropertyMapTypeSelector | Selector for the property map type |
  ReservedVector | A Vector class with statically reserved memory |
  null_deleter | Implements the Deleter concept of shared_ptr without deleting anything |
  SimdScalarTypeTraits | |
  Singleton | An adapter to turn a class into a singleton |
  SLListIterator | A mutable iterator for the SLList |
  SLListConstIterator | A constant iterator for the SLList |
  SLListModifyIterator | A mutable iterator for the SLList |
  SLList | A single linked list |
  TimerError | Exception thrown by the Timer class |
  Timer | A simple stop watch |
  TupleAccessTraits | |
  TupleAccessTraits< T * > | |
  TupleAccessTraits< T & > | |
  NullPointerInitialiser | A helper template that initializes a std::tuple consisting of pointers to nullptr |
  NullPointerInitialiser< std::tuple< Args...> > | |
  ForEachType | Helper template to clone the type definition of a std::tuple with the storage types replaced by a user-defined rule |
  ForEachType< TE, std::tuple< Args...> > | |
  TransformTupleFunctor | |
   TypeEvaluator | |
  AddRefTypeEvaluator | TypeEvaluator to turn a type T into a reference to T |
  AddPtrTypeEvaluator | TypeEvaluator to turn a type T into a pointer to T |
  AddPtrTypeEvaluator< T & > | |
  ForEachValue | Helper template which implements iteration over all storage elements in a std::tuple |
  ForEachValuePair | Extension of ForEachValue to two std::tuple's |
  AtType | Type for reverse element access |
  At | Reverse element access |
  PointerPairDeletor | Deletes all objects pointed to in a std::tuple of pointers |
  FirstPredicateIndex | Finding the index of a certain type in a std::tuple |
  IsType | Generator for predicates accepting one particular type |
   Predicate | The actual predicate |
  FirstTypeIndex | Find the first occurrence of a type in a std::tuple |
  PushBackTuple | Helper template to append a type to a std::tuple |
  PushBackTuple< typename std::tuple< Args...>, T > | |
  PushFrontTuple | Helper template to prepend a type to a std::tuple |
  PushFrontTuple< typename std::tuple< Args...>, T > | |
  ReduceTuple | Apply reduce with meta binary function to template |
  ReduceTuple< F, Tuple, Seed, 0 > | Apply reduce with meta binary function to template |
  JoinTuples | Join two std::tuple's |
  FlattenTuple | Flatten a std::tuple of std::tuple's |
  TupleVector | A class augmenting std::tuple by element access via operator[] |
  TypeList | A simple type list |
  IsTypeList | Check if given type is a TypeList |
  IsTypeList< TypeList< T...> > | Check if given type is a TypeList. |
  IsEmptyTypeList | Check if given type is an empty TypeList |
  TypeListSize | |
  TypeListSize< TypeList< T...> > | Get size of TypeList |
  TypeListElement | |
  TypeListElement< i, TypeList< T...> > | Get element of TypeList |
  Empty | Just an empty class |
  ConstantVolatileTraits | Determines whether a type is const or volatile and provides the unqualified types |
  IsVolatile | Tests whether a type is volatile |
  IsConst | Tests whether a type is constant |
  remove_const | |
  remove_reference | |
  Conversion | Checks whether a type is convertible to another |
  IsBaseOf | Checks whether a type is derived from another |
  IsInteroperable | Checks whether two types are interoperable |
  enable_if | |
  enable_if< true, T > | |
  EnableIfInterOperable | Enable typedef if two types are interoperable |
  is_same | |
  conditional | |
  integral_constant | |
  true_type | |
  false_type | |
  is_pointer | |
  is_lvalue_reference | |
  remove_pointer | |
  AlwaysFalse | Template which always yields a false value |
  AlwaysTrue | Template which always yields a true value |
  IsNumber | |
  IsNumber< std::complex< T > > | |
  has_nan | |
  has_nan< std::complex< T > > | |
  is_indexable | |
  is_range | |
  IsTuple | Check if T is a std::tuple<...> |
  IsTupleOrDerived | Check if T derived from a std::tuple<...> |
  IsIntegralConstant | Check if T is an std::integral_constant<I, i> |
  SizeOf | Compute size of variadic type list |
  PriorityTag | Helper class for tagging priorities |
  PriorityTag< 0 > | Helper class for tagging priorities |
 std | STL namespace |
  numeric_limits< Dune::bigunsignedint< k > > | |