►Nboost | |
►Nproperty_tree | |
Cbasic_ptree | |
►NDune | |
►NAmg | |
CAggregationLevelTransferPolicyCpr | A LeveTransferPolicy that used aggregation to construct the coarse level system |
CAMGCPR | Parallel algebraic multigrid based on agglomeration |
CConstructionTraits< MultithreadDILU< M, X, Y > > | Policy for the construction of the MultithreadDILU smoother |
CConstructionTraits< Opm::ParallelRestrictedOverlappingSchwarz< Range, Domain, ParallelInfo, SeqPreconditioner > > | Tells AMG how to construct the Opm::ParallelOverlappingILU0 smoother |
CKAMG | |
CKAmgTwoGrid | |
CLevelTransferPolicyCpr | Abstract base class for transfer between levels and creation of the coarse level system |
COneStepAMGCoarseSolverPolicyCpr | A policy class for solving the coarse level system using one step of AMG |
CPressureSolverPolicy | |
CSmootherTraits< Opm::ParallelRestrictedOverlappingSchwarz< Range, Domain, ParallelInfo, SeqPreconditioner > > | Tells AMG how to use Opm::ParallelOverlappingILU0 smoother |
CTwoLevelMethodCpr | |
►NMatrixMarketImpl | |
Cmm_block_structure_header< BCRSMatrix< Opm::MatrixBlock< T, i, j >, A > > | |
Cmm_header_printer< BCRSMatrix< Opm::MatrixBlock< T, i, j >, A > > | |
Cmm_multipliers< BCRSMatrix< Opm::MatrixBlock< T, i, j >, A > > | |
CCartesianIndexMapper | |
►CCartesianIndexMapper< Dune::ALUGrid< 3, 3, Dune::cube, Dune::nonconforming > > | Interface class to access the logical Cartesian grid as used in industry standard simulator decks |
CGlobalIndexDataHandle | |
CDummyUpdatePreconditioner | |
CFlexibleSolver | A solver class that encapsulates all needed objects for a linear solver (operator, scalar product, iterative solver and preconditioner) and sets them up based on runtime parameters, using the PreconditionerFactory for setting up preconditioners |
CGeneralPreconditionerMaker | Interface class ensuring make function is overriden |
CMultithreadDILU | The OpenMP thread parallelized DILU preconditioner |
COwningBlockPreconditioner | |
COwningTwoLevelPreconditioner | A version of the two-level preconditioner that is: |
CPreconditionerMaker | Struct implementing a make function which creates a preconditioner Can create arbitrary preconditioners using parameter packs as template arguments |
CPreconditionerWithUpdate | Interface class adding the update() method to the preconditioner interface |
CRebuildOnUpdatePreconditioner | Wrapper class of preconditioners that should be reconstructed on update |
CUMFPack | |
►NOpm | This file contains a set of helper functions used by VFPProd / VFPInj |
►NAccelerator | |
CamgclSolverBackend | This class does not implement a solver, but converts the BCSR format to normal CSR and uses amgcl for solving Note amgcl also implements blocked solvers, but looks like it needs unblocked input data |
CBdaResult | This class is based on InverseOperatorResult struct from dune/istl/solver.hh It is needed to prevent a compile error in basearray.hh, the nvcc compiler might not support all features in there |
CBdaSolver | This class serves to simplify choosing between different backend solvers, such as cusparseSolver and openclSolver This class is abstract, no instantiations can of it can be made, only of its children |
CBILU0 | This class implements a Blocked ILU0 preconditioner The decomposition is done on GPU, using exact decomposition, or ChowPatel decomposition The preconditioner is applied via two exact triangular solves |
CBISAI | This class implements a Blocked version of the Incomplete Sparse Approximate Inverse (ISAI) preconditioner |
CBlockedMatrix | This struct resembles a blocked csr matrix, like Dune::BCRSMatrix |
CCPR | This class implements a Constrained Pressure Residual (CPR) preconditioner |
CcusparseSolverBackend | This class implements a cusparse-based ilu0-bicgstab solver on GPU |
CMatrix | This struct resembles a csr matrix, only doubles are supported The data is stored in contiguous memory, such that they can be copied to a device in one transfer |
COpenclKernels | |
COpenclMatrix | This struct resembles a csr matrix, only doubles are supported The matrix data is stored in OpenCL Buffers |
CopenclSolverBackend | This class implements a opencl-based ilu0-bicgstab solver on GPU |
CPreconditioner | |
CrocalutionSolverBackend | This class implements a rocalution based linear solver solver on GPU It uses ilu0-bicgstab |
CrocsparseSolverBackend | This class implements a rocsparse-based ilu0-bicgstab solver on GPU |
►Ncuistl | |
►Ndetail | Contains wrappers to make the CuBLAS library behave as a modern C++ library with function overlading |
CCuBlasHandle | Singleton for the simulator universal cuBlasHandle |
CCuSparseHandle | Singleton for the simulator universal cuSparseHandle |
CCuSparseResource | The CuSparseResource class wraps a CuSparse resource in a proper RAII pattern |
Chas_communication | The has_communication class checks if the type has the member function getCommunication |
Chas_should_call_post | The has_should_call_post class detects the presence of the method shouldCallPost |
Chas_should_call_pre | The has_should_call_pre class detects the presence of the method shouldCallPre |
Cis_a_well_operator | The is_a_well_operator class tries to guess if the operator is a well type operator |
CCuBlockPreconditioner | Is an adaptation of Dune::BlockPreconditioner that works within the CuISTL framework |
CCuDILU | DILU preconditioner on the GPU |
CCuJac | Jacobi preconditioner on the GPU |
CCuOwnerOverlapCopy | CUDA compatiable variant of Dune::OwnerOverlapCopyCommunication |
CCuSeqILU0 | Sequential ILU0 preconditioner on the GPU through the CuSparse library |
CCuSparseMatrix | The CuSparseMatrix class simple wrapper class for a CuSparse matrix |
CPreconditionerAdapter | Makes a CUDA preconditioner available to a CPU simulator |
CPreconditionerConvertFieldTypeAdapter | Converts the field type (eg |
CPreconditionerHolder | Common interface for adapters that hold preconditioners |
CSolverAdapter | Wraps a CUDA solver to work with CPU data |
►NDamarisOutput | Below are the Damaris Keywords supported by Damaris to be filled in the built-in XML file |
CDamarisSettings | |
CDamarisVar | Class to store a Damaris variable representation for the XML file (can be used with class DamarisKeywords) |
CDamarisVarXMLAttributes | This class contains the extra elements that need to be part of a Damaris <variable> type |
►Ndetail | |
CBdaSolverInfo | |
CInterpData | Helper struct for linear interpolation |
CNoReorderer | |
CParallelFileMerger | A functor that merges multiple files of a parallel run to one file |
CRealReorderer | |
CReorderer | |
CVFPEvaluation | An "ADB-like" structure with a single value and a set of derivatives |
►NEQUIL | Types and routines that collectively implement a basic ECLIPSE-style equilibration-based initialisation scheme |
►NDeckDependent | |
CInitialStateComputer | |
►NDetails | |
CPhaseQuantityValue | Simple set of per-phase (named by primary component) quantities |
►CPhaseSaturations | Calculator for phase saturations |
CPosition | Evaluation point within a model geometry |
CPressureTable | |
CRK4IVP | |
►NMiscibility | Types and routines relating to phase mixing in equilibration calculations |
CNoMixing | Type that implements "no phase mixing" policy |
CPBVD | Type that implements "dissolved gas-oil ratio" tabulated as a function of depth policy |
CPDVD | Type that implements "vaporized oil-gas ratio" tabulated as a function of depth policy |
CRsFunction | Base class for phase mixing functions |
CRsSatAtContact | Class that implements "dissolved gas-oil ratio" (Rs) as function of depth and pressure as follows: |
CRsVD | Type that implements "dissolved gas-oil ratio" tabulated as a function of depth policy |
CRvSatAtContact | Class that implements "vaporized oil-gas ratio" (Rv) as function of depth and pressure as follows: |
CRvVD | Type that implements "vaporized oil-gas ratio" tabulated as a function of depth policy |
CRvwSatAtContact | Class that implements "vaporized water-gas ratio" (Rvw) as function of depth and pressure as follows: |
CRvwVD | Type that implements "vaporized water-gas ratio" tabulated as a function of depth policy |
CEquilReg | Aggregate information base of an equilibration region |
CPcEq | Functor for inverting capillary pressure function |
CPcEqSum | Functor for inverting a sum of capillary pressure functions |
►NGridDataOutput | |
CSimMeshDataAccessor | |
►NKeywordValidation | |
Callow_values | |
CKeywordValidator | |
CPartiallySupportedKeywordProperties | |
CUnsupportedKeywordProperties | |
CValidationError | |
►NMpi | |
►Ndetail | |
CPacking | Abstract struct for packing which is (partially) specialized for specific types |
CPacking< false, std::bitset< Size > > | Specialization for std::bitset |
CPacking< false, T > | Default handling for unsupported types |
CPacking< true, T > | Packaging for pod data |
CPacker | Struct handling packing of serialization for MPI communication |
►NParallel | |
CMpiSerializer | Class for serializing and broadcasting data using MPI |
►NProperties | |
►NTTag | |
CAluGridVanguard | |
CCpGridVanguard | |
CEclTimeSteppingParameters | |
CFlowBaseProblem | |
CFlowBaseVanguard | |
CFlowEarlyBird | |
CFlowIstlSolver | |
CFlowIstlSolverParams | |
CFlowModelParameters | |
CFlowNonLinearSolver | |
CFlowProblem | |
CFlowTimeSteppingParameters | |
COutputBlackOil | |
CPolyhedralGridVanguard | |
CVtkTracer | |
CAcceleratorMode | |
CAcceleratorMode< TypeTag, TTag::FlowIstlSolverParams > | |
CAllowDistributedWells | |
CAllowDistributedWells< TypeTag, TTag::FlowBaseVanguard > | |
CAlternativeWellRateInit | |
CAlternativeWellRateInit< TypeTag, TTag::FlowModelParameters > | |
CAquiferModel | |
CAquiferModel< TypeTag, TTag::FlowBaseProblem > | |
CAquiferModel< TypeTag, TTag::FlowProblem > | |
CBaseDiscretizationType< TypeTag, TTag::FlowBaseProblem > | |
CBdaDeviceId | |
CBdaDeviceId< TypeTag, TTag::FlowIstlSolverParams > | |
CBlackoilConserveSurfaceVolume< TypeTag, TTag::FlowProblem > | |
CCprReuseInterval | |
CCprReuseInterval< TypeTag, TTag::FlowIstlSolverParams > | |
CCprReuseSetup | |
CCprReuseSetup< TypeTag, TTag::FlowIstlSolverParams > | |
CDamarisDaskFile | |
CDamarisDedicatedCores | |
CDamarisDedicatedNodes | |
CDamarisLogLevel | |
CDamarisOutputHdfCollective | |
CDamarisPythonParaviewScript | |
CDamarisPythonScript | |
CDamarisSaveMeshToHdf | |
CDamarisSaveToHdf | |
CDamarisSharedMemoryName | |
CDamarisSharedMemorySizeBytes | |
CDamarisSimName | |
CDbhpMaxRel | |
CDbhpMaxRel< TypeTag, TTag::FlowModelParameters > | |
CDebugEmitCellPartition | |
CDebugEmitCellPartition< TypeTag, TTag::FlowModelParameters > | |
CDiscreteFunction< TypeTag, TTag::FlowBaseProblem > | |
CDwellFractionMax | |
CDwellFractionMax< TypeTag, TTag::FlowModelParameters > | |
CEclDeckFileName | |
CEclDeckFileName< TypeTag, TTag::FlowBaseVanguard > | |
CEclOutputDoublePrecision | |
CEclOutputDoublePrecision< TypeTag, TTag::FlowBaseProblem > | |
CEclOutputInterval | |
CEclOutputInterval< TypeTag, TTag::FlowBaseVanguard > | |
CEdgeWeightsMethod | |
CEdgeWeightsMethod< TypeTag, TTag::FlowBaseVanguard > | |
CEnableAdaptiveTimeStepping | |
CEnableAdaptiveTimeStepping< TypeTag, TTag::FlowProblem > | |
CEnableApiTracking | |
CEnableApiTracking< TypeTag, TTag::FlowBaseProblem > | |
CEnableAsyncEclOutput | |
CEnableAsyncEclOutput< TypeTag, TTag::FlowBaseProblem > | |
CEnableBrine< TypeTag, TTag::FlowProblem > | |
CEnableDamarisOutput | |
CEnableDebuggingChecks | |
CEnableDebuggingChecks< TypeTag, TTag::FlowBaseProblem > | |
CEnableDebuggingChecks< TypeTag, TTag::FlowProblem > | |
CEnableDiffusion< TypeTag, TTag::FlowBaseProblem > | |
CEnableDispersion< TypeTag, TTag::FlowBaseProblem > | |
CEnableDispersion< TypeTag, TTag::FlowProblem > | |
CEnableDriftCompensation | |
CEnableDriftCompensation< TypeTag, TTag::FlowBaseProblem > | |
CEnableDryRun | |
CEnableDryRun< TypeTag, TTag::FlowProblem > | |
CEnableEclOutput | |
CEnableEclOutput< TypeTag, TTag::FlowBaseProblem > | |
CEnableEnergy< TypeTag, TTag::FlowBaseProblem > | |
CEnableEnergy< TypeTag, TTag::FlowProblem > | |
CEnableEsmry | |
CEnableEsmry< TypeTag, TTag::FlowBaseProblem > | |
CEnableExperiments< TypeTag, TTag::FlowBaseProblem > | |
CEnableExtbo< TypeTag, TTag::FlowBaseProblem > | |
CEnableFoam< TypeTag, TTag::FlowBaseProblem > | |
CEnableFoam< TypeTag, TTag::FlowProblem > | |
CEnableGravity< TypeTag, TTag::FlowBaseProblem > | |
CEnableIntensiveQuantityCache< TypeTag, TTag::FlowBaseProblem > | |
CEnableLoggingFalloutWarning | |
CEnableLoggingFalloutWarning< TypeTag, TTag::FlowProblem > | |
CEnableMech< TypeTag, TTag::FlowBaseProblem > | |
CEnableMICP< TypeTag, TTag::FlowBaseProblem > | |
CEnableMICP< TypeTag, TTag::FlowProblem > | |
CEnableOpmRstFile | |
CEnableOpmRstFile< TypeTag, TTag::FlowBaseVanguard > | |
CEnablePolymer< TypeTag, TTag::FlowBaseProblem > | |
CEnablePolymer< TypeTag, TTag::FlowProblem > | |
CEnableSaltPrecipitation< TypeTag, TTag::FlowProblem > | |
CEnableSolvent< TypeTag, TTag::FlowBaseProblem > | |
CEnableSolvent< TypeTag, TTag::FlowProblem > | |
CEnableStorageCache< TypeTag, TTag::FlowBaseProblem > | |
CEnableTemperature< TypeTag, TTag::FlowBaseProblem > | |
CEnableTemperature< TypeTag, TTag::FlowProblem > | |
CEnableTerminalOutput | |
CEnableTerminalOutput< TypeTag, TTag::FlowProblem > | |
CEnableThermalFluxBoundaries | |
CEnableThermalFluxBoundaries< TypeTag, TTag::FlowBaseProblem > | |
CEnableTracerModel | |
CEnableTuning | |
CEnableTuning< TypeTag, TTag::EclTimeSteppingParameters > | |
CEnableVtkOutput< TypeTag, TTag::FlowBaseProblem > | |
CEnableWellOperabilityCheck | |
CEnableWellOperabilityCheck< TypeTag, TTag::FlowModelParameters > | |
CEnableWellOperabilityCheckIter | |
CEnableWellOperabilityCheckIter< TypeTag, TTag::FlowModelParameters > | |
CEnableWriteAllSolutions | |
CEnableWriteAllSolutions< TypeTag, TTag::FlowBaseProblem > | |
CEndTime< TypeTag, TTag::FlowBaseProblem > | |
CEquilGrid | |
CEquilGrid< TypeTag, TTag::AluGridVanguard > | |
CEquilGrid< TypeTag, TTag::CpGridVanguard > | |
CEquilGrid< TypeTag, TTag::PolyhedralGridVanguard > | |
CExplicitRockCompaction | |
CExplicitRockCompaction< TypeTag, TTag::FlowBaseProblem > | |
CExternalPartition | |
CExternalPartition< TypeTag, TTag::FlowBaseVanguard > | |
CFluxModule< TypeTag, TTag::FlowBaseProblem > | |
CForceDisableFluidInPlaceOutput | |
CForceDisableFluidInPlaceOutput< TypeTag, TTag::OutputBlackOil > | |
CForceDisableResvFluidInPlaceOutput | |
CForceDisableResvFluidInPlaceOutput< TypeTag, TTag::OutputBlackOil > | |
CFullTimeStepInitially | |
CFullTimeStepInitially< TypeTag, TTag::FlowTimeSteppingParameters > | |
CGradientCalculator< TypeTag, TTag::FlowBaseProblem > | |
CGrid< TypeTag, TTag::AluGridVanguard > | |
CGrid< TypeTag, TTag::CpGridVanguard > | |
CGrid< TypeTag, TTag::PolyhedralGridVanguard > | |
CGridView< TypeTag, TTag::FlowBaseProblem > | |
CIgnoreKeywords | |
CIgnoreKeywords< TypeTag, TTag::FlowBaseVanguard > | |
CIluFillinLevel | |
CIluFillinLevel< TypeTag, TTag::FlowIstlSolverParams > | |
CIluRedblack | |
CIluRedblack< TypeTag, TTag::FlowIstlSolverParams > | |
CIluRelaxation | |
CIluRelaxation< TypeTag, TTag::FlowIstlSolverParams > | |
CIluReorderSpheres | |
CIluReorderSpheres< TypeTag, TTag::FlowIstlSolverParams > | |
CInitialTimeStepInDays | |
CInitialTimeStepInDays< TypeTag, TTag::FlowTimeSteppingParameters > | |
CInitialTimeStepSize< TypeTag, TTag::FlowBaseProblem > | |
CLinearSolver | |
CLinearSolver< TypeTag, TTag::FlowIstlSolverParams > | |
CLinearSolverBackend< TypeTag, TTag::FlowIstlSolverParams > | |
CLinearSolverIgnoreConvergenceFailure | |
CLinearSolverIgnoreConvergenceFailure< TypeTag, TTag::FlowIstlSolverParams > | |
CLinearSolverMaxIter | |
CLinearSolverMaxIter< TypeTag, TTag::FlowIstlSolverParams > | |
CLinearSolverPrintJsonDefinition | |
CLinearSolverPrintJsonDefinition< TypeTag, TTag::FlowIstlSolverParams > | |
CLinearSolverReduction | |
CLinearSolverReduction< TypeTag, TTag::FlowIstlSolverParams > | |
CLinearSolverRestart | |
CLinearSolverRestart< TypeTag, TTag::FlowIstlSolverParams > | |
CLinearSolverSplice< TypeTag, TTag::FlowProblem > | |
CLinearSolverVerbosity< TypeTag, TTag::FlowIstlSolverParams > | |
CLoadFile | |
CLoadFile< TypeTag, TTag::FlowProblem > | |
CLoadStep | |
CLoadStep< TypeTag, TTag::FlowProblem > | |
CLocalDomainsOrderingMeasure | |
CLocalDomainsOrderingMeasure< TypeTag, TTag::FlowModelParameters > | |
CLocalDomainsPartitioningImbalance | |
CLocalDomainsPartitioningImbalance< TypeTag, TTag::FlowModelParameters > | |
CLocalDomainsPartitioningMethod | |
CLocalDomainsPartitioningMethod< TypeTag, TTag::FlowModelParameters > | |
CLocalLinearizerSplice< TypeTag, TTag::FlowBaseProblem > | |
CLocalSolveApproach | |
CLocalSolveApproach< TypeTag, TTag::FlowModelParameters > | |
CLocalToleranceScalingCnv | |
CLocalToleranceScalingCnv< TypeTag, TTag::FlowModelParameters > | |
CLocalToleranceScalingMb | |
CLocalToleranceScalingMb< TypeTag, TTag::FlowModelParameters > | |
CLocalWellSolveControlSwitching | |
CLocalWellSolveControlSwitching< TypeTag, TTag::FlowModelParameters > | |
CMaterialLaw< TypeTag, TTag::FlowBaseProblem > | |
CMatrixAddWellContributions | |
CMatrixAddWellContributions< TypeTag, TTag::FlowModelParameters > | |
CMaximumNumberOfWellSwitches | |
CMaximumNumberOfWellSwitches< TypeTag, TTag::FlowModelParameters > | |
CMaxInnerIterMsWells | |
CMaxInnerIterMsWells< TypeTag, TTag::FlowModelParameters > | |
CMaxInnerIterWells | |
CMaxInnerIterWells< TypeTag, TTag::FlowModelParameters > | |
CMaxLocalSolveIterations | |
CMaxLocalSolveIterations< TypeTag, TTag::FlowModelParameters > | |
CMaxNewtonIterationsWithInnerWellIterations | |
CMaxNewtonIterationsWithInnerWellIterations< TypeTag, TTag::FlowModelParameters > | |
CMaxPressureChangeMsWells | |
CMaxPressureChangeMsWells< TypeTag, TTag::FlowModelParameters > | |
CMaxResidualAllowed | |
CMaxResidualAllowed< TypeTag, TTag::FlowModelParameters > | |
CMaxSinglePrecisionDays | |
CMaxSinglePrecisionDays< TypeTag, TTag::FlowModelParameters > | |
CMaxWelleqIter | |
CMaxWelleqIter< TypeTag, TTag::FlowModelParameters > | |
CMiluVariant | |
CMiluVariant< TypeTag, TTag::FlowIstlSolverParams > | |
CMinStrictCnvIter | |
CMinStrictCnvIter< TypeTag, TTag::FlowModelParameters > | |
CMinStrictMbIter | |
CMinStrictMbIter< TypeTag, TTag::FlowModelParameters > | |
CMinTimeStepBasedOnNewtonIterations | |
CMinTimeStepBasedOnNewtonIterations< TypeTag, TTag::FlowTimeSteppingParameters > | |
CMinTimeStepBeforeShuttingProblematicWellsInDays | |
CMinTimeStepBeforeShuttingProblematicWellsInDays< TypeTag, TTag::FlowTimeSteppingParameters > | |
CModel< TypeTag, TTag::FlowBaseProblem > | |
CNetworkMaxIterations | |
CNetworkMaxIterations< TypeTag, TTag::FlowModelParameters > | |
CNetworkMaxStrictIterations | |
CNetworkMaxStrictIterations< TypeTag, TTag::FlowModelParameters > | |
CNewtonMaxIterations< TypeTag, TTag::FlowNonLinearSolver > | |
CNewtonMaxRelax | |
CNewtonMaxRelax< TypeTag, TTag::FlowNonLinearSolver > | |
CNewtonMinIterations | |
CNewtonMinIterations< TypeTag, TTag::FlowNonLinearSolver > | |
CNewtonRelaxationType | |
CNewtonRelaxationType< TypeTag, TTag::FlowNonLinearSolver > | |
CNewtonTolerance< TypeTag, TTag::FlowBaseProblem > | |
CNlddNumInitialNewtonIter | |
CNlddNumInitialNewtonIter< TypeTag, TTag::FlowModelParameters > | |
CNonlinearSolver | |
CNonlinearSolver< TypeTag, TTag::FlowModelParameters > | |
CNumLocalDomains | |
CNumLocalDomains< TypeTag, TTag::FlowModelParameters > | |
CNumPressurePointsEquil | |
CNumPressurePointsEquil< TypeTag, TTag::FlowBaseProblem > | |
COpenclIluParallel | |
COpenclIluParallel< TypeTag, TTag::FlowIstlSolverParams > | |
COpenclPlatformId | |
COpenclPlatformId< TypeTag, TTag::FlowIstlSolverParams > | |
COutputDir< TypeTag, TTag::FlowBaseProblem > | |
COutputDir< TypeTag, TTag::FlowProblem > | |
COutputExtraConvergenceInfo | |
COutputExtraConvergenceInfo< TypeTag, TTag::FlowProblem > | |
COutputInterval | |
COutputInterval< TypeTag, TTag::FlowProblem > | |
COutputMode | |
COutputMode< TypeTag, TTag::FlowBaseProblem > | |
COwnerCellsFirst | |
COwnerCellsFirst< TypeTag, TTag::FlowBaseVanguard > | |
CParsingStrictness | |
CParsingStrictness< TypeTag, TTag::FlowBaseVanguard > | |
CProblem< TypeTag, TTag::FlowBaseProblem > | |
CRegularizationFactorWells | |
CRegularizationFactorWells< TypeTag, TTag::FlowModelParameters > | |
CRelaxedLinearSolverReduction | |
CRelaxedLinearSolverReduction< TypeTag, TTag::FlowIstlSolverParams > | |
CRelaxedMaxPvFraction | |
CRelaxedMaxPvFraction< TypeTag, TTag::FlowModelParameters > | |
CRelaxedPressureTolMsw | |
CRelaxedPressureTolMsw< TypeTag, TTag::FlowModelParameters > | |
CRelaxedWellFlowTol | |
CRelaxedWellFlowTol< TypeTag, TTag::FlowModelParameters > | |
CRestartWritingInterval | |
CRestartWritingInterval< TypeTag, TTag::FlowBaseProblem > | |
CSaveFile | |
CSaveFile< TypeTag, TTag::FlowProblem > | |
CSaveStep | |
CSaveStep< TypeTag, TTag::FlowProblem > | |
CScaleLinearSystem | |
CScaleLinearSystem< TypeTag, TTag::FlowIstlSolverParams > | |
CSchedRestart | |
CSchedRestart< TypeTag, TTag::FlowBaseVanguard > | |
CSerialPartitioning | |
CSerialPartitioning< TypeTag, TTag::FlowBaseVanguard > | |
CShutUnsolvableWells | |
CShutUnsolvableWells< TypeTag, TTag::FlowModelParameters > | |
CSolidEnergyLaw< TypeTag, TTag::FlowBaseProblem > | |
CSolverContinueOnConvergenceFailure | |
CSolverContinueOnConvergenceFailure< TypeTag, TTag::FlowTimeSteppingParameters > | |
CSolverGrowthFactor | |
CSolverGrowthFactor< TypeTag, TTag::EclTimeSteppingParameters > | |
CSolverMaxGrowth | |
CSolverMaxGrowth< TypeTag, TTag::EclTimeSteppingParameters > | |
CSolverMaxRestarts | |
CSolverMaxRestarts< TypeTag, TTag::FlowTimeSteppingParameters > | |
CSolverMaxTimeStepInDays | |
CSolverMaxTimeStepInDays< TypeTag, TTag::EclTimeSteppingParameters > | |
CSolverMinTimeStep | |
CSolverMinTimeStep< TypeTag, TTag::EclTimeSteppingParameters > | |
CSolverRestartFactor | |
CSolverRestartFactor< TypeTag, TTag::EclTimeSteppingParameters > | |
CSolverVerbosity | |
CSolverVerbosity< TypeTag, TTag::FlowTimeSteppingParameters > | |
CSolveWelleqInitially | |
CSolveWelleqInitially< TypeTag, TTag::FlowModelParameters > | |
CSparseMatrixAdapter< TypeTag, TTag::FlowIstlSolver > | Set the type of a global jacobian matrix for linear solvers that are based on dune-istl |
CSpatialDiscretizationSplice< TypeTag, TTag::FlowBaseProblem > | |
CStencil< TypeTag, TTag::FlowBaseProblem > | |
CStrictInnerIterWells | |
CStrictInnerIterWells< TypeTag, TTag::FlowModelParameters > | |
CStrictOuterIterWells | |
CStrictOuterIterWells< TypeTag, TTag::FlowModelParameters > | |
CThermalConductionLaw< TypeTag, TTag::FlowBaseProblem > | |
CTimeStepAfterEventInDays | |
CTimeStepAfterEventInDays< TypeTag, TTag::EclTimeSteppingParameters > | |
CTimeStepControl | |
CTimeStepControl< TypeTag, TTag::FlowTimeSteppingParameters > | |
CTimeStepControlDecayDampingFactor | |
CTimeStepControlDecayDampingFactor< TypeTag, TTag::FlowTimeSteppingParameters > | |
CTimeStepControlDecayRate | |
CTimeStepControlDecayRate< TypeTag, TTag::FlowTimeSteppingParameters > | |
CTimeStepControlFileName | |
CTimeStepControlFileName< TypeTag, TTag::FlowTimeSteppingParameters > | |
CTimeStepControlGrowthDampingFactor | |
CTimeStepControlGrowthDampingFactor< TypeTag, TTag::FlowTimeSteppingParameters > | |
CTimeStepControlGrowthRate | |
CTimeStepControlGrowthRate< TypeTag, TTag::FlowTimeSteppingParameters > | |
CTimeStepControlTargetIterations | |
CTimeStepControlTargetIterations< TypeTag, TTag::FlowTimeSteppingParameters > | |
CTimeStepControlTargetNewtonIterations | |
CTimeStepControlTargetNewtonIterations< TypeTag, TTag::FlowTimeSteppingParameters > | |
CTimeStepControlTolerance | |
CTimeStepControlTolerance< TypeTag, TTag::FlowTimeSteppingParameters > | |
CTimeStepVerbosity | |
CTimeStepVerbosity< TypeTag, TTag::FlowTimeSteppingParameters > | |
CToleranceCnv | |
CToleranceCnv< TypeTag, TTag::FlowModelParameters > | |
CToleranceCnvRelaxed | |
CToleranceCnvRelaxed< TypeTag, TTag::FlowModelParameters > | |
CToleranceMb | |
CToleranceMb< TypeTag, TTag::FlowModelParameters > | |
CToleranceMbRelaxed | |
CToleranceMbRelaxed< TypeTag, TTag::FlowModelParameters > | |
CTolerancePressureMsWells | |
CTolerancePressureMsWells< TypeTag, TTag::FlowModelParameters > | |
CToleranceWellControl | |
CToleranceWellControl< TypeTag, TTag::FlowModelParameters > | |
CToleranceWells | |
CToleranceWells< TypeTag, TTag::FlowModelParameters > | |
CUpdateEquationsScaling | |
CUpdateEquationsScaling< TypeTag, TTag::FlowModelParameters > | |
CUseAverageDensityMsWells | |
CUseAverageDensityMsWells< TypeTag, TTag::FlowModelParameters > | |
CUseGmres | |
CUseGmres< TypeTag, TTag::FlowIstlSolverParams > | |
CUseImplicitIpr | |
CUseImplicitIpr< TypeTag, TTag::FlowModelParameters > | |
CUseMultisegmentWell | |
CUseMultisegmentWell< TypeTag, TTag::FlowBaseVanguard > | |
CUseMultisegmentWell< TypeTag, TTag::FlowModelParameters > | |
CUseUpdateStabilization | |
CUseUpdateStabilization< TypeTag, TTag::FlowModelParameters > | |
CUseVolumetricResidual< TypeTag, TTag::FlowProblem > | |
CVanguard< TypeTag, TTag::AluGridVanguard > | |
CVanguard< TypeTag, TTag::CpGridVanguard > | |
CVanguard< TypeTag, TTag::PolyhedralGridVanguard > | |
CVtkWriteTracerConcentration | |
CVtkWriteTracerConcentration< TypeTag, TTag::VtkTracer > | |
CWellModel | |
CWellModel< TypeTag, TTag::FlowProblem > | |
CZoltanImbalanceTol | |
CZoltanImbalanceTol< TypeTag, TTag::FlowBaseVanguard > | |
CZoltanParams | |
CZoltanParams< TypeTag, TTag::FlowBaseVanguard > | |
►NPybind | |
CPyBlackOilSimulator | |
CPyFluidState | |
CPyMaterialState | |
►NRateConverter | |
CSurfaceToReservoirVoidage | Convert component rates at surface conditions to phase (voidage) rates at reservoir conditions |
►NRegionAttributeHelpers | |
►NSelect | Convenience tools for processing region spesific attributes |
CRegionIDParameter | |
CRegionIDParameter< RegionID, true > | |
CAverageIncrementCalculator | Computes the temperature, pressure, and counter increment |
CAverageIncrementCalculator< false > | |
►CRegionAttributes | Provide mapping from Region IDs to user-specified collection of per-region attributes |
CValue | Aggregate per-region attributes along with region's representative cell |
►NRegionAverageCalculator | |
CAverageRegionalPressure | Computes hydrocarbon weighed average pressures over regions |
►NSerialization | |
►Ndetail | |
CPacking< false, boost::gregorian::date > | |
►NWellGroupHelpers | |
CFractionCalculator | |
CInjectionTargetCalculator | Based on a group control mode, extract or calculate rates, and provide other conveniences |
CTargetCalculator | Based on a group control mode, extract or calculate rates, and provide other conveniences |
►Nwellhelpers | |
CParallelStandardWellB | A wrapper around the B matrix for distributed wells |
CActionHandler | Class handling Action support in simulator |
CAdaptiveSimulatorTimer | Simulation timer for adaptive time stepping |
CAdaptiveTimeStepping | |
CALQState | |
CAluGridVanguard | Helper class for grid instantiation of ECL file-format using problems |
CAMGHelper | |
CAMGSmootherArgsHelper | |
CAMGSmootherArgsHelper< Opm::ParallelOverlappingILU0< M, V, V, C > > | |
CAquiferAnalytical | |
CAquiferCarterTracy | |
CAquiferConstantFlux | |
CAquiferFetkovich | |
CAquiferInterface | |
CAquiferNumerical | |
CBaseAquiferModel | The base class which specifies the API of aquifer models |
CBdaBridge | BdaBridge acts as interface between opm-simulators with the BdaSolvers |
CBlackoilAquiferModel | Class for handling the blackoil aquifer model |
CBlackoilModel | A model implementation for three-phase black oil |
CBlackoilModelNldd | A NLDD implementation for three-phase black oil |
CBlackoilModelParameters | Solver parameters for the BlackoilModel |
CBlackoilPhases | |
►CBlackoilWellModel | Class for handling the blackoil well model |
CWBPCalcID | |
CBlackoilWellModelConstraints | Class for handling constraints for the blackoil well model |
►CBlackoilWellModelGeneric | Class for handling the blackoil well model |
CConnectionIndexMap | Connection index mappings |
CBlackoilWellModelGuideRates | Class for handling the guide rates in the blackoil well model |
CBlackoilWellModelRestart | Class for restarting the blackoil well model |
CCheckDistributedWellConnections | Class checking that all connections are on active cells |
CCollectDataOnIORank | |
CCommunicateAboveBelow | Class to facilitate getting values associated with the above/below perforation |
CComponentName | |
CConnFiltrateData | |
CConvergenceOutputConfiguration | Parse comma separated option strings into a runtime configuration object for whether to output additional convergence information and, if so, what information to output |
►CConvergenceOutputThread | Encapsulating object for thread processing producer's convergence output requests |
CImpl | |
►CConvergenceReport | Represents the convergence status of the whole simulator, to make it possible to query and store the reasons for convergence failures |
CReservoirConvergenceMetric | |
CReservoirFailure | |
CWellFailure | |
►CConvergenceReportQueue | Communication channel between thread creating output requests and consumer thread writing those requests to a file |
COutputRequest | Single output request |
CCopyGatherScatter | |
CCpGridVanguard | Helper class for grid instantiation of ECL file-format using problems |
CDamarisWriter | Collects necessary output values and pass them to Damaris server processes |
►CDeferredLogger | |
CMessage | |
CDistributeIndexMapping | |
CDummyGradientCalculator | This is a "dummy" gradient calculator which does not do anything |
CEcfvDiscretization | |
CEclGenericWriter | |
CEclWriter | Collects necessary output values and pass it to opm-output |
CElementIndexHandle | Communication handle to scatter the global index |
CElementIndexScatterHandle | Communication handle to scatter the global index |
CEquilInitializer | Computes the initial condition based on the EQUIL keyword from ECL |
CFIBlackOilModel | |
CFlowAluGridVanguard | |
CFlowBaseVanguard | Helper class for grid instantiation of ECL file-format using problems |
►CFlowGenericProblem | This problem simulates an input file given in the data format used by the commercial ECLiPSE simulator |
CRockParams | |
►CFlowGenericVanguard | |
CSimulationModelParams | |
CFlowLinearSolverParameters | This class carries all parameters for the NewtonIterationBlackoilInterleaved class |
CFlowMain | |
CFlowProblem | This problem simulates an input file given in the data format used by the commercial ECLiPSE simulator |
CFlowsData | Simple container for FLOWS data |
CFlowThresholdPressure | This class calculates the threshold pressure for grid faces according to the Eclipse Reference Manual |
CGasLiftCommon | |
►CGasLiftGroupInfo | |
CGroupRates | |
CGasLiftSingleWell | |
►CGasLiftSingleWellGeneric | |
CBasicRates | |
CGradInfo | |
CLimitedRates | |
COptimizeState | |
►CGasLiftStage2 | |
COptimizeState | |
CSurplusState | |
CGasLiftWellState | |
CGenericCpGridVanguard | |
CGenericOutputBlackoilModule | |
CGenericThresholdPressure | |
CGenericTracerModel | |
CGlobalCellIndex | |
CGlobalPerfContainerFactory | A factory for creating a global data representation for distributed wells |
CGlobalWellInfo | |
CGroupEconomicLimitsChecker | |
CGroupState | |
CHardcodedTimeStepControl | HardcodedTimeStepControl Input generated from summary file using the ert application: |
CHDF5File | Class handling simple output to HDF5 |
CHDF5Serializer | Class for (de-)serializing using HDF5 |
►CInterRegFlowMap | Inter-region flow accumulation maps for all region definition arrays |
CSingleRegion | Minimal representation of a single named region defintion |
►CInterRegFlowMapSingleFIP | Form CSR adjacency matrix representation of inter-region flow rate graph provided as a list of connections between regions on local MPI rank |
CCell | Minimal characteristics of a cell from a simulation grid |
CIsNumericalAquiferCell | |
CIsNumericalAquiferCell< Dune::CpGrid > | |
CISTLSolver | This class solves the fully implicit black-oil system by solving the reduced system (after eliminating well variables) as a block-structured matrix (one block for all cell variables) for a fixed number of cell variables np |
CISTLSolverBda | This class solves the fully implicit black-oil system by solving the reduced system (after eliminating well variables) as a block-structured matrix (one block for all cell variables) for a fixed number of cell variables np |
CLinearOperatorExtra | Linear operator wrapper for well model |
CLogOutputHelper | |
CLookUpCartesianData | |
CLookUpCellCentroid | |
CLookUpData | |
CMain | |
CMatrixBlock | |
CMICPSolutionContainer | Struct holding MICP extension data |
CMixingRateControls | Class handling mixing rate controls for a FlowProblem |
CMultisegmentWell | |
CMultisegmentWellAssemble | Class handling assemble of the equation system for MultisegmentWell |
CMultisegmentWellContribution | This class serves to duplicate the functionality of the MultisegmentWell A MultisegmentWell uses C, D and B and performs y -= (C^T * (D^-1 * (B*x))) B and C are matrices, with M rows and N columns, where N is the size of the matrix |
CMultisegmentWellEquationAccess | Class administering assembler access to equation system |
CMultisegmentWellEquations | |
CMultisegmentWellEval | |
CMultisegmentWellGeneric | |
CMultisegmentWellPrimaryVariables | |
CMultisegmentWellSegments | |
CNewTranBaseProblem | Provides the defaults for the parameters required by the transmissibility based volume flux calculation |
CNewTranExtensiveQuantities | Provides the ECL flux module |
CNewTranFluxModule | Specifies a flux module which uses ECL transmissibilities |
CNewTranIntensiveQuantities | Provides the intensive quantities for the ECL flux module |
►CNonlinearSolver | A nonlinear solver class suitable for general fully-implicit models, as well as pressure, transport and sequential models |
CSolverParameters | |
COutputBlackOilModule | Output module for the results black oil model writing in ECL binary format |
CPackUnPackAquiferData | |
CPackUnPackBlockData | |
CPackUnPackCellData | |
CPackUnpackFlows | |
CPackUnPackGroupAndNetworkValues | |
CPackUnpackInterRegFlows | |
CPackUnPackWBPData | |
CPackUnPackWellData | |
CPackUnPackWellTestState | |
CParallelEclipseState | Parallel frontend to the EclipseState |
CParallelFieldPropsManager | Parallel frontend to the field properties |
CParallelNLDDPartitioningZoltan | Partition connectivity graph into non-overlapping domains using the Zoltan graph partitioning software package |
►CParallelOverlappingILU0 | A two-step version of an overlapping Schwarz preconditioner using one step ILU0 as |
CCRS | |
CParallelOverlappingILU0Args | |
CParallelPAvgCalculator | Facility for deriving well-level pressure values from selected block-averaging procedures |
CParallelPAvgDynamicSourceData | Dynamic source data for block-average pressure calculations |
CParallelRestrictedOverlappingSchwarz | Block parallel preconditioner |
CParallelWBPCalculation | Parallel facility for managing the on-rank collection and global distribution of WBPn source values as well as local calculation and distributed reduction of the inferred WBPn report values |
CParallelWellInfo | Class encapsulating some information about parallel wells |
CPerfData | |
CPerforationData | Static data associated with a well perforation |
CPerforationRates | |
CPhaseUsage | |
CPIDAndIterationCountTimeStepControl | PID controller based adaptive time step control as above that also takes an target iteration into account |
CPIDTimeStepControl | PID controller based adaptive time step control as suggested in: Turek and Kuzmin |
CPolyhedralGridVanguard | Helper class for grid instantiation of ECL file-format using problems |
CPolymerSolutionContainer | Struct holding polymer extension data |
CPreconditionerFactory | This is an object factory for creating preconditioners |
CPressureBhpTransferPolicy | |
CPressureTransferPolicy | |
CPropertyTree | |
►CRegionPhasePoreVolAverage | Facility for calculating volume-weighted average function values over user-defined regions in parallel |
CCellValue | Minimal characteristics of a cell from a simulation grid |
CPhase | Compile-time disambiguation type for phases |
CRegion | Compile-time disambiguation type for regions |
CRelativeChangeInterface | RelativeChangeInterface |
CRelpermDiagnostics | This class is intend to be a relperm diagnostics, to detect wrong input of relperm table and endpoints |
CRSTConv | Class computing RPTRST CONV output |
CSegmentState | |
CSerializableSim | Abstract interface for simulator serialization ops |
CSimpleIterationCountTimeStepControl | A simple iteration count based adaptive time step control |
CSimulatorFullyImplicitBlackoil | Simulator for the blackoil model |
CSimulatorReport | |
CSimulatorReportSingle | A struct for returning timing data from a simulator to its caller |
CSimulatorSerializer | Class handling simulator serialization |
CSimulatorTimer | |
CSimulatorTimerInterface | Interface class for SimulatorTimer objects, to be improved |
CSingleWellState | |
CStandardPreconditioners | |
CStandardPreconditioners< Operator, Dune::Amg::SequentialInformation > | |
CStandardWell | |
CStandardWellAssemble | Class handling assemble of the equation system for StandardWell |
►CStandardWellConnections | |
CProperties | |
CStandardWellEquationAccess | Class administering assembler access to equation system |
CStandardWellEquations | |
CStandardWellEval | |
CStandardWellPrimaryVariables | Class holding primary variables for StandardWell |
CStepReport | |
CSubDomain | Representing a part of a grid, in a way suitable for performing local solves |
CSupportsFaceTag | |
CSupportsFaceTag< Dune::CpGrid > | |
CTimeStepControlInterface | TimeStepControlInterface |
►CTracerModel | A class which handles tracers as specified in by ECL |
CTracerBatch | |
CTransmissibility | |
CVectorVectorDataHandle | A data handle sending multiple data store in vectors attached to cells |
CVFPInjProperties | |
CVFPProdProperties | Class which linearly interpolates BHP as a function of rate, tubing head pressure, water fraction, gas fraction, and artificial lift for production VFP tables, and similarly the BHP as a function of the rate and tubing head pressure |
CVFPProperties | A thin wrapper class that holds one VFPProdProperties and one VFPInjProperties object |
CVtkTracerModule | VTK output module for the tracer model's parameters |
CWellAssemble | |
CWellBhpThpCalculator | Class for computing BHP limits |
CWellConnectionAuxiliaryModule | |
CWellConnectionAuxiliaryModuleGeneric | |
CWellConstraints | Class for computing well group constraints |
CWellContainer | |
CWellContributions | This class serves to eliminate the need to include the WellContributions into the matrix (with –matrix-add-well-contributions=true) for the cusparseSolver or openclSolver |
CWellContributionsCuda | |
CWellContributionsOCL | |
CWellContributionsRocsparse | |
►CWellConvergence | |
CTolerances | |
CWellFilterCake | Class for well calculations related to filter cakes |
CWellGroupConstraints | Class for computing well group constraints |
CWellGroupControls | Class for computing well group controls |
CWellInterface | |
CWellInterfaceFluidSystem | |
►CWellInterfaceGeneric | |
COperabilityStatus | |
CWellInterfaceIndices | |
CWellModelAsLinearOperator | |
CWellModelGhostLastMatrixAdapter | Adapter to combine a matrix and another linear operator into a combined linear operator |
CWellModelMatrixAdapter | Adapter to combine a matrix and another linear operator into a combined linear operator |
CWellProdIndexCalculator | Collect per-connection static information to enable calculating connection-level or well-level productivity index values when incorporating dynamic phase mobilities |
CWellState | The state of a set of wells, tailored for use by the fully implicit blackoil simulator |
CWellTest | Class for performing well tests |
CWGState | |
CZoltanPartitioningControl | Control parameters for on-rank subdomain partitioning using Zoltan library |
►Nrocalution | |
CBiCGStab | |
CILU | |
CLocalMatrix | |
CLocalVector | |