Detailed Description
Simple Gas Transportation Model.
This example shows how to setup nonlinear constraints with signpower-expression when using SCIP as callable library. The example implements a model for the distribution of gas through a network of pipelines, which is formulated as a cost minimization subject to nonlinear flow-pressure relations, material balances, and pressure bounds. The Belgian gas network is used as an example.
The model is taken from the GAMS model library: https://www.gams.com/latest/gamslib_ml/libhtml/gamslib_gastrans.html
Original model source:
- D. de Wolf and Y. Smeers
The Gas Transmission Problem Solved by and Extension of the Simplex Algorithm
Management Science 46, 11 (2000), 1454-1465
Definition in file gastrans.c.
Go to the source code of this file.
Data Structures | |
struct | NodeData |
struct | ArcData |
Macros | |
#define | nnodes 20 |
#define | narcs 24 |
#define | infinity 1e+20 |
Typedefs | |
typedef struct NodeData | NodeData |
typedef struct ArcData | ArcData |
Functions | |
static SCIP_RETCODE | setupProblem (SCIP *scip) |
static SCIP_RETCODE | runGastrans (void) |
int | main (int argc, char **argv) |
Variables | |
static const NodeData | nodedata [] |
static const ArcData | arcdata [] |
static const SCIP_Real | gastemp = 281.15 |
static const SCIP_Real | rugosity = 0.05 |
static const SCIP_Real | density = 0.616 |
static const SCIP_Real | compressibility = 0.8 |
Macro Definition Documentation
◆ nnodes
#define nnodes 20 |
number of nodes (towns)
Definition at line 65 of file gastrans.c.
Referenced by addBoundCutSepa(), addNodesInformation(), allTermsAreVisited(), applyBranchHistoryToGraph(), applyRepair(), bidecomposition_cutnodesInit(), bidecomposition_init(), bidecomposition_isPossible(), bidecomposition_markSub(), blctreeInitPrimitives(), boundPruneHeur(), boundPruneHeurMw(), buildsolgraph(), buildTmAllSp(), calculateScalingValue(), cgraph_idIsContained(), checkLeavesBelowIncumbent(), checkSdWalk(), cliquePathsInitData(), closeNodesRunInit(), cmst_isSync(), collectFixedTerminals(), collectRoots(), COLORprobGetComplementaryGraph(), COLORprobSetUpArrayOfCons(), compSubcliques(), computeBranchingPriorities(), computeDegConsTree(), computeMinDistance(), computeNewSols(), computeNextAdjacency(), computeOnMarked_init(), computeOrderingFromNode(), computeStarts(), computeSteinerTree(), computeSteinerTree_allFixedTermsAreReached(), computeSteinerTree_allPseudoTermsAreReached(), computeSteinerTree_allTermsAreReached(), computeSteinerTree_init(), computeSteinerTreeTM(), computeSteinerTreeVnoi(), connectivityDataInit(), createClique(), createConsStoreGraphAtRoot(), createConstraints(), createDegreeConstraints(), createMIP(), createModel(), createNewSol(), createPrizeConstraints(), createVariableNodes(), createVariables(), csrdepoFillCSR(), csrdepoFillRandom(), csrdepoGetNnodes(), cutEdgeProbe(), cutNodesGetLastCutnode(), cutNodesSetDfsRoot(), cutNodesTreeBuildSteinerTree(), cutNodesTreeDeleteComponents(), cutNodesTreeInit(), cutNodesTreeMakeTermsIsComplete(), daExec(), daGetNruns(), daInit(), dapathsInit(), dapathsIsPromising(), dapathsSetRunParams(), dapathsSortStarts(), daPcFindRoots(), daRedCostIsValid(), daRedcostsInit(), dcmstInsert(), debugPrintSeparator(), decomposeBuildCsr(), decomposeGetFirstMarked(), deletenodesDeg1(), depthFirstSearch(), dhcstpWarmUp(), distCloseNodesCompute(), distCloseNodesIncluded(), distDataAllocateNodesArrays(), distDataPathRootsInitialize(), distGetRestricted(), distgraphAddEdges(), distgraphAddEdgesFromTpaths(), distgraphAddNodes(), dpborder_coreSolve(), dpborder_dpbsequenceCopy(), dpborder_dpbsequenceInit(), dpborder_markSolNodes(), dpborderInitHelper(), dpgraphInit(), dpiterAddNewPrepare(), dpiterInit(), dpiterSetDefault(), dpsolverInitData(), dpterms_isPromisingFully(), dpterms_streeInit(), dualascent_execDegCons(), dualascent_execPcMw(), ensureSuccessorsSize(), enumExec(), enumIsPromising(), extInitRedCostArrays(), extInitRedCostArraysPc(), extPreprocessInitialComponent(), extractSubgraphGetSizeAndMap(), extreduce_checkComponent(), extreduce_distCloseNodesAreValid(), extreduce_distDataInit(), extreduce_distDataRecomputeDirtyPaths(), extreduce_extdataCleanArraysDbg(), extreduce_extdataIsClean(), extreduce_extPermaInit(), extreduce_extPermaIsClean(), extreduce_mstTopLevelBaseObjValid(), extreduce_pcdataIsClean(), extreduce_redcostAddEdge(), extreduce_redcostInitExpansion(), extreduce_treeIsFlawed(), extTreeGetDirectedRedcostProper(), fillGraphByLinearConss(), fillGraphByNonlinearConss(), findArticulationPointsUtil(), findCumulativeConss(), findPrecedenceConss(), findSolPcMw2Term(), findSolRPcMw(), findSubtour(), fixVarsDualcost(), fixVarsDualcostLurking(), fixVarsRedbased(), freeConflictGraphSST(), generateBoundInequalityFromSOS1Nodes(), getBiasedMw(), getBiasedPc(), getBoundchanges(), getBoundchangesPcMW(), getcloseterms(), getEnsembleEstimation(), getHighSolDegVertex(), getlecloseterms(), getLowestCommonAncestors(), getNViolatedEdges(), getOrderedRootIndices(), getOrgNodeToNodeMap(), getRedCost2ndNextDistances(), getReductionRatios(), getSd(), globalrelabel(), graph_buildCompleteGraph(), graph_buildOrgNodesToReducedMap(), graph_csr_alloc(), graph_csr_build(), graph_csr_buildCosts(), graph_csr_chgCosts(), graph_csr_costsAreInSync(), graph_csr_getNedges(), graph_csr_isValid(), graph_csrdepo_addEmptyTop(), graph_dcsr_deleteEdge(), graph_dijkLimited_clean(), graph_dijkLimited_init(), graph_dijkLimited_initPcShifts(), graph_findCentralTerminal(), graph_getCsr(), graph_getIsTermArray(), graph_getTerms(), graph_grid_create(), graph_hasMultiEdges(), graph_init_dcsr(), graph_initContractTracing(), graph_initHistory(), graph_isMarked(), graph_load(), graph_mark(), graph_mincut_exec(), graph_mincut_setDefaultVals(), graph_obstgrid_create(), graph_pack(), graph_path_exec(), graph_path_execX(), graph_path_invroot(), graph_path_st(), graph_path_st_brmwcs(), graph_path_st_dc(), graph_path_st_pcmw(), graph_path_st_pcmw_extend(), graph_path_st_pcmw_extendBiased(), graph_path_st_pcmw_extendOut(), graph_path_st_pcmw_full(), graph_path_st_rpcmw(), graph_pc_2org(), graph_pc_2trans(), graph_pc_getNonLeafTermOffset(), graph_pc_getOrgCostsCsr(), graph_pc_getReductionRatios(), graph_pc_knotHasMaxPrize(), graph_pc_markOrgGraph(), graph_pc_nFixedTerms(), graph_pc_nNonLeafTerms(), graph_pc_shiftNonLeafCosts(), graph_pc_solGetObj(), graph_pc_termMarkProper(), graph_printEdgeConflicts(), graph_printInfoReduced(), graph_pseudoAncestors_hashNode(), graph_pseudoAncestors_hashNodeDirty(), graph_pseudoAncestors_unhashNode(), graph_pseudoAncestors_unhashNodeDirty(), graph_sdCloseNodesBiased(), graph_sdStarBiased(), graph_subinoutInit(), graph_termsReachable(), graph_transMw(), graph_transNw2pc(), graph_transNw2sap(), graph_transPc(), graph_transPcGetRsap(), graph_transPcGetSap(), graph_transRmw(), graph_transRpc(), graph_transRpc2FixedProper(), graph_transRpcToSpgIsStable(), graph_valid(), graph_valid_dcsr(), graph_validInput(), graph_vnoiCompute(), graph_vnoiComputeImplied(), graph_vnoiInit(), graph_voronoiMw(), graph_voronoiRepair(), graph_voronoiTerms(), graph_voronoiWithDist(), graph_voronoiWithRadius(), graph_voronoiWithRadiusMw(), graph_writeReductionStats(), graph_writeStp(), graphBuildV5E5(), graphisValidPcMw(), graphmarkIsClean(), greedyInitialColoring(), greedyStableSet(), hasUncoloredNode(), index2nodes(), initCostsAndPrioLP(), initialise(), initPropAtFirstCall(), initReceivedSubproblem(), initRedcostdata(), initSolve(), insertionInit(), isMaxprizeTerm(), isRestartApplicable(), keyNodesResetTerms(), keyNodesSetTerms(), ledgeFromNetgraph(), localExtendPc(), localInsertion(), localInsertion2(), localInsertion2pc(), localKeyPathExchange(), localKeyPathExchangeMw(), localKeyPathExchangePc(), localKeyPathExchangePc2(), localKeyVertex(), localKeyVertexHeuristics(), localKeyVertexPc(), localKeyVertexPc2(), localRun(), localVertexInsertion(), lurkpruneInit(), markNonLeafTerms_2trans(), markNonLeafTerms_pretransPc(), markPseudoDeletablesFromBounds(), markSolTreeNodes(), mincut_findTerminalSeparatorsIsPromising(), mincut_separateLp(), mincutExec(), mincutFree(), mincutInit(), mincutInitForLp(), mincutInitForTermSepa(), mincutPrepareForLp(), mst_getObj(), mst_getSoledges(), mst_init(), mwContract0WeightVertices(), mwContractTerminalsChainWise(), mwContractTerminalsSimple(), nodes2index(), nsvInitData(), nwptstpSetRoot(), pcBiasCostsDCSR(), pcmwAdaptStarts(), pcmwDeleteNonSolEdges(), pcmwFindMax2Terms(), pcmwGetStartNodes(), pcmwUpdate(), pcmwUpdateBestSol_csrInSync(), pcsolGetMstEdges(), pcsolMarkGraphNodes(), pcsolMarkGraphNodes_csr(), pcsolPrune(), pcsubtreePruneForProfit_csr(), prClean(), presolveCons(), prInit(), propagateUBs(), propgraphApplyImplicationsPcMw(), propgraphApplyStates(), propgraphMarkFixedTermsPcMw(), pruneSteinerTreeStp(), pseudoDelDouble(), pseudodeleteBiasedIsPromising(), pseudodeleteDeleteMarkedNodes(), pseudodeleteExecute(), pseudodeleteInit(), pseudoDelSingle(), readCol(), redcostGetNTermsMarked(), redcostGraphBuild(), redcostGraphMark(), redcostGraphSolRetransform(), reduce_ans(), reduce_ansAdv(), reduce_ansAdv2(), reduce_applyPseudoDeletions(), reduce_baseInit(), reduce_bd34(), reduce_bd34WithSd(), reduce_bdkWithSd(), reduce_bound(), reduce_boundHop(), reduce_boundHopR(), reduce_boundHopRc(), reduce_boundMw(), reduce_chain2(), reduce_cnsAdv(), reduce_compbuilderInit(), reduce_cutEdgeTryPrune(), reduce_da(), reduce_daPcMw(), reduce_daSlackPrune(), reduce_dc(), reduce_dcmstMstIsValid(), reduce_deleteMultiedges(), reduce_extendedCheck3Tree(), reduce_extendedEdge(), reduce_getMinNreductions(), reduce_getSdByPaths(), reduce_hc(), reduce_identifyNonLeafTerms(), reduce_impliedNodesGet(), reduce_impliedNodesIsValid(), reduce_mw(), reduce_nnp(), reduce_nodesDeg1(), reduce_npv(), reduce_nv(), reduce_nvAdv(), reduce_nw(), reduce_pc(), reduce_removeDeg0NonLeafTerms(), reduce_rpt(), reduce_sap(), reduce_sd(), reduce_sdBiased(), reduce_sdBiasedNeighbor(), reduce_sdEdgeCliqueStar(), reduce_sdImpLongEdge(), reduce_sdneighborGetCloseTerms(), reduce_sdneighborInit(), reduce_sdPc(), reduce_sdprofitPrintStats(), reduce_sdsp(), reduce_sdspSap(), reduce_sdStar(), reduce_sdStarBiasedWithProfit(), reduce_sdStarPc(), reduce_sdStarPc2(), reduce_sdWalk(), reduce_sdWalk_csr(), reduce_sdWalkExt(), reduce_sdWalkExt2(), reduce_sdWalkTriangle(), reduce_simple(), reduce_simple_dc(), reduce_simple_hc(), reduce_simple_mw(), reduce_simple_pc(), reduce_simple_sap(), reduce_sl(), reduce_stp(), reduce_termcompChangeSubgraphToBottleneck(), reduce_unconnected(), reduce_unconnectedForDirected(), reduce_unconnectedInfeas(), reduce_unconnectedRpcRmwInfeas(), reduceCheckEdge(), reduceExact(), reducePcMw(), reduceRootedProb(), reduceWithEdgeFixingBounds(), reduceWithNodeFixingBounds(), reinitialise(), reopttreeGetNNodes(), reroot(), retransformReducedProbSolution(), rpcTryFullReduce(), runTabuCol(), runTmPcMW_mode(), scale_coords(), SCIP_DECL_BRANCHEXECLP(), SCIP_DECL_CONCSOLVEREXEC(), SCIP_DECL_CONSACTIVE(), SCIP_DECL_CONSPROP(), SCIP_DECL_CONSSEPALP(), SCIP_DECL_HEUREXEC(), SCIP_DECL_NODESELSELECT(), SCIP_DECL_PRICERFARKAS(), SCIP_DECL_PRICERREDCOST(), SCIP_DECL_READERREAD(), SCIP_DECL_READERWRITE(), SCIPaddNNodes(), SCIPbtPrintGml(), SCIPcreateProbColoring(), SCIPdigraphAddArc(), SCIPdigraphAddArcSafe(), SCIPdigraphComputeDirectedComponents(), SCIPdigraphCopy(), SCIPdigraphCreate(), SCIPdigraphGetNodeData(), SCIPdigraphGetNSuccessors(), SCIPdigraphGetSuccessors(), SCIPdigraphGetSuccessorsData(), SCIPdigraphResize(), SCIPdigraphSetNodeData(), SCIPdigraphSetNSuccessors(), SCIPnodeGetAncestorBranchingPath(), SCIPprintNodeRootPath(), SCIPrealHashCode(), SCIPsolveCIP(), SCIPStpBranchruleInitNodeState(), SCIPStpHeurLocalExtendPcMw(), SCIPStpHeurLocalExtendPcMwImp(), SCIPStpHeurLocalExtendPcMwOut(), SCIPStpHeurPruneRun(), SCIPStpHeurPruneUpdateSols(), SCIPStpHeurRecExclude(), SCIPStpHeurRecRun(), SCIPStpHeurSlackPruneRun(), SCIPStpHeurTMBuildTree(), SCIPStpHeurTMBuildTreeDc(), SCIPStpHeurTMBuildTreePcMw(), SCIPStpHeurTMCompStarts(), SCIPStpHeurTMRunLP(), SCIPStpPropCheckForInfeas(), SCIPStpPropGetGraph(), SCIPStpValidateSol(), SCIPtreeGetAvgLowerbound(), sddeltable(), sdGetSdPcMw(), sdgraphAlloc(), sdgraphAllocRestricted(), sdgraphSetDefaults(), sdgraphUpdateDistgraphFromTpaths(), sdmstGetWeight(), sdneighborUpdateExec(), sdneighborUpdateInit(), sdneighborUpdateNode(), sdprofitAlloc(), sdprofitBuild(), sdprofitBuild1stOnly(), sdqueryBuildNodesToFullMap(), sdqueryBuildNodesToRmqMap(), sdqueryRmqInit(), sdStarBiasedProcessNode(), sdStarInit(), sdStarReset(), sdwalkReset(), sdwalkResetExt(), sdwalkResetExt2(), selectBestNode(), selectBranchingVertexByDegree(), selectBranchingVertexByLp(), selectBranchingVertexByLp2Flow(), selectBranchingVertexBySol(), sep_flow(), sepaspecial_pcimplicationsInit(), sepaspecial_pcimplicationsSeparate(), sepaspecial_vtimplicationsInit(), setNodeSolArray(), setupProblem(), shortestpath_pcInit(), solDegIsValid(), solGetMstEdges_csr(), solgraphAdaptForDCSTP(), solgraphAdaptForPcMw(), solNodeIsValid(), solPrune(), solstp_isValid(), solstp_markPcancestors(), solstp_pcConnectDummies(), solstp_pcGetObjCsr(), solstp_pcGetSolRoot(), solstp_pruneFromEdges(), solstp_pruneFromTmHeur_csr(), solstp_setVertexFromEdge(), solstp_setVertexFromEdgeConn(), sortGenVBounds(), sortNodes(), STP_Vectype(), stPcmwInit(), stpsol_pruningIsPossible(), stpsolPrune_csr(), strongPruneSteinerTreePc(), strongPruneSteinerTreePc_csr(), stRpcmwInit(), subsolUpdate(), subtreesBuild(), subtreesExtend(), subtreesRemoveNonValids(), subtreeSumGapSplit(), supergraphComputeMst(), SYMcomputeSymmetryGenerators(), tarjan(), tbottleneckGetMax(), tbottleneckInit(), TCLIQUE_ISEDGE(), TCLIQUE_NEWSOL(), TCLIQUE_SELECTADJNODES(), tcliqueAddEdge(), tcliqueFlush(), tcliqueGetFirstAdjedge(), tcliqueGetLastAdjedge(), tcliquegraphConstructCliqueTable(), tcliqueMaxClique(), termsepaCsrGetMaxNedges(), termsepaCsrGetMaxNnodes(), termsepaCutIsCorrect(), termsepaStoreCutFinalize(), termsepaTraverseSinkComp(), testBdkSdMstDeletesNodeDeg3(), testBdkSdMstDeletesNodeDeg4(), testBdkSdMstStarDeletesNodeDeg4(), testBdkTreeDistDeletesNodeDeg4(), testBiasedTerminalPathsTo4NextFound(), testBiconnectedComponentsAreFound(), testBiconnectedComponentsAreFound2(), testBiconnectedComponentsAreFound3(), testBiconnectedDecomposition(), testBiconnectedDecomposition2(), testBiconnectedDecomposition3(), testBLCworksFor3Star(), testBLCworksFor3StarAfterReduction(), testBLCworksFor5Tree(), testDistCloseNodesAreValid(), testDistCloseNodesPcAreValid1(), testDistCloseNodesPcAreValid2(), testDistCloseNodesPcAreValidAfterDeletion(), testDistDistancesAreValid(), testDistRootPathsAreValid(), testEdgeDeletedBy3LeafSpg(), testEdgeDeletedByCommonRedCostsTargets(), testEdgeDeletedByEqBottleneck(), testEdgeDeletedByEqBottleneck2(), testEdgeDeletedByMst1(), testEdgeDeletedByMst2(), testEdgeDeletedByMultiRedCosts(), testEdgeDeletion1_deprecated(), testEdgeDeletion2_deprecated(), testEdgeDeletion3_deprecated(), testEdgeDeletion4_deprecated(), testEdgeDeletion5_deprecated(), testEdgeNotDeleted1(), testGeneralStarDeletedEdge1(), testGeneralStarDeletedEdge2(), testGeneralStarDeletedEdge3(), testNode3PseudoDeletedByContraction(), testNode3PseudoDeletedByRedCosts1(), testNode3PseudoDeletedBySd1(), testNode3PseudoDeletedBySd2(), testNode3PseudoDeletedBySd3(), testNode3PseudoDeletedBySdBiased(), testNode3PseudoDeletedBySdBiasedSimple(), testNode4PseudoDeletedBySd1(), testNode4PseudoNotDeletedBySd1(), testNsvImpliedContractsCutDistEdge(), testNsvImpliedContractsCutDistMiddleEdge(), testNsvImpliedContractsEdge(), testNsvImpliedContractsEdge2(), testNsvImpliedContractsImpliedToTermEdge(), testPathReplaceDeletesEdge(), testPathReplaceDeletesEdge2(), testPcEdgeDeletedByMst1(), testPcEdgeNotDeleted(), testPcNode3PseudoDeletedBySd1(), testPcNode4PseudoDeletedBySd1(), testPrunedSolIsImprovedPc1(), testPrunedSolIsImprovedPc2(), testRmwChain2DeletesNode(), testRmwNpv3DeletesNode(), testSdBiasedBottleneckDeletesEdge(), testSdBiasedBottleneckTermPathDeletesEdge(), testSdBiasedDeletesEdge(), testSdCliqueStarDeg3AdjacencyIsCorrect(), testSdCliqueStarDeg3IsCorrect(), testSdCliqueStarDeg3IsCorrect2(), testSdCliqueStarDeg4IsCorrect(), testSdCliqueStarDeletesEdge(), testSdGetterReturnsCorrectSds(), testSdGraphDistsAreValid(), testSdGraphDistsAreValid2(), testSdGraphQueriesAreValid(), testSdGraphStrongBiasedDistsAreValid(), testSdPcKillsEdge1(), testSdPcKillsEdge2(), testSdPcKillsTwoEdges(), testSdRepair(), testSdStarBiasedDeletesEdge(), testSdStarBiasedDeletesEdge2(), testSdStarBiasedDeletesEdge3(), testSdStarPcKillsEdge(), testStar3IsCorrect(), testStar4EdgeIsCorrect(), testStar4IsCorrect(), testStar5IsCorrect(), testTerminalPathsRepair(), testTerminalPathsRepair2(), testTerminalPathsRepair3(), testTerminalPathsTo3NextFound(), testTerminalSeparatorsAreFound(), testTerminalSeparatorsAreFound2(), testTerminalSeparatorsAreFound3(), testTmGivesExpectedTreePcFull1(), testTmGivesExpectedTreePcFull2(), testTmGivesExpectedTreePcFull3(), tmAllspFree(), tmAllspInit(), tmBaseInit(), tmVnoiFree(), tmVnoiInit(), trail(), trailGraphWithStates(), transitiveClosure(), treeDistsAreFlawed(), treeResetCounters(), tryPathPcMw(), updateDeg2LurkingBounds(), updateEdgeFixingBounds(), updateEdgeLurkingBounds(), updateEdgestateFromRedPcmw(), updateNodeFixingBounds(), updateNodeReplaceBounds(), updateTerminalSource(), vnoiInit(), wrapperRins(), and tsp::ReaderTSP::~ReaderTSP().
◆ narcs
#define narcs 24 |
number of arcs
Definition at line 68 of file gastrans.c.
Referenced by addGLSCliques(), createMIP(), doSeachEcAggr(), SCIPdigraphGetNArcs(), separateGLS(), and setupProblem().
◆ infinity
#define infinity 1e+20 |
value we use to represent infinity
Definition at line 71 of file gastrans.c.
Referenced by atomic_userexpr::atomic_userexpr(), resolvePropagation(), SCIPintervalAddInf(), SCIPintervalAddScalar(), SCIPintervalAddSup(), SCIPintervalDiv(), SCIPintervalDivScalar(), SCIPintervalEntropy(), SCIPintervalExp(), SCIPintervalIsEntire(), SCIPintervalLog(), SCIPintervalMulInf(), SCIPintervalMulScalarInf(), SCIPintervalMulScalarSup(), SCIPintervalMulSup(), SCIPintervalPowerScalar(), SCIPintervalQuadBivar(), SCIPintervalQuadUpperBound(), SCIPintervalReciprocal(), SCIPintervalScalprod(), SCIPintervalScalprodScalarsInf(), SCIPintervalScalprodScalarsSup(), SCIPintervalSetEntire(), SCIPintervalSignPowerScalar(), SCIPintervalSolveBivariateQuadExpressionAllScalar(), SCIPintervalSolveUnivariateQuadExpressionPositive(), SCIPintervalSolveUnivariateQuadExpressionPositiveAllScalar(), SCIPintervalSquare(), SCIPintervalSquareRoot(), SCIPintervalSub(), SCIPlpiInfinity(), SCIPlpiIsInfinity(), SCIPlpiScaleCol(), SCIPlpiScaleRow(), and setupProblem().
Typedef Documentation
◆ NodeData
◆ ArcData
Function Documentation
◆ setupProblem()
|
static |
sets up problem
- Parameters
-
scip SCIP data structure
Definition at line 145 of file gastrans.c.
References active, ArcData::active, compressibility, NodeData::cost, density, gastemp, infinity, ArcData::length, NodeData::name, narcs, nnodes, ArcData::node1, NULL, NodeData::pressurelower, NodeData::pressureupper, rugosity, SCIP_CALL, SCIP_MAXSTRLEN, SCIP_OKAY, SCIP_Real, SCIP_VARTYPE_CONTINUOUS, SCIPaddCoefLinear(), SCIPaddCons(), SCIPaddVar(), SCIPcreateConsBasicLinear(), SCIPcreateConsBasicNonlinear(), SCIPcreateExprSignpower(), SCIPcreateExprSum(), SCIPcreateExprVar(), SCIPcreateProbBasic(), SCIPcreateVarBasic(), SCIPinfinity(), SCIPreleaseCons(), SCIPreleaseExpr(), SCIPreleaseVar(), SCIPsnprintf(), NodeData::supplylower, and NodeData::supplyupper.
Referenced by runGastrans().
◆ runGastrans()
|
static |
runs gas transportation example
Definition at line 322 of file gastrans.c.
References FALSE, NULL, SCIP_CALL, SCIP_OKAY, SCIPcreate(), SCIPfree(), SCIPincludeDefaultPlugins(), SCIPinfoMessage(), SCIPpresolve(), SCIPprintOrigProblem(), SCIPsolve(), and setupProblem().
Referenced by main().
◆ main()
int main | ( | int | argc, |
char ** | argv | ||
) |
main method starting SCIP
- Parameters
-
argc number of arguments from the shell argv array of shell arguments
Definition at line 365 of file gastrans.c.
References runGastrans(), SCIP_OKAY, and SCIPprintError().
Variable Documentation
◆ nodedata
|
static |
data of nodes
Definition at line 74 of file gastrans.c.
Referenced by addBranchingComplementaritiesSOS1(), addSSTConssOrbitAndUpdateSST(), analyzeConflictOverload(), checkConComponentsVarbound(), checkOverloadViaThetaTree(), collectThetaSubtree(), computeEnergyContribution(), deleteLambdaLeaf(), detectVarboundSOS1(), findResponsibleLambdaLeafTraceEnergy(), findResponsibleLambdaLeafTraceEnvelop(), freeConflictgraph(), freeConflictGraphSST(), generateBoundInequalityFromSOS1Nodes(), getBoundConsFromVertices(), inferboundsEdgeFinding(), initConflictgraph(), initImplGraphSOS1(), insertThetanode(), moveNodeToLambda(), nodeGetSolvalVarboundLbSOS1(), nodeGetSolvalVarboundUbSOS1(), passConComponentVarbound(), propVariableNonzero(), selectOrbitLeaderSSTConss(), sepaImplBoundCutsSOS1(), traceLambdaEnergy(), traceLambdaEnvelop(), traceThetaEnvelop(), updateEnvelope(), updateKeyOnTrace(), and updateSymInfoConflictGraphSST().
◆ arcdata
|
static |
data of arcs
Definition at line 100 of file gastrans.c.
◆ gastemp
|
static |
◆ rugosity
|
static |
◆ density
|
static |
density of gas relative to air
Definition at line 136 of file gastrans.c.
Referenced by dpterms_isPromisingPartly(), setupProblem(), and tcliquegraphConstructCliqueTable().
◆ compressibility
|
static |