Scippy

SCIP

Solving Constraint Integer Programs

Detailed Description

methods and macros to use the SCIP memory management

See also
Using the memory functions of SCIP for more information

Block Memory Management Macros

#define SCIPallocBlockMemory(scip, ptr)
 
#define SCIPallocBlockMemoryArray(scip, ptr, num)
 
#define SCIPallocBlockMemorySize(scip, ptr, size)
 
#define SCIPallocClearBlockMemoryArray(scip, ptr, num)
 
#define SCIPreallocBlockMemoryArray(scip, ptr, oldnum, newnum)
 
#define SCIPreallocBlockMemorySize(scip, ptr, oldsize, newsize)
 
#define SCIPduplicateBlockMemory(scip, ptr, source)
 
#define SCIPduplicateBlockMemoryArray(scip, ptr, source, num)
 
#define SCIPensureBlockMemoryArray(scip, ptr, arraysizeptr, minsize)   ( (SCIPensureBlockMemoryArray_call((scip), (void**)(ptr), sizeof(**(ptr)), (arraysizeptr), (minsize))) )
 
#define SCIPfreeBlockMemory(scip, ptr)   BMSfreeBlockMemory(SCIPblkmem(scip), (ptr))
 
#define SCIPfreeBlockMemoryNull(scip, ptr)   BMSfreeBlockMemoryNull(SCIPblkmem(scip), (ptr))
 
#define SCIPfreeBlockMemoryArray(scip, ptr, num)   BMSfreeBlockMemoryArray(SCIPblkmem(scip), (ptr), (num))
 
#define SCIPfreeBlockMemoryArrayNull(scip, ptr, num)   BMSfreeBlockMemoryArrayNull(SCIPblkmem(scip), (ptr), (num))
 
#define SCIPfreeBlockMemorySize(scip, ptr, size)   BMSfreeBlockMemorySize(SCIPblkmem(scip), (ptr), (size))
 
#define SCIPfreeBlockMemorySizeNull(scip, ptr, size)   BMSfreeBlockMemorySizeNull(SCIPblkmem(scip), (ptr), (size))
 

Buffer Memory Management Macros

#define SCIPallocBuffer(scip, ptr)
 
#define SCIPallocBufferArray(scip, ptr, num)
 
#define SCIPallocClearBufferArray(scip, ptr, num)
 
#define SCIPreallocBufferArray(scip, ptr, num)
 
#define SCIPduplicateBuffer(scip, ptr, source)
 
#define SCIPduplicateBufferArray(scip, ptr, source, num)
 
#define SCIPfreeBuffer(scip, ptr)   BMSfreeBufferMemorySize(SCIPbuffer(scip), (ptr))
 
#define SCIPfreeBufferNull(scip, ptr)   BMSfreeBufferMemoryNull(SCIPbuffer(scip), (ptr))
 
#define SCIPfreeBufferArray(scip, ptr)   BMSfreeBufferMemoryArray(SCIPbuffer(scip), (ptr))
 
#define SCIPfreeBufferArrayNull(scip, ptr)   BMSfreeBufferMemoryArrayNull(SCIPbuffer(scip), (ptr))
 
#define SCIPallocCleanBuffer(scip, ptr)
 
#define SCIPallocCleanBufferArray(scip, ptr, num)
 
#define SCIPfreeCleanBuffer(scip, ptr)   BMSfreeBufferMemorySize(SCIPcleanbuffer(scip), (ptr))
 
#define SCIPfreeCleanBufferNull(scip, ptr)   BMSfreeBufferMemoryNull(SCIPcleanbuffer(scip), (ptr))
 
#define SCIPfreeCleanBufferArray(scip, ptr)   BMSfreeBufferMemoryArray(SCIPcleanbuffer(scip), (ptr))
 
#define SCIPfreeCleanBufferArrayNull(scip, ptr)   BMSfreeBufferMemoryArrayNull(SCIPcleanbuffer(scip), (ptr))
 

Memory Management Functions

BMS_BLKMEMSCIPblkmem (SCIP *scip)
 
BMS_BUFMEMSCIPbuffer (SCIP *scip)
 
BMS_BUFMEMSCIPcleanbuffer (SCIP *scip)
 
SCIP_Longint SCIPgetMemUsed (SCIP *scip)
 
SCIP_Longint SCIPgetMemTotal (SCIP *scip)
 
SCIP_Longint SCIPgetMemExternEstim (SCIP *scip)
 
int SCIPcalcMemGrowSize (SCIP *scip, int num)
 
SCIP_RETCODE SCIPensureBlockMemoryArray_call (SCIP *scip, void **arrayptr, size_t elemsize, int *arraysize, int minsize)
 
void SCIPprintMemoryDiagnostic (SCIP *scip)
 

Macro Definition Documentation

◆ SCIPallocBlockMemory

#define SCIPallocBlockMemory (   scip,
  ptr 
)
Value:
BMS_BLKMEM * SCIPblkmem(SCIP *scip)
Definition: scip.c:45519
#define NULL
Definition: lpi_spx1.cpp:137
#define BMSallocBlockMemory(mem, ptr)
Definition: memory.h:406

Definition at line 21890 of file scip.h.

Referenced by catchLinearVarEvents(), catchQuadVarEvents(), catchVarEventCardinality(), consdataCreate(), consdataCreateEmpty(), consdataCreateSuperindicator(), consdataEnsureVarsSize(), conshdlrdataCreate(), copyDimensions(), createAndAddAndCons(), createConstarray(), createDepthinfo(), createSolTuple(), createVararray(), ecaggrCreateEmpty(), getEventData(), includeEventHdlrSync(), initConflictgraph(), initImplGraphSOS1(), initProblem(), initTCliquegraph(), linconsupgradeFree(), mpsinputCreate(), nlrowaggrCreate(), objimplicsCreate(), parseOutputDimensioninfo(), probdataCreate(), propdataCreate(), readerdataAddOutputvar(), readerdataCreate(), SCIP_DECL_CONSCOPY(), SCIP_DECL_CONSTRANS(), SCIP_DECL_DISPINITSOL(), SCIP_DECL_HEURINIT(), SCIP_DECL_SEPAEXECLP(), SCIPcreateConcurrent(), SCIPcreateConsAbspower(), SCIPcreateConsBivariate(), SCIPcreateConsCardinality(), SCIPcreateConsLOP(), SCIPcreateConsPseudobooleanWithConss(), SCIPcreateConsSOC(), SCIPcreateConsSOS1(), SCIPcreateConsSOS2(), tsp::SCIPcreateConsSubtour(), SCIPgenVBoundAdd(), SCIPincludeBranchruleAllfullstrong(), SCIPincludeBranchruleCloud(), SCIPincludeBranchruleDistribution(), SCIPincludeBranchruleFullstrong(), SCIPincludeBranchruleInference(), SCIPincludeBranchruleMultAggr(), SCIPincludeBranchrulePscost(), SCIPincludeBranchruleRandom(), SCIPincludeBranchruleRelpscost(), SCIPincludeComprLargestrepr(), SCIPincludeComprWeakcompr(), SCIPincludeConshdlrAbspower(), SCIPincludeConshdlrBivariate(), SCIPincludeConshdlrBounddisjunction(), SCIPincludeConshdlrCardinality(), SCIPincludeConshdlrComponents(), SCIPincludeConshdlrDisjunction(), SCIPincludeConshdlrIndicator(), SCIPincludeConshdlrNonlinear(), SCIPincludeConshdlrQuadratic(), SCIPincludeConshdlrSOC(), SCIPincludeConshdlrSOS2(), SCIPincludeConshdlrSuperindicator(), SCIPincludeConshdlrViolatedCut(), SCIPincludeEventHdlrBoundwriting(), SCIPincludeEventHdlrSofttimelimit(), SCIPincludeEventHdlrSolvingphase(), SCIPincludeHeurActconsdiving(), SCIPincludeHeurBound(), SCIPincludeHeurCoefdiving(), SCIPincludeHeurCompletesol(), SCIPincludeHeurCrossover(), SCIPincludeHeurDins(), SCIPincludeHeurDualval(), SCIPincludeHeurFixandinfer(), SCIPincludeHeurFracdiving(), SCIPincludeHeurGuideddiving(), SCIPincludeHeurIndicator(), SCIPincludeHeurIntdiving(), SCIPincludeHeurLinesearchdiving(), SCIPincludeHeurLocalbranching(), SCIPincludeHeurLpface(), SCIPincludeHeurMultistart(), SCIPincludeHeurMutation(), SCIPincludeHeurObjpscostdiving(), SCIPincludeHeurOctane(), SCIPincludeHeurOfins(), SCIPincludeHeurOneopt(), SCIPincludeHeurProximity(), SCIPincludeHeurPscostdiving(), SCIPincludeHeurRandrounding(), SCIPincludeHeurRens(), SCIPincludeHeurReoptsols(), SCIPincludeHeurRins(), SCIPincludeHeurRootsoldiving(), SCIPincludeHeurRounding(), SCIPincludeHeurShiftandpropagate(), SCIPincludeHeurSimplerounding(), SCIPincludeHeurSubNlp(), SCIPincludeHeurTrySol(), SCIPincludeHeurTwoopt(), SCIPincludeHeurUndercover(), SCIPincludeHeurVbounds(), SCIPincludeHeurVeclendiving(), SCIPincludeHeurZeroobj(), SCIPincludeHeurZirounding(), SCIPincludeNodeselBfs(), SCIPincludeNodeselEstimate(), SCIPincludeNodeselHybridestim(), SCIPincludeNodeselRestartdfs(), SCIPincludeNodeselUct(), SCIPincludeNonlinconsUpgrade(), SCIPincludePresolBoundshift(), SCIPincludePresolConvertinttobin(), SCIPincludePresolDomcol(), SCIPincludePresolDualcomp(), SCIPincludePresolQPKKTref(), SCIPincludePricerBinpacking(), SCIPincludePropNlobbt(), SCIPincludePropRedcost(), SCIPincludePropVbounds(), SCIPincludeQuadconsUpgrade(), SCIPincludeReaderBnd(), SCIPincludeReaderCip(), SCIPincludeReaderLp(), SCIPincludeReaderMps(), SCIPincludeReaderPbm(), SCIPincludeReaderPpm(), SCIPincludeSepaCGMIP(), SCIPincludeSepaClique(), SCIPincludeSepaClosecuts(), SCIPincludeSepaConvexproj(), SCIPincludeSepaDisjunctive(), SCIPincludeSepaGauge(), SCIPincludeSepaGMI(), SCIPincludeSepaGomory(), SCIPincludeSepaImpliedbounds(), SCIPincludeSepaOddcycle(), SCIPincludeSepaStrongcg(), SCIPinitRepresentation(), sepadataCreate(), tcliquegraphCreate(), updateArcData(), vardataCreate(), variableGraphCreate(), ZerohalfCutDataCreate(), and ZerohalfCutDataFree().

◆ SCIPallocBlockMemoryArray

#define SCIPallocBlockMemoryArray (   scip,
  ptr,
  num 
)
Value:
( (BMSallocBlockMemoryArray(SCIPblkmem(scip), (ptr), (num)) == NULL) \
BMS_BLKMEM * SCIPblkmem(SCIP *scip)
Definition: scip.c:45519
#define NULL
Definition: lpi_spx1.cpp:137
#define BMSallocBlockMemoryArray(mem, ptr, num)
Definition: memory.h:408

Definition at line 21892 of file scip.h.

Referenced by addEdgeToAuxGraph(), addExtendedAsymmetricFormulation(), addExtendedFlowFormulation(), applyNlobbt(), branch(), branchruledataEnsureArraySize(), branchruledataEnsureNlcount(), catchLinearVarEvents(), catchVarEvents(), checkFactorable(), collectNondefaultParams(), componentSetupWorkingSol(), computeED(), computeInteriorPoint(), consdataAddExprtrees(), consdataCollectLinkingCons(), consdataCreate(), consdataCreateBinvars(), conshdlrdataCreate(), constructCompression(), correctLocksAndCaptures(), createAndSplitProblem(), createCapacityRestriction(), createCoverCutsTimepoint(), createDepthinfo(), createPresoldata(), createRelaxation(), createSolTuple(), createStartingData(), createSubSCIP(), createSubscip(), createZerohalfCutFromZerohalfWeightvector(), ecaggrCreateEmpty(), ensureConstarrySizeFznInput(), ensureDepthInfoArraySize(), ensureVararrySize(), ensureVararrySizeFznInput(), fillVariableGraph(), getEventData(), getZerohalfWeightvectorFromSelectedRowsBitarray(), initConcsolver(), initData(), initializeCandsLists(), initProblem(), initPropdata(), innerPresolve(), LOPreadFile(), nlrowaggrCreate(), nlrowaggrStoreLinearTerms(), nlrowaggrStoreQuadraticVars(), objimplicsCreate(), parseOutputDimensioninfo(), preprocess(), process(), propdataInit(), readCoefficients(), SCIP_DECL_BRANCHEXECLP(), SCIP_DECL_CONSINIT(), SCIP_DECL_CONSINITSOL(), SCIP_DECL_CONSTRANS(), SCIP_DECL_EVENTEXEC(), SCIP_DECL_HEURINITSOL(), SCIP_DECL_READERREAD(), SCIP_DECL_READERWRITE(), SCIP_DECL_SOLVECUMULATIVE(), SCIPapplyHeurDualval(), SCIPapplyProximity(), SCIPcreateConsCardinality(), SCIPcreateConsLOP(), SCIPcreateConsSOC(), SCIPreadDiff(), SCIPreadLp(), SCIPreadPip(), SCIPsyncstoreInit(), SCIPwriteLp(), searchEcAggr(), sepadataAddNlrowaggr(), separateByAuxGraph(), setUpEvents(), sortGenVBounds(), storeNonlinearConvexNlrows(), and tcliquegraphCreate().

◆ SCIPallocBlockMemorySize

#define SCIPallocBlockMemorySize (   scip,
  ptr,
  size 
)
Value:
( (BMSallocBlockMemorySize(SCIPblkmem(scip), (ptr), (size)) == NULL) \
BMS_BLKMEM * SCIPblkmem(SCIP *scip)
Definition: scip.c:45519
#define NULL
Definition: lpi_spx1.cpp:137
#define BMSallocBlockMemorySize(mem, ptr, size)
Definition: memory.h:407

Definition at line 21894 of file scip.h.

◆ SCIPallocClearBlockMemoryArray

#define SCIPallocClearBlockMemoryArray (   scip,
  ptr,
  num 
)
Value:
BMS_BLKMEM * SCIPblkmem(SCIP *scip)
Definition: scip.c:45519
#define BMSallocClearBlockMemoryArray(mem, ptr, num)
Definition: memory.h:409
#define NULL
Definition: lpi_spx1.cpp:137

Definition at line 21896 of file scip.h.

Referenced by computeED(), computeGauge(), computeInteriorPoint(), consdataCreate(), SCIPboundstoreCreate(), and variableGraphCreate().

◆ SCIPreallocBlockMemoryArray

#define SCIPreallocBlockMemoryArray (   scip,
  ptr,
  oldnum,
  newnum 
)
Value:
( (BMSreallocBlockMemoryArray(SCIPblkmem(scip), (ptr), (oldnum), (newnum)) == NULL) \
BMS_BLKMEM * SCIPblkmem(SCIP *scip)
Definition: scip.c:45519
#define NULL
Definition: lpi_spx1.cpp:137
#define BMSreallocBlockMemoryArray(mem, ptr, oldnum, newnum)
Definition: memory.h:412

Definition at line 21898 of file scip.h.

Referenced by addCoef(), addNewGenVBound(), addNodesInformation(), branchruledataEnsureArraySize(), branchruledataEnsureNlcount(), checkMemSize(), collectAggregatedVars(), collectNondefaultParams(), consdataAddExprtrees(), consdataEnsureAddLinConsSize(), consdataEnsureAdjBilinSize(), consdataEnsureBilinSize(), consdataEnsureLinearVarsSize(), consdataEnsureQuadVarTermsSize(), consdataEnsureVarsSize(), consdataEnsurevarsSizeCardinality(), consdataEnsurevarsSizeSOS1(), consdataEnsurevarsSizeSOS2(), correctPresoldata(), createCapacityRestriction(), createCoverCutsTimepoint(), determineVariableFixings(), ensureConstarrySizeFznInput(), ensureDepthInfoArraySize(), ensureVararrySize(), ensureVararrySizeFznInput(), fillGlobalStartingData(), fillVariableGraph(), getInferInt(), innerPresolve(), parseOutputDimensioninfo(), presolveRemoveFixedVariables(), readCoefficients(), SCIPgenVBoundAdd(), SCIPincludeNonlinconsUpgrade(), SCIPincludeQuadconsUpgrade(), SCIPprobdataAddVar(), SCIPpropSyncAddBndchg(), SCIPseparateRelaxedKnapsack(), sepadataAddNlrowaggr(), and setUpEvents().

◆ SCIPreallocBlockMemorySize

#define SCIPreallocBlockMemorySize (   scip,
  ptr,
  oldsize,
  newsize 
)
Value:
( (BMSreallocBlockMemorySize(SCIPblkmem(scip), (ptr), (oldsize), (newsize)) == NULL) \
BMS_BLKMEM * SCIPblkmem(SCIP *scip)
Definition: scip.c:45519
#define NULL
Definition: lpi_spx1.cpp:137
#define BMSreallocBlockMemorySize(mem, ptr, oldsize, newsize)
Definition: memory.h:410

Definition at line 21900 of file scip.h.

◆ SCIPduplicateBlockMemory

#define SCIPduplicateBlockMemory (   scip,
  ptr,
  source 
)
Value:
( (BMSduplicateBlockMemory(SCIPblkmem(scip), (ptr), (source)) == NULL) \
BMS_BLKMEM * SCIPblkmem(SCIP *scip)
Definition: scip.c:45519
#define BMSduplicateBlockMemory(mem, ptr, source)
Definition: memory.h:414
#define NULL
Definition: lpi_spx1.cpp:137

Definition at line 21902 of file scip.h.

Referenced by SCIP_DECL_CONSTRANS().

◆ SCIPduplicateBlockMemoryArray

◆ SCIPensureBlockMemoryArray

#define SCIPensureBlockMemoryArray (   scip,
  ptr,
  arraysizeptr,
  minsize 
)    ( (SCIPensureBlockMemoryArray_call((scip), (void**)(ptr), sizeof(**(ptr)), (arraysizeptr), (minsize))) )

◆ SCIPfreeBlockMemory

◆ SCIPfreeBlockMemoryNull

#define SCIPfreeBlockMemoryNull (   scip,
  ptr 
)    BMSfreeBlockMemoryNull(SCIPblkmem(scip), (ptr))

Definition at line 21908 of file scip.h.

Referenced by SCIP_DECL_HEURFREE().

◆ SCIPfreeBlockMemoryArray

#define SCIPfreeBlockMemoryArray (   scip,
  ptr,
  num 
)    BMSfreeBlockMemoryArray(SCIPblkmem(scip), (ptr), (num))

Definition at line 21909 of file scip.h.

Referenced by branchruledataFreeArrays(), checkFactorable(), cleanupHashDatas(), consdataFree(), consdataFreeRows(), consdataSetExprtrees(), consDropAllEvents(), conshdlrdataFree(), constructCompression(), correctLocksAndCaptures(), correctPresoldata(), createAndAddAndCons(), createConstraints(), createPresoldata(), deleteSubproblem(), dropVarEvents(), ecaggrFree(), freeAllEventData(), freeComponent(), freeComponentsData(), freeConstarray(), freeDepthinfo(), freeEventData(), freeGenVBound(), freeMemory(), freeProblem(), freeStartingData(), freeSubSCIP(), freeSubscip(), freeVararray(), getZerohalfWeightvectorFromSelectedRowsBitarray(), innerPresolve(), nlrowaggrFree(), preprocessTrivialZerohalfCuts(), presolveDisaggregate(), probdataFree(), propdataClear(), SCIP_DECL_BRANCHEXITSOL(), SCIP_DECL_COMPREXIT(), SCIP_DECL_CONCSOLVERDESTROYINST(), SCIP_DECL_CONSDELETE(), SCIP_DECL_EVENTEXEC(), SCIP_DECL_EVENTEXITSOL(), SCIP_DECL_HEUREXEC(), SCIP_DECL_HEUREXIT(), SCIP_DECL_HEUREXITSOL(), SCIP_DECL_PROPEXITSOL(), SCIP_DECL_READERREAD(), SCIP_DECL_READERWRITE(), SCIP_DECL_SEPAEXITSOL(), SCIP_DECL_SEPAFREE(), SCIP_DECL_SOLVECUMULATIVE(), SCIPapplyHeurDualval(), SCIPboundstoreFree(), SCIPcreateConsPseudobooleanWithConss(), SCIPfreeConcurrent(), SCIPgenVBoundAdd(), SCIPheurPassIndicator(), SCIPreadDiff(), SCIPreadLp(), SCIPreadPip(), SCIPsyncstoreExit(), SCIPwriteLp(), searchEcAggr(), sepadataClear(), sepadataFreeNlrows(), separateByAuxGraph(), separateByEnumerationHeuristics(), separateBySolvingAuxIP(), subscipdataFreeSubscip(), tcliquegraphFree(), vardataDelete(), and ZerohalfAuxGraphFree().

◆ SCIPfreeBlockMemoryArrayNull

◆ SCIPfreeBlockMemorySize

#define SCIPfreeBlockMemorySize (   scip,
  ptr,
  size 
)    BMSfreeBlockMemorySize(SCIPblkmem(scip), (ptr), (size))

Definition at line 21911 of file scip.h.

◆ SCIPfreeBlockMemorySizeNull

#define SCIPfreeBlockMemorySizeNull (   scip,
  ptr,
  size 
)    BMSfreeBlockMemorySizeNull(SCIPblkmem(scip), (ptr), (size))

Definition at line 21912 of file scip.h.

◆ SCIPallocBuffer

#define SCIPallocBuffer (   scip,
  ptr 
)

◆ SCIPallocBufferArray

#define SCIPallocBufferArray (   scip,
  ptr,
  num 
)
Value:
BMS_BUFMEM * SCIPbuffer(SCIP *scip)
Definition: scip.c:45534
#define BMSallocBufferMemoryArray(mem, ptr, num)
Definition: memory.h:675
#define NULL
Definition: lpi_spx1.cpp:137

Definition at line 21925 of file scip.h.

Referenced by addAltLPColumn(), addAltLPConstraint(), addAltLPRow(), addBranchingComplementaritiesSOS1(), addCliqueDataEntry(), addCliques(), addConcaveEstimatorMultivariate(), addConsToOccurList(), addConstraint(), addCut(), addFixedVarsConss(), addGenVBound(), addIntervalGradientEstimator(), addKnapsackConstraints(), addLinearization(), addLocalBranchingConstraint(), addLogicOrConstraints(), addObjcut(), addSetppcConstraints(), addSplitcons(), addUserEstimator(), aggregation(), analyzeEnergyRequirement(), applyAlternativeBoundsFixing(), applyCompletesol(), applyFixings(), applyHeur(), applyOfins(), applyProbing(), applyRepair(), applyVariableAssignment(), applyVbounds(), branchBalancedCardinality(), calcTwoRowBnds(), changePartitionCovervars(), changePartitionFeasiblesetvars(), checkConComponentsVarbound(), checkConsnames(), checkCumulativeCondition(), checkCurvature(), checkFactorable(), checkLPBoundsClean(), checkOrigPbCons(), checkOverloadViaThetaTree(), checkSolution(), checkSystemGF2(), checkVarnames(), chgLhs(), chgRhs(), cleanCycle(), cleanupNetwork(), cliquePresolve(), collectBinaryVars(), collectCliqueData(), computeAndConstraintInfos(), computeCut(), computeFixingOrder(), computeGradient(), computeInteriorPoint(), computeMinDistance(), computePeak(), computeReferencePointProjection(), computeVarsCoverSOS1(), computeViolation(), computeViolations(), consCapacityConstraintsFinder(), consCheckRedundancy(), consdataCreate(), consdataLinearize(), consdataPrint(), consdataSortBilinTerms(), consdataSortQuadVarTerms(), constructCompression(), constructSNFRelaxation(), copyConsPseudoboolean(), copyCuts(), copySol(), correctConshdlrdata(), CREATE_CONSTRAINT(), createAndAddLinearCons(), createCapacityRestrictionIntvars(), createCGCuts(), createConflict(), createConstraints(), createCoverCuts(), createCoverCutsTimepoint(), createCoveringProblem(), createCumulativeCons(), createDisjuctiveCons(), createLinking(), createLP(), createMIP(), createNewSol(), createNewSols(), createNlRow(), createNormalizedKnapsack(), createNormalizedLogicor(), createNormalizedSetppc(), createPresoldata(), createRows(), createSelectedSortedEventpointsSol(), createSubscip(), createTcliqueGraph(), createZerohalfCutFromZerohalfWeightvector(), cutGenerationHeuristic(), CUTOFF_CONSTRAINT(), deleteRedundantVars(), detectParallelCols(), detectRedundantVars(), determineVariableFixings(), disaggregate(), dualBoundStrengthening(), dualPresolve(), enforceConflictgraph(), enforceCuts(), ensureFactorsSize(), ensureMonomialsSize(), Exec(), execRelpscost(), extendToCover(), extensionOperatorSOS1(), extractCapacityRows(), extractFlow(), extractGates(), extractNodes(), fillDigraph(), fillVariableGraph(), findAggregation(), findAndStoreEcAggregations(), findComponents(), findCumulativeConss(), findPrecedenceConss(), findUnblockedShortestPathToRoot(), findUncapacitatedArcs(), findVarAggrRedVbcons(), fixAltLPVariables(), fixAndPropagate(), forbidCover(), forbidFixation(), generateAverageRay(), generateBoundInequalityFromSOS1Cons(), generateBoundInequalityFromSOS1Nodes(), generateClusterCuts(), generateCut(), generateCutLTI(), generateCutPoint(), generateCutProjectedPoint(), generateCutSol(), generateCutUnboundedLP(), generateOddCycleCut(), generateRowCardinality(), generateSparseCut(), getBoundConsFromVertices(), getBranchingDecisionStrongbranchSOS1(), getCover(), getFeasibleSet(), getFixedVariable(), getFlowCover(), getGradientMaxElement(), getHighestCapacityUsage(), getLiftingSequence(), getLiftingSequenceGUB(), getLinearCoeffs(), getLinVarsAndAndRess(), getMaxactImplicObjchg(), getNodeIdx(), getNodeSimilarityScore(), getVariableIndex(), GUBsetCalcCliquePartition(), handleLinearCons(), heurdataEnsureArraySize(), identifyComponent(), identifySourcesTargets(), improvePoint(), inferboundsEdgeFinding(), initConcsolver(), initConflictgraph(), initGraph(), initializeCandsLists(), initializeMatrix(), initImplGraphSOS1(), initMatrix(), initPricing(), insertSortedRootNeighbors(), isCandidate(), labelSortStable(), liftOddCycleCut(), loadTcliquegraph(), makeCoverMinimal(), makeSOS1conflictgraphFeasible(), maxWeightIndSetHeuristic(), mcfnetworkExtract(), mcfnetworkFill(), mergeAndCleanBilinearTerms(), mergeMultiples(), multiAggregateBinvar(), nlrowaggrCreate(), nodepairqueueCreate(), nodepartitionCreate(), nodepartitionIsConnected(), optimize(), parseAggregation(), parseConstantArray(), parseConstantArrayAssignment(), parseLinking(), parseQuadratic(), parseSolveItem(), parseVariableArray(), parseVariableArrayAssignment(), performRelaxSimpleRounding(), preprocessCliques(), preprocessColumns(), preprocessRows(), preprocessTrivialZerohalfCuts(), presolRoundCardinality(), presolRoundConssSOS1(), presolRoundVarsSOS1(), presolveAddKKTAggregatedVars(), presolveAddKKTKnapsackConss(), presolveAddKKTLogicorConss(), presolveAddKKTSetppcConss(), presolveAddKKTVarboundConss(), presolveConsEffectiveHorizon(), presolveConsEst(), presolveConsLct(), presolveCreateBenTalNemirovskiApproxDim3(), presolveCreateGlineurApproxDim3(), presolveDisaggregate(), presolveRemoveFixedVariables(), presolveTryAddAND(), presolveUpgrade(), printActiveVariables(), printAggregatedCons(), printAndCons(), printDualSol(), printLinearCons(), printNonLinearCons(), printNonlinearCons(), printPseudobooleanCons(), printQuadraticCons(), propagateAllConss(), propagateBounds(), propagateBoundsCons(), propagateCons(), propagateTTEF(), propIndicator(), readBounds(), readCnf(), readCoefficients(), readConstraints(), readExpression(), readIndicators(), readLinearCoefs(), readNonlinearExprs(), readObjective(), readOPBFile(), readPolynomial(), readQCMatrix(), readQMatrix(), readVariables(), reformulate(), removeBilinearTermsPos(), removeConstraintsDueToNegCliques(), removeDoubleAndSingletonsAndPerformDualpresolve(), removeFixedNonlinearVariables(), removeRedundantConss(), removeRedundantConssAndNonzeros(), resolvePropagationCoretimes(), scaleFirstRow(), SCIP_DECL_BRANCHEXECLP(), SCIP_DECL_CONCSOLVERCOPYSOLVINGDATA(), SCIP_DECL_CONCSOLVERCREATEINST(), SCIP_DECL_CONFLICTEXEC(), SCIP_DECL_CONSCHECK(), SCIP_DECL_CONSCOPY(), SCIP_DECL_CONSEXIT(), SCIP_DECL_CONSEXITPRE(), SCIP_DECL_CONSGETNVARS(), SCIP_DECL_CONSGETVARS(), SCIP_DECL_CONSINITLP(), SCIP_DECL_CONSINITPRE(), SCIP_DECL_CONSINITSOL(), SCIP_DECL_CONSPARSE(), SCIP_DECL_CONSPRESOL(), SCIP_DECL_CONSPRINT(), SCIP_DECL_CONSPROP(), SCIP_DECL_CONSTRANS(), SCIP_DECL_DIALOGEXEC(), SCIP_DECL_EXPRGRAPHNODEREFORM(), SCIP_DECL_HEUREXEC(), SCIP_DECL_LINCONSUPGD(), SCIP_DECL_PARAMCHGD(), SCIP_DECL_PRESOLEXEC(), SCIP_DECL_PRICERREDCOST(), SCIP_DECL_QUADCONSUPGD(), SCIP_DECL_READERREAD(), SCIP_DECL_READERWRITE(), SCIP_DECL_SEPAEXECLP(), SCIP_DECL_SEPAEXECSOL(), SCIP_DECL_SOLVECUMULATIVE(), SCIPaddCoefLinear(), SCIPaddNlpiProbRows(), SCIPaddToNlpiProblemQuadratic(), SCIPaddToNlpiProblemSOC(), SCIPapplyHeurDualval(), SCIPapplyRens(), SCIPapplyUndercover(), SCIPapplyZeroobj(), SCIPcomputeConvexEnvelopeFacet(), SCIPcomputeCoverUndercover(), SCIPcomputeLPRelIntPoint(), SCIPcopyConflicts(), SCIPcopyConsLinear(), SCIPcopyImplicationsCliques(), SCIPcreateConsCardinality(), SCIPcreateConsPseudoboolean(), SCIPcreateFiniteSolCopy(), SCIPcreateNlpiProb(), SCIPcreateWorstCaseProfile(), SCIPcutGenerationHeuristicCmir(), SCIPdummyDebugMethodForSun(), SCIPendStrongbranch(), SCIPevalExprtreeGlobalBounds(), SCIPevalExprtreeLocalBounds(), SCIPevalExprtreeSol(), SCIPgetLinDatasWithoutAndPseudoboolean(), SCIPgetVarCopy(), SCIPgetVarsStrongbranchesFrac(), SCIPgetVarsStrongbranchesInt(), SCIPmatrixCreate(), SCIPmatrixGetParallelCols(), SCIPmatrixGetParallelRows(), SCIPparseVarsList(), SCIPperformGenericDivingAlgorithm(), SCIPprintBranchingStatistics(), SCIPprintNodeRootPath(), SCIPprobdataCreate(), SCIPpropagateProbing(), SCIPreadOpb(), SCIPreoptApplyGlbConss(), SCIPselectVarStrongBranching(), SCIPseparateKnapsackCuts(), SCIPseparateRelaxedKnapsack(), SCIPsetNLPInitialGuessSol(), SCIPsetRelaxSolValsSol(), SCIPshrinkDisjunctiveVarSet(), SCIPsolveKnapsackApproximately(), SCIPsolveKnapsackApproximatelyLT(), SCIPsolveKnapsackExactly(), SCIPsolveParallel(), SCIPupdateNlpiProb(), SCIPwriteCcg(), SCIPwriteGms(), SCIPwriteLp(), SCIPwritePbm(), SCIPwritePip(), SCIPwritePpm(), searchEcAggr(), searchEcAggrWithCliques(), selectBranchVar(), selectInitialVariable(), selectVarMultAggrBranching(), sepaBoundInequalitiesFromGraph(), separateByAuxGraph(), separateByEnumerationHeuristics(), separateConsOnIntegerVariables(), separateCuts(), separateGLS(), separateHeur(), separateIISRounding(), separatePerspective(), separateSequLiftedExtendedWeightInequality(), separateSequLiftedMinimalCoverInequality(), separateSupLiftedMinimalCoverInequality(), sepaSubtour(), sequentialUpAndDownLifting(), sequentialUpAndDownLiftingGUB(), setAltLPObj(), setAltLPObjZero(), setColumnMajorFormat(), setQuadraticObj(), shortenConss(), singletonColumnStuffing(), solCutIsViolated(), solveAndEvalSubscip(), solveCoveringProblem(), solveIndependentCons(), solveSubNLP(), solveSubproblem(), sortComponents(), sortGenVBounds(), sortIDs(), sortVariables(), splitOffLinearPart(), stableSort(), stableSortBinvars(), superadditiveUpLifting(), tcliquegraphConstructCliqueTable(), tightenCapacity(), tightenVarsBoundsSOS1(), tightenWeights(), topologicalSort(), transformSols(), tryUpgradingLogicor(), tryUpgradingXor(), unfixAltLPVariables(), upgradeCons(), upgradeIndicatorSuperindicator(), upgradeLinearSuperindicator(), variablegraphBreadthFirst(), writeBounds(), writeExpandedSolutions(), writeFzn(), and writeOpbConstraints().

◆ SCIPallocClearBufferArray

#define SCIPallocClearBufferArray (   scip,
  ptr,
  num 
)
Value:
#define BMSallocClearBufferMemoryArray(mem, ptr, num)
Definition: memory.h:676
BMS_BUFMEM * SCIPbuffer(SCIP *scip)
Definition: scip.c:45534
#define NULL
Definition: lpi_spx1.cpp:137

Definition at line 21927 of file scip.h.

Referenced by applyCompletesol(), computeReferencePointProjection(), constructCompression(), getLinVarsAndAndRess(), SCIP_DECL_QUADCONSUPGD(), SCIPreadProb(), topologicalSort(), and variablegraphBreadthFirst().

◆ SCIPreallocBufferArray

#define SCIPreallocBufferArray (   scip,
  ptr,
  num 
)
Value:
BMS_BUFMEM * SCIPbuffer(SCIP *scip)
Definition: scip.c:45534
#define BMSreallocBufferMemoryArray(mem, ptr, num)
Definition: memory.h:677
#define NULL
Definition: lpi_spx1.cpp:137

Definition at line 21929 of file scip.h.

Referenced by addBdchg(), addCliqueDataEntry(), addConsToOccurList(), addKnapsackConstraints(), addLogicOrConstraints(), addSetppcConstraints(), appendBuffer(), applyFixings(), applyProbing(), checkArraySizesGLS(), checkArraySizesHeur(), checkCurvature(), checkForOverlapping(), checkSparseMatrixCapacity(), collectBinaryVars(), collectCliqueData(), correctConshdlrdata(), createConstantAssignment(), ensureEdgeCapacity(), ensureFactorsSize(), ensureMonomialsSize(), Exec(), fillDigraph(), generateClusterCuts(), generateCut(), getActiveVariables(), getActiveVariables2(), getFixedVariable(), getInputString(), getLinearCoeffs(), getNodeIdx(), getVariableIndex(), getVariableOrTerm(), heurdataEnsureArraySize(), insertZerolist(), liftCliqueVariables(), optimize(), parseConstantArrayAssignment(), parseList(), parseVariableArrayAssignment(), preprocessCliques(), presolvePropagateCons(), presolveTryAddLinearReform(), presolveUpgrade(), processNlRow(), readBounds(), readCoefficients(), readExpression(), readQCMatrix(), readQMatrix(), removeFixedNonlinearVariables(), SCIP_DECL_CONSCOPY(), SCIP_DECL_CONSINITPRE(), SCIP_DECL_CONSPARSE(), SCIP_DECL_DIALOGEXEC(), SCIP_DECL_HEUREXEC(), SCIP_DECL_PRESOLEXEC(), SCIP_DECL_READERWRITE(), SCIPaddCoefLinear(), SCIPcopyConsLinear(), SCIPcreateConsLinear(), SCIPmatrixCreate(), SCIPparseVarsPolynomial(), SCIPperformGenericDivingAlgorithm(), SCIPprintNodeRootPath(), and tightenVarsBoundsSOS1().

◆ SCIPduplicateBuffer

#define SCIPduplicateBuffer (   scip,
  ptr,
  source 
)
Value:
( (BMSduplicateBufferMemory(SCIPbuffer(scip), (ptr), (source), (size_t)sizeof(**(ptr))) \
BMS_BUFMEM * SCIPbuffer(SCIP *scip)
Definition: scip.c:45534
#define BMSduplicateBufferMemory(mem, ptr, source, size)
Definition: memory.h:679

Definition at line 21931 of file scip.h.

◆ SCIPduplicateBufferArray

#define SCIPduplicateBufferArray (   scip,
  ptr,
  source,
  num 
)
Value:
( (BMSduplicateBufferMemoryArray(SCIPbuffer(scip), (ptr), (source), (num)) == NULL) \
#define BMSduplicateBufferMemoryArray(mem, ptr, source, num)
Definition: memory.h:681
BMS_BUFMEM * SCIPbuffer(SCIP *scip)
Definition: scip.c:45534
#define NULL
Definition: lpi_spx1.cpp:137

Definition at line 21933 of file scip.h.

Referenced by addConstraint(), correctConshdlrdata(), createConstantAssignment(), createTcliqueGraph(), determineMaxDistance(), getConstraint(), getLinearCoeffs(), greedyCliqueAlgorithm(), GUBsetCalcCliquePartition(), handleLinearCons(), multiAggregateBinvar(), parseConstraint(), parseList(), performRandRounding(), preprocessCliques(), preprocessConstraintPairs(), printActiveVariables(), printLinearCons(), printNonLinearCons(), printNonlinearCons(), printPseudobooleanCons(), printQuadraticCons(), propagateAllConss(), propagateCons(), removeDoubleAndSingletonsAndPerformDualpresolve(), removeRedundantConssAndNonzeros(), SCIP_DECL_CONSCOPY(), SCIP_DECL_CONSINITPRE(), SCIP_DECL_CONSPARSE(), SCIP_DECL_DIALOGEXEC(), SCIP_DECL_PRESOLEXEC(), SCIPcopyConsLinear(), SCIPcreateConsLinear(), SCIPmatrixCreate(), SCIPparseVarsPolynomial(), SCIPreadProb(), SCIPtransformMinUC(), selectBranchVar(), selectInitialVariable(), tightenVarsBoundsSOS1(), transformSols(), tryUpgradingLogicor(), tryUpgradingSetppc(), tryUpgradingXor(), updateConsanddataUses(), writeOpbConstraints(), and writeProblem().

◆ SCIPfreeBuffer

◆ SCIPfreeBufferNull

#define SCIPfreeBufferNull (   scip,
  ptr 
)    BMSfreeBufferMemoryNull(SCIPbuffer(scip), (ptr))

Definition at line 21936 of file scip.h.

◆ SCIPfreeBufferArray

#define SCIPfreeBufferArray (   scip,
  ptr 
)    BMSfreeBufferMemoryArray(SCIPbuffer(scip), (ptr))

Definition at line 21937 of file scip.h.

Referenced by addAltLPColumn(), addAltLPConstraint(), addAltLPRow(), addBranchingComplementaritiesSOS1(), addCliques(), addConcaveEstimatorMultivariate(), addConstraint(), addCut(), addFixedVarsConss(), addGenVBound(), addLinearization(), addLocalBranchingConstraint(), addObjcut(), addSplitcons(), addUserEstimator(), aggregation(), analyzeEnergyRequirement(), applyAlternativeBoundsFixing(), applyCompletesol(), applyFixings(), applyHeur(), applyOfins(), applyProbing(), applyRepair(), applyVariableAssignment(), applyVbounds(), branchBalancedCardinality(), calcTwoRowBnds(), changePartitionCovervars(), changePartitionFeasiblesetvars(), checkConComponentsVarbound(), checkConsnames(), checkCumulativeCondition(), checkCurvature(), checkFactorable(), checkLPBoundsClean(), checkOrigPbCons(), checkOverloadViaThetaTree(), checkSolution(), checkSystemGF2(), chgLhs(), chgRhs(), cleanCycle(), cleanupNetwork(), cliquePresolve(), computeAndConstraintInfos(), computeCut(), computeFixingOrder(), computeGradient(), computeMinDistance(), computePeak(), computeReferencePointProjection(), computeVarsCoverSOS1(), computeViolation(), computeViolations(), consCapacityConstraintsFinder(), consCheckRedundancy(), consdataCreate(), consdataLinearize(), consdataPrint(), consdataSortBilinTerms(), consdataSortQuadVarTerms(), constructCompression(), constructSNFRelaxation(), copyConsPseudoboolean(), copyCuts(), copySol(), correctConshdlrdata(), CREATE_CONSTRAINT(), createAndAddLinearCons(), createCGCuts(), createConstraints(), createCoverCuts(), createCoverCutsTimepoint(), createCoveringProblem(), createCumulativeCons(), createDisjuctiveCons(), createLinking(), createLP(), createMIP(), createNewSol(), createNewSols(), createNlRow(), createNormalizedKnapsack(), createNormalizedLogicor(), createNormalizedSetppc(), createPresoldata(), createRows(), createSelectedSortedEventpointsSol(), createSubscip(), createZerohalfCutFromZerohalfWeightvector(), cutGenerationHeuristic(), CUTOFF_CONSTRAINT(), deleteRedundantVars(), detectParallelCols(), detectRedundantVars(), determineMaxDistance(), determineVariableFixings(), disaggregate(), dualBoundStrengthening(), dualPresolve(), enforceCuts(), Exec(), execRelpscost(), extendToCover(), extensionOperatorSOS1(), extractCapacityRows(), extractFlow(), extractGates(), extractNodes(), fillDigraph(), fillVariableGraph(), findAggregation(), findAndStoreEcAggregations(), findComponents(), findCumulativeConss(), findPrecedenceConss(), findUnblockedShortestPathToRoot(), findUncapacitatedArcs(), findVarAggrRedVbcons(), fixAltLPVariables(), fixAndPropagate(), forbidCover(), forbidFixation(), freeGraph(), freeMatrix(), freeStringBufferArray(), freeTcliqueGraph(), generateAverageRay(), generateBoundInequalityFromSOS1Cons(), generateBoundInequalityFromSOS1Nodes(), generateClusterCuts(), generateCut(), generateCutPoint(), generateCutProjectedPoint(), generateCutSol(), generateCutUnboundedLP(), generateOddCycleCut(), generateRowCardinality(), generateSparseCut(), getBoundConsFromVertices(), getConstraint(), getCover(), getFeasibleSet(), getFixedVariable(), getFlowCover(), getGradientMaxElement(), getHighestCapacityUsage(), getLiftingSequence(), getLiftingSequenceGUB(), getLinearCoeffs(), getLinVarsAndAndRess(), getMaxactImplicObjchg(), getNodeSimilarityScore(), greedyCliqueAlgorithm(), GUBsetCalcCliquePartition(), handleLinearCons(), heurdataFreeArrays(), identifyComponent(), identifySourcesTargets(), improvePoint(), inferboundsEdgeFinding(), initConcsolver(), initConflictgraph(), initializeCandsLists(), initPricing(), insertSortedRootNeighbors(), isCandidate(), labelSortStable(), liftOddCycleCut(), loadTcliquegraph(), makeCoverMinimal(), makeSOS1conflictgraphFeasible(), mcfnetworkExtract(), mcfnetworkFill(), mergeAndCleanBilinearTerms(), mergeMultiples(), multiAggregateBinvar(), nlrowaggrCreate(), nodepairqueueFree(), nodepartitionCreate(), nodepartitionFree(), nodepartitionIsConnected(), optimize(), parseAggregation(), parseConstantArray(), parseConstraint(), parseQuadratic(), parseSolveItem(), parseVariableArray(), performRandRounding(), performRelaxSimpleRounding(), preprocessCliques(), preprocessColumns(), preprocessConstraintPairs(), preprocessRows(), preprocessTrivialZerohalfCuts(), presolRoundCardinality(), presolveAddKKTKnapsackConss(), presolveAddKKTLogicorConss(), presolveAddKKTSetppcConss(), presolveAddKKTVarboundConss(), presolveConsEffectiveHorizon(), presolveConsEst(), presolveConsLct(), presolveCreateBenTalNemirovskiApproxDim3(), presolveCreateGlineurApproxDim3(), presolveDisaggregate(), presolveRemoveFixedVariables(), presolveTryAddAND(), presolveUpgrade(), printActiveVariables(), printAggregatedCons(), printAndCons(), printDualSol(), printLinearCons(), printNonLinearCons(), printNonlinearCons(), printPseudobooleanCons(), printQuadraticCons(), propagateAllConss(), propagateBounds(), propagateCons(), propagateTTEF(), propIndicator(), readCnf(), readCoefficients(), readConstraints(), readExpression(), readIndicators(), readNonlinearExprs(), readObjective(), readOPBFile(), readPolynomial(), readQCMatrix(), readQMatrix(), reformulate(), removeBilinearTermsPos(), removeConstraintsDueToNegCliques(), removeDoubleAndSingletonsAndPerformDualpresolve(), removeFixedNonlinearVariables(), removeRedundantConss(), removeRedundantConssAndNonzeros(), resolvePropagationCoretimes(), scaleFirstRow(), SCIP_DECL_BRANCHEXECLP(), SCIP_DECL_CONCSOLVERCOPYSOLVINGDATA(), SCIP_DECL_CONCSOLVERCREATEINST(), SCIP_DECL_CONFLICTEXEC(), SCIP_DECL_CONSCHECK(), SCIP_DECL_CONSCOPY(), SCIP_DECL_CONSEXIT(), SCIP_DECL_CONSEXITPRE(), SCIP_DECL_CONSGETNVARS(), SCIP_DECL_CONSGETVARS(), SCIP_DECL_CONSINITLP(), SCIP_DECL_CONSINITPRE(), SCIP_DECL_CONSINITSOL(), SCIP_DECL_CONSPARSE(), SCIP_DECL_CONSPRESOL(), SCIP_DECL_CONSPRINT(), SCIP_DECL_CONSPROP(), SCIP_DECL_CONSTRANS(), SCIP_DECL_DIALOGEXEC(), SCIP_DECL_EXPRGRAPHNODEREFORM(), SCIP_DECL_HEUREXEC(), SCIP_DECL_LINCONSUPGD(), SCIP_DECL_PARAMCHGD(), SCIP_DECL_PRESOLEXEC(), SCIP_DECL_PRICERREDCOST(), SCIP_DECL_QUADCONSUPGD(), SCIP_DECL_READERREAD(), SCIP_DECL_READERWRITE(), SCIP_DECL_SEPAEXECLP(), SCIP_DECL_SEPAEXECSOL(), SCIP_DECL_SOLVECUMULATIVE(), SCIPaddCoefLinear(), SCIPaddNlpiProbRows(), SCIPaddToNlpiProblemSOC(), SCIPapplyHeurDualval(), SCIPapplyRens(), SCIPapplyUndercover(), SCIPapplyZeroobj(), SCIPcomputeConvexEnvelopeFacet(), SCIPcomputeCoverUndercover(), SCIPcomputeLPRelIntPoint(), SCIPcopyConsLinear(), SCIPcopyImplicationsCliques(), SCIPcreateConsCardinality(), SCIPcreateConsLinear(), SCIPcreateConsPseudoboolean(), SCIPcreateFiniteSolCopy(), SCIPcreateNlpiProb(), SCIPcreateWorstCaseProfile(), SCIPcutGenerationHeuristicCmir(), SCIPdummyDebugMethodForSun(), SCIPendStrongbranch(), SCIPevalExprtreeGlobalBounds(), SCIPevalExprtreeLocalBounds(), SCIPevalExprtreeSol(), SCIPfreeParseVarsPolynomialData(), SCIPgetLinDatasWithoutAndPseudoboolean(), SCIPgetVarCopy(), SCIPgetVarsStrongbranchesFrac(), SCIPgetVarsStrongbranchesInt(), SCIPmatrixCreate(), SCIPmatrixFree(), SCIPmatrixGetParallelCols(), SCIPmatrixGetParallelRows(), SCIPparseVarsList(), SCIPperformGenericDivingAlgorithm(), SCIPprintBranchingStatistics(), SCIPprintNodeRootPath(), SCIPprobdataCreate(), SCIPpropagateProbing(), SCIPreadProb(), SCIPreoptApplyGlbConss(), SCIPselectVarStrongBranching(), SCIPseparateKnapsackCuts(), SCIPseparateRelaxedKnapsack(), SCIPsetNLPInitialGuessSol(), SCIPsetRelaxSolValsSol(), SCIPshrinkDisjunctiveVarSet(), SCIPsolveKnapsackApproximately(), SCIPsolveKnapsackApproximatelyLT(), SCIPsolveKnapsackExactly(), SCIPsolveParallel(), SCIPtransformMinUC(), SCIPupdateNlpiProb(), SCIPwriteCcg(), SCIPwriteGms(), SCIPwriteLp(), SCIPwritePbm(), SCIPwritePip(), SCIPwritePpm(), searchEcAggr(), searchEcAggrWithCliques(), selectBranchVar(), selectInitialVariable(), selectVarMultAggrBranching(), sepaBoundInequalitiesFromGraph(), separateByAuxGraph(), separateConsOnIntegerVariables(), separateCuts(), separateGLS(), separateHeur(), separateIISRounding(), separatePerspective(), separateSequLiftedExtendedWeightInequality(), separateSequLiftedMinimalCoverInequality(), separateSupLiftedMinimalCoverInequality(), sepaSubtour(), sequentialUpAndDownLifting(), sequentialUpAndDownLiftingGUB(), setAltLPObj(), setAltLPObjZero(), setColumnMajorFormat(), setQuadraticObj(), shortenConss(), singletonColumnStuffing(), solCutIsViolated(), solveAndEvalSubscip(), solveCoveringProblem(), solveIndependentCons(), solveSubNLP(), solveSubproblem(), sortComponents(), sortGenVBounds(), sortIDs(), sortVariables(), splitOffLinearPart(), stableSort(), stableSortBinvars(), superadditiveUpLifting(), tcliquegraphConstructCliqueTable(), tightenCapacity(), tightenVarsBoundsSOS1(), tightenWeights(), topologicalSort(), transformSols(), tryUpgradingLogicor(), tryUpgradingSetppc(), tryUpgradingXor(), unfixAltLPVariables(), updateConsanddataUses(), upgradeCons(), upgradeIndicatorSuperindicator(), upgradeLinearSuperindicator(), variablegraphBreadthFirst(), writeBounds(), writeExpandedSolutions(), writeFzn(), writeOpbConstraints(), and writeProblem().

◆ SCIPfreeBufferArrayNull

◆ SCIPallocCleanBuffer

#define SCIPallocCleanBuffer (   scip,
  ptr 
)
Value:
#define BMSallocBufferMemory(mem, ptr)
Definition: memory.h:671
#define NULL
Definition: lpi_spx1.cpp:137
BMS_BUFMEM * SCIPcleanbuffer(SCIP *scip)
Definition: scip.c:45548

Definition at line 21941 of file scip.h.

◆ SCIPallocCleanBufferArray

#define SCIPallocCleanBufferArray (   scip,
  ptr,
  num 
)
Value:
#define BMSallocBufferMemoryArray(mem, ptr, num)
Definition: memory.h:675
#define NULL
Definition: lpi_spx1.cpp:137
BMS_BUFMEM * SCIPcleanbuffer(SCIP *scip)
Definition: scip.c:45548

Definition at line 21943 of file scip.h.

Referenced by SCIPshrinkDisjunctiveVarSet(), and shortenConss().

◆ SCIPfreeCleanBuffer

#define SCIPfreeCleanBuffer (   scip,
  ptr 
)    BMSfreeBufferMemorySize(SCIPcleanbuffer(scip), (ptr))

Definition at line 21945 of file scip.h.

◆ SCIPfreeCleanBufferNull

#define SCIPfreeCleanBufferNull (   scip,
  ptr 
)    BMSfreeBufferMemoryNull(SCIPcleanbuffer(scip), (ptr))

Definition at line 21946 of file scip.h.

◆ SCIPfreeCleanBufferArray

#define SCIPfreeCleanBufferArray (   scip,
  ptr 
)    BMSfreeBufferMemoryArray(SCIPcleanbuffer(scip), (ptr))

Definition at line 21947 of file scip.h.

Referenced by SCIPshrinkDisjunctiveVarSet(), and shortenConss().

◆ SCIPfreeCleanBufferArrayNull

#define SCIPfreeCleanBufferArrayNull (   scip,
  ptr 
)    BMSfreeBufferMemoryArrayNull(SCIPcleanbuffer(scip), (ptr))

Definition at line 21948 of file scip.h.

Function Documentation

◆ SCIPblkmem()

◆ SCIPbuffer()

BMS_BUFMEM* SCIPbuffer ( SCIP scip)

returns buffer memory for short living temporary objects

Returns
the buffer memory for short living temporary objects
Parameters
scipSCIP data structure

Definition at line 45534 of file scip.c.

References SCIP_Mem::buffer, Scip::mem, and NULL.

Referenced by exitPresolve(), initPresolve(), presolve(), presolveRound(), propagationRound(), SCIP_DECL_PARAMCHGD(), SCIPprimalHeuristics(), SCIPprintMemoryDiagnostic(), SCIPsetCopyPlugins(), and separationRoundLP().

◆ SCIPcleanbuffer()

BMS_BUFMEM* SCIPcleanbuffer ( SCIP scip)

returns clean buffer memory for short living temporary objects initialized to all zero

Returns
the buffer memory for short living temporary objects initialized to all zero
Parameters
scipSCIP data structure

Definition at line 45548 of file scip.c.

References SCIP_Mem::cleanbuffer, Scip::mem, and NULL.

Referenced by exitPresolve(), initPresolve(), presolve(), presolveRound(), SCIP_DECL_PARAMCHGD(), SCIPprintMemoryDiagnostic(), and SCIPsetCopyPlugins().

◆ SCIPgetMemUsed()

SCIP_Longint SCIPgetMemUsed ( SCIP scip)

returns the total number of bytes used in block and buffer memory

Returns
the total number of bytes used in block and buffer memory.
Parameters
scipSCIP data structure

Definition at line 45562 of file scip.c.

References Scip::mem, NULL, and SCIPmemGetUsed().

Referenced by applyRepair(), checkArraySizesGLS(), checkArraySizesHeur(), determineLimits(), getCopyMemlimit(), SCIP_DECL_DISPOUTPUT(), SCIP_DECL_PRICERREDCOST(), SCIPapplyUndercover(), SCIPcomputeCoverUndercover(), SCIPsolveParallel(), SCIPtransformProb(), setSubscipLimits(), solveIndependentCons(), and solveSubscip().

◆ SCIPgetMemTotal()

SCIP_Longint SCIPgetMemTotal ( SCIP scip)

returns the total number of bytes in block and buffer memory

Returns
the total number of bytes in block and buffer memory.
Parameters
scipSCIP data structure

Definition at line 45575 of file scip.c.

References Scip::mem, NULL, and SCIPmemGetTotal().

Referenced by SCIP_DECL_CONCSOLVERSYNCWRITE(), SCIP_DECL_DISPOUTPUT(), SCIPgetConcurrentMemTotal(), and SCIPsyncstoreStartSync().

◆ SCIPgetMemExternEstim()

SCIP_Longint SCIPgetMemExternEstim ( SCIP scip)

returns the estimated number of bytes used by external software, e.g., the LP solver

Returns
the estimated number of bytes used by external software, e.g., the LP solver.
Parameters
scipSCIP data structure

Definition at line 45588 of file scip.c.

References NULL, SCIPstatGetMemExternEstim(), and Scip::stat.

Referenced by applyRepair(), checkArraySizesGLS(), checkArraySizesHeur(), determineLimits(), getCopyMemlimit(), SCIPapplyUndercover(), SCIPcheckCopyLimits(), SCIPcomputeCoverUndercover(), SCIPsolveParallel(), setSubscipLimits(), solveIndependentCons(), and solveSubscip().

◆ SCIPcalcMemGrowSize()

◆ SCIPensureBlockMemoryArray_call()

SCIP_RETCODE SCIPensureBlockMemoryArray_call ( SCIP scip,
void **  arrayptr,
size_t  elemsize,
int *  arraysize,
int  minsize 
)

extends a dynamically allocated block memory array to be able to store at least the given number of elements; use SCIPensureBlockMemoryArray() define to call this method!

Returns
SCIP_OKAY is returned if everything worked. Otherwise a suitable error code is passed. See SCIP_RETCODE for a complete list of error codes.
Parameters
scipSCIP data structure
arrayptrpointer to dynamically sized array
elemsizesize in bytes of each element in array
arraysizepointer to current array size
minsizerequired minimal array size

Definition at line 45617 of file scip.c.

References BMSreallocBlockMemorySize, NULL, SCIP_ALLOC, SCIP_OKAY, SCIPblkmem(), SCIPsetCalcMemGrowSize(), and Scip::set.

◆ SCIPprintMemoryDiagnostic()

void SCIPprintMemoryDiagnostic ( SCIP scip)

prints output about used memory

Parameters
scipSCIP data structure

Definition at line 45643 of file scip.c.

References BMSdisplayBlockMemory, BMSdisplayMemory, BMSprintBufferMemory(), Scip::mem, Scip::messagehdlr, NULL, SCIP_Mem::probmem, SCIPbuffer(), SCIPcleanbuffer(), SCIPmessagePrintInfo(), Scip::set, and SCIP_Mem::setmem.

Referenced by SCIP_DECL_DIALOGEXEC().