Google OR-Tools v9.15
a fast and portable software suite for combinatorial optimization
Loading...
Searching...
No Matches
operations_research Namespace Reference

OR-Tools root namespace. More...

Detailed Description

OR-Tools root namespace.

Namespaces

namespace  internal
namespace  ssmf_internal
namespace  base
namespace  gtl
namespace  bop
namespace  Source
namespace  sat
namespace  fz
namespace  glop
namespace  math_opt
namespace  mb
namespace  lp_format
namespace  packing
namespace  pdlp
namespace  sysinfo
namespace  routing
namespace  scheduling
namespace  scp
namespace  use_only_in_tests
namespace  cap_prod_util

Classes

class  BinaryIndexedTree
class  DenseDoublyLinkedList
class  DenseIntDuplicateRemover
class  DynamicPartition
class  MergingPartition
class  SimpleDynamicPartition
class  DynamicPermutation
class  GraphSymmetryFinder
class  HungarianOptimizer
class  KnapsackBruteForceSolver
struct  KnapsackItemWithEfficiency
class  Knapsack64ItemsSolver
class  KnapsackDynamicProgrammingSolver
class  KnapsackDivideAndConquerSolver
class  KnapsackMIPSolver
class  KnapsackCpSat
class  KnapsackSolver
struct  KnapsackAssignment
struct  KnapsackItem
class  KnapsackSearchNode
class  KnapsackSearchPath
class  KnapsackState
 KnapsackState represents a partial solution to the knapsack problem. More...
class  KnapsackPropagator
 KnapsackPropagator is the base class for modeling and propagating a constraint given an assignment. More...
class  KnapsackCapacityPropagator
 KnapsackCapacityPropagator is a KnapsackPropagator used to enforce a capacity constraint. More...
class  BaseKnapsackSolver
 This is the base class for knapsack solvers. More...
class  KnapsackGenericSolver
 KnapsackGenericSolver is the multi-dimensional knapsack solver class. More...
class  SpaceSavingMostFrequent
class  SparsePermutation
class  AccurateSum
class  Bitmap
class  MathUtil
class  ThreadPool
class  Queue
struct  StateInfo
struct  StateMarker
struct  Trail
class  Trace
class  LocalSearchMonitorPrimary
class  SimpleRevFIFO
class  LightIntFunctionElementCt
class  LightIntIntFunctionElementCt
class  LightIntIntIntFunctionElementCt
struct  DefaultPhaseParameters
 This struct holds all parameters for the default search. More...
class  Solver
 Solver Class. More...
class  BaseObject
class  PropagationBaseObject
 NOLINT. More...
class  Decision
class  DecisionVisitor
class  DecisionBuilder
class  ProfiledDecisionBuilder
class  Demon
class  ModelVisitor
 Model visitor. More...
class  Constraint
class  CastConstraint
class  SearchMonitor
 A search monitor is a simple set of callbacks to monitor all search events. More...
class  Rev
class  NumericalRev
 Subclass of Rev<T> which adds numerical operations. More...
class  RevArray
class  NumericalRevArray
 Subclass of RevArray<T> which adds numerical operations. More...
class  IntExpr
class  IntVarIterator
class  InitAndGetValues
class  IntVar
class  SolutionCollector
class  BaseObjectiveMonitor
class  ObjectiveMonitor
class  OptimizeVar
class  SearchLimit
 Base class of all search limits. More...
class  RegularLimit
class  ImprovementSearchLimit
class  IntervalVar
class  SequenceVar
class  AssignmentElement
class  IntVarElement
class  IntervalVarElement
class  SequenceVarElement
class  AssignmentContainer
class  Assignment
class  Pack
class  DisjunctiveConstraint
class  SolutionPool
class  BaseIntExpr
class  RevImmutableMultiMap
class  RevSwitch
 A reversible switch that can switch once from false to true. More...
class  SmallRevBitSet
class  RevBitSet
class  RevBitMatrix
 Matrix version of the RevBitSet class. More...
class  CallMethod0
 Demon proxy to a method on the constraint with no arguments. More...
class  CallMethod1
 Demon proxy to a method on the constraint with one argument. More...
class  CallMethod2
 Demon proxy to a method on the constraint with two arguments. More...
class  CallMethod3
 Demon proxy to a method on the constraint with three arguments. More...
class  DelayedCallMethod0
 Low-priority demon proxy to a method on the constraint with no arguments. More...
class  DelayedCallMethod1
 Low-priority demon proxy to a method on the constraint with one argument. More...
class  DelayedCallMethod2
 Low-priority demon proxy to a method on the constraint with two arguments. More...
class  LocalSearchOperator
 The base class for all local search operators. More...
class  LocalSearchOperatorState
class  IntVarLocalSearchOperator
class  BaseLns
 Here's a sample relaxing one variable at a time: More...
class  ChangeValue
class  AlternativeNodeIterator
class  NodeNeighborIterator
class  BaseNodeIterators
class  PathOperator
class  SubDagComputer
class  LocalSearchState
class  LocalSearchFilter
class  LocalSearchFilterManager
class  IntVarLocalSearchFilter
class  PropagationMonitor
class  LocalSearchMonitor
class  BooleanVar
class  SymmetryBreaker
class  SearchLog
class  ModelCache
class  ArgumentHolder
 Argument Holder: useful when visiting a model. More...
class  ModelParser
 Model Parser. More...
class  ArrayWithOffset
class  RevGrowingArray
class  RevIntSet
class  RevPartialSequence
 --— RevPartialSequence --— More...
class  UnsortedNullableRevBitset
class  DemonProfiler
class  IfThenElseCt
class  PiecewiseLinearExpr
class  TwoOpt
class  Relocate
class  Exchange
class  Cross
class  BaseInactiveNodeToPathOperator
class  MakeActiveOperator
class  RelocateAndMakeActiveOperator
class  ExchangeAndMakeActiveOperator
class  ExchangePathStartEndsAndMakeActiveOperator
class  MakeActiveAndRelocateOperator
class  MakeInactiveOperator
class  RelocateAndMakeInactiveOperator
class  MakeChainInactiveOperator
class  SwapActiveOperator
class  SwapActiveChainOperator
class  ExtendedSwapActiveOperator
class  TSPOpt
class  TSPLns
class  NearestNeighbors
class  LinKernighan
class  PathLns
class  NeighborhoodLimit
class  LocalSearchProfiler
class  FindOneNeighbor
class  LocalSearchPhaseParameters
class  LocalSearch
class  DefaultSolutionPool
class  Dimension
class  RoutingModelInspector
struct  RoutingSearchStats
class  RoutingModel
class  RoutingModelVisitor
 Routing model visitor. More...
class  TypeRegulationsChecker
class  TypeIncompatibilityChecker
 Checker for type incompatibilities. More...
class  TypeRequirementChecker
 Checker for type requirements. More...
class  TypeRegulationsConstraint
struct  BoundCost
class  SimpleBoundCosts
class  RoutingDimension
class  BreakPropagator
class  FinalizerVariables
class  CommittableValue
class  CommittableArray
class  IndexRange
class  DimensionValues
class  PrePostVisitValues
class  PathState
class  DimensionChecker
class  LightVehicleBreaksChecker
class  WeightedWaveletTree
class  PathEnergyCostChecker
class  BasePathFilter
 Generic path-based filter class. More...
class  MaxLinearExpressionEvaluator
class  RuinAndRecreateDecisionBuilder
class  RoutingSolution
class  RuinProcedure
class  CloseRoutesRemovalRuinProcedure
class  RandomWalkRemovalRuinProcedure
class  CompositeRuinProcedure
class  SISRRuinProcedure
class  NeighborAcceptanceCriterion
class  RoutingIndexManager
 Manager for any NodeIndex <-> variable index conversion. More...
class  FilteredHeuristicLocalSearchOperator
class  FilteredHeuristicPathLNSOperator
class  RelocatePathAndHeuristicInsertUnperformedOperator
class  FilteredHeuristicExpensiveChainLNSOperator
class  FilteredHeuristicCloseNodesLNSOperator
class  RelocateVisitTypeOperator
class  CumulBoundsPropagator
class  RoutingLinearSolverWrapper
class  RoutingGlopWrapper
class  RoutingCPSatWrapper
class  DimensionCumulOptimizerCore
class  LocalDimensionCumulOptimizer
class  GlobalDimensionCumulOptimizer
struct  SlopeAndYIntercept
class  MakeRelocateNeighborsOperator
class  ShortestPathOnAlternatives
class  TwoOptWithShortestPathOperator
class  SwapActiveToShortestPathOperator
class  MakePairActiveOperator
class  MakePairInactiveOperator
 Operator which makes pairs of active nodes inactive. More...
class  PairRelocateOperator
class  GroupPairAndRelocateOperator
class  LightPairRelocateOperator
class  PairExchangeOperator
class  PairExchangeRelocateOperator
class  SwapIndexPairOperator
class  IndexPairSwapActiveOperator
class  RelocateExpensiveChain
 RelocateExpensiveChain. More...
class  PairNodeSwapActiveOperator
class  PickupAndDeliveryData
 A utility class to maintain pickup and delivery information of nodes. More...
class  RelocateSubtrip
class  ExchangeSubtrip
class  VehicleTypeCurator
class  IntVarFilteredDecisionBuilder
 Generic filter-based decision builder using an IntVarFilteredHeuristic. More...
class  IntVarFilteredHeuristic
 Generic filter-based heuristic applied to IntVars. More...
class  RoutingFilteredHeuristic
 Filter-based heuristic dedicated to routing. More...
class  CheapestInsertionFilteredHeuristic
class  GlobalCheapestInsertionFilteredHeuristic
class  InsertionSequenceContainer
class  InsertionSequenceGenerator
struct  PickupDeliveryInsertion
class  LocalCheapestInsertionFilteredHeuristic
class  CheapestAdditionFilteredHeuristic
class  EvaluatorCheapestAdditionFilteredHeuristic
class  ComparatorCheapestAdditionFilteredHeuristic
class  SavingsFilteredHeuristic
class  SequentialSavingsFilteredHeuristic
class  ParallelSavingsFilteredHeuristic
class  ChristofidesFilteredHeuristic
class  SweepArranger
struct  PickupDeliveryPair
class  BinCapacities
class  RoundRobinCompoundObjectiveMonitor
class  SymmetryManager
class  SimpleLinearSumAssignment
class  BidirectionalDijkstra
class  BoundedDijkstraWrapper
class  ChristofidesPathSolver
class  BronKerboschAlgorithm
class  WeightedBronKerboschBitsetAlgorithm
struct  ArcWithLengthAndResources
struct  GraphPathWithLength
class  ConstrainedShortestPathsOnDagWrapper
struct  ArcWithLength
struct  PathWithLength
class  ShortestPathsOnDagWrapper
class  KShortestPathsOnDagWrapper
class  PriorityQueueWithRestrictedPush
class  MaxFlowStatusClass
class  GenericMaxFlow
class  ElementIterator
class  Set
class  SetRangeIterator
class  SetRangeWithCardinality
class  LatticeMemoryManager
class  HamiltonianPathSolver
class  PruningHamiltonianSolver
struct  KShortestPaths
class  LinearSumAssignment
class  CostValueCycleHandler
class  ArcIndexOrderingByTailNode
class  SimpleMaxFlow
class  GenericMinCostFlow
class  MinCostFlowBase
class  SimpleMinCostFlow
struct  MinCostFlow
struct  DistanceAndParentArc
class  MinCostPerfectMatching
class  BlossomGraph
class  RootedTree
class  GenericPathContainer
struct  CppFlags
class  CppBridge
class  OrToolsVersion
class  BopInterface
class  CBCInterface
class  CLPInterface
class  CplexInterface
class  GLOPInterface
class  GLPKInformation
class  GLPKInterface
class  GurobiInterface
class  HighsInterface
class  KnapsackInterface
class  LinearExpr
class  LinearRange
class  MPSolver
class  MPObjective
 A class to express a linear objective. More...
class  MPVariable
 The class for variables of a Mathematical Programming (MP) model. More...
class  MPConstraint
class  MPSolverParameters
class  MPSolverInterface
class  MPSolverInterfaceFactoryRepository
class  MPCallbackContext
class  MPCallback
class  MPCallbackList
struct  MPModelExportOptions
 Export options. More...
class  PdlpInterface
struct  HighsSolveInfo
class  IntegerBoundsPreprocessor
class  BoundPropagationPreprocessor
class  ImpliedIntegerPreprocessor
class  ReduceCostOverExclusiveOrConstraintPreprocessor
class  SatInterface
struct  CallbackSetup
struct  ScipConstraintHandlerDescription
class  ScipConstraintHandlerContext
struct  CallbackRangeConstraint
class  ScipConstraintHandler
struct  ScipCallbackConstraintOptions
class  SCIPInterface
class  ScipConstraintHandlerForMPCallback
class  ScipMPCallbackContext
class  XpressMPCallbackContext
class  MPCallbackWrapper
class  XpressInterface
class  MPSReaderTemplate
struct  GScipResult
struct  GScipLinearRange
class  GScip
struct  GScipQuadraticRange
struct  GScipSOSData
struct  GScipIndicatorConstraint
struct  GScipLogicalConstraintData
struct  GScipVariableOptions
struct  GScipConstraintOptions
struct  GScipConstraintHandlerProperties
struct  GScipCutOptions
struct  GScipLazyConstraintOptions
struct  GScipCallbackStats
class  GScipConstraintHandlerContext
class  GScipConstraintHandler
struct  GScipEventHandlerDescription
class  GScipEventHandlerContext
class  GScipEventHandler
struct  GScipLinearExpr
struct  GScipIndicatorRangeConstraint
struct  GScipAndVariables
class  LocationContainer
class  RandomDemand
class  ServiceTimePlusTransition
class  StopServiceTimePlusTransition
class  CourseSchedulingSolver
class  SetCoverAssignment
class  CompressedStrongVectorIterator
class  CompressedStrongVector
class  IndexRangeIterator
class  IterableContainerBase
class  IterableContainer
class  StopWatch
class  CapacityInvariant
class  CapacityModel
class  SetCoverSolutionGenerator
class  SubsetListBasedSolutionGenerator
class  BoolVectorBasedSolutionGenerator
class  TrivialSolutionGenerator
class  RandomSolutionGenerator
class  GreedySolutionGenerator
class  ElementDegreeSolutionGenerator
class  LazyElementDegreeSolutionGenerator
class  SteepestSearch
class  LazySteepestSearch
class  TabuList
class  GuidedTabuSearch
class  GuidedLocalSearch
class  SetCoverDecision
class  SetCoverInvariant
class  SetCoverLagrangian
class  SetCoverMip
class  SetCoverModel
class  IntersectingSubsetsIterator
class  IntersectingSubsetsRange
class  SetCoverReader
class  StrongModelView
class  IndexListModelView
class  FilterModelView
class  AdaptiveParameterValue
class  AffineRelation
class  Bitset64
class  BitQueue64
class  SparseBitset
class  CachedLog
class  DenseSet
class  FixedShapeBinaryTree
class  FlatMatrix
class  RoundTripDoubleFormat
class  ScopedFloatingPointEnv
class  IntegerPriorityQueue
class  LazyMutableCopy
class  SolverLogger
class  PresolveTimer
class  MonoidOperationTree
class  PermutationCycleHandler
class  ArrayIndexCycleHandler
class  PermutationApplier
class  PiecewiseSegment
class  PiecewiseLinearFunction
class  FloatSlopePiecewiseLinearFunction
struct  QapProblem
class  RangeMinimumQuery
class  RangeMinimumIndexQuery
class  RangeIntToIntFunction
class  RangeMinMaxIndexFunction
class  ReversibleInterface
class  RevRepository
class  RevVector
class  RevMap
class  RevGrowingMultiMap
class  RunningAverage
class  RunningMax
class  ThetaLambdaTree
class  SolveInterrupter
class  ScopedSolveInterrupterCallback
struct  ClosedInterval
class  Domain
class  SortedDisjointIntervalList
class  Stat
class  StatsGroup
class  DistributionStat
class  TimeDistribution
class  RatioDistribution
class  DoubleDistribution
class  IntegerDistribution
class  EnabledScopedTimeDistributionUpdater
class  DisabledScopedTimeDistributionUpdater
class  DisabledScopedTimeStats
class  EnabledScopedTimeStats
struct  DebugStringFormatter
class  StrongIndex
class  StrongInt64
class  TimeLimit
class  SharedTimeLimit
class  NestedTimeLimit
class  TimeLimitCheckEveryNCalls
class  IntTupleSet
class  VectorOrFunction
class  VectorOrFunction< ScalarType, std::vector< ScalarType > >
class  MatrixOrFunction
class  MatrixOrFunction< ScalarType, std::vector< std::vector< ScalarType > >, square >
class  MatrixOrFunction< ScalarType, FlatMatrix< ScalarType >, square >
class  ZVector
struct  WorkerInfoDefaultTypeInternal
struct  SequenceVarAssignmentDefaultTypeInternal
struct  IntervalVarAssignmentDefaultTypeInternal
struct  IntVarAssignmentDefaultTypeInternal
struct  AssignmentProtoDefaultTypeInternal
class  WorkerInfo
class  SequenceVarAssignment
class  IntervalVarAssignment
class  IntVarAssignment
class  AssignmentProto
struct  DemonRunsDefaultTypeInternal
struct  ConstraintRunsDefaultTypeInternal
class  DemonRuns
class  ConstraintRuns
struct  RoutingSearchStatusDefaultTypeInternal
struct  LocalSearchMetaheuristicDefaultTypeInternal
struct  FirstSolutionStrategyDefaultTypeInternal
class  RoutingSearchStatus
class  LocalSearchMetaheuristic
class  FirstSolutionStrategy
struct  SavingsParametersDefaultTypeInternal
struct  LocalCheapestInsertionParametersDefaultTypeInternal
struct  GlobalCheapestInsertionParametersDefaultTypeInternal
class  SavingsParameters
class  LocalCheapestInsertionParameters
class  GlobalCheapestInsertionParameters
struct  SpatiallyCloseRoutesRuinStrategyDefaultTypeInternal
struct  SimulatedAnnealingAcceptanceStrategyDefaultTypeInternal
struct  SISRRuinStrategyDefaultTypeInternal
struct  RuinCompositionStrategyDefaultTypeInternal
struct  RandomWalkRuinStrategyDefaultTypeInternal
struct  PerturbationStrategyDefaultTypeInternal
struct  MoreNodesPerformedAcceptanceStrategyDefaultTypeInternal
struct  GreedyDescentAcceptanceStrategyDefaultTypeInternal
struct  CoolingScheduleStrategyDefaultTypeInternal
struct  AllNodesPerformedAcceptanceStrategyDefaultTypeInternal
struct  AbsencesBasedAcceptanceStrategyDefaultTypeInternal
struct  RuinStrategyDefaultTypeInternal
struct  RecreateParametersDefaultTypeInternal
struct  AcceptanceStrategyDefaultTypeInternal
struct  RecreateStrategyDefaultTypeInternal
struct  RuinRecreateParametersDefaultTypeInternal
struct  IteratedLocalSearchParametersDefaultTypeInternal
class  SpatiallyCloseRoutesRuinStrategy
class  SimulatedAnnealingAcceptanceStrategy
class  SISRRuinStrategy
class  RuinCompositionStrategy
class  RandomWalkRuinStrategy
class  PerturbationStrategy
class  MoreNodesPerformedAcceptanceStrategy
class  GreedyDescentAcceptanceStrategy
class  CoolingScheduleStrategy
class  AllNodesPerformedAcceptanceStrategy
class  AbsencesBasedAcceptanceStrategy
class  RuinStrategy
class  RecreateParameters
class  AcceptanceStrategy
class  RecreateStrategy
class  RuinRecreateParameters
class  IteratedLocalSearchParameters
struct  RoutingSearchParameters_LocalSearchNeighborhoodOperatorsDefaultTypeInternal
struct  RoutingSearchParameters_ImprovementSearchLimitParametersDefaultTypeInternal
struct  RoutingModelParametersDefaultTypeInternal
struct  RoutingSearchParametersDefaultTypeInternal
class  RoutingSearchParameters_LocalSearchNeighborhoodOperators
class  RoutingSearchParameters_ImprovementSearchLimitParameters
class  RoutingModelParameters
class  RoutingSearchParameters
struct  RegularLimitParametersDefaultTypeInternal
class  RegularLimitParameters
struct  SubSolverStatisticsDefaultTypeInternal
struct  LocalSearchStatistics_LocalSearchOperatorStatisticsDefaultTypeInternal
struct  LocalSearchStatistics_LocalSearchFilterStatisticsDefaultTypeInternal
struct  LocalSearchStatistics_FirstSolutionStatisticsDefaultTypeInternal
struct  ConstraintSolverStatisticsDefaultTypeInternal
struct  LocalSearchStatisticsDefaultTypeInternal
struct  SearchStatisticsDefaultTypeInternal
class  SubSolverStatistics
class  LocalSearchStatistics_LocalSearchOperatorStatistics
class  LocalSearchStatistics_LocalSearchFilterStatistics
class  LocalSearchStatistics_FirstSolutionStatistics
class  ConstraintSolverStatistics
class  LocalSearchStatistics
class  SearchStatistics
struct  ConstraintSolverParametersDefaultTypeInternal
class  ConstraintSolverParameters
struct  FlowNodeProtoDefaultTypeInternal
struct  FlowArcProtoDefaultTypeInternal
struct  FlowModelProtoDefaultTypeInternal
class  FlowModelProto
class  FlowNodeProto
class  FlowArcProto
struct  PartialVariableAssignmentDefaultTypeInternal
struct  OptionalDoubleDefaultTypeInternal
struct  MPVariableProtoDefaultTypeInternal
struct  MPSosConstraintDefaultTypeInternal
struct  MPSolveInfoDefaultTypeInternal
struct  MPSolutionDefaultTypeInternal
struct  MPQuadraticObjectiveDefaultTypeInternal
struct  MPQuadraticConstraintDefaultTypeInternal
struct  MPModelProto_AnnotationDefaultTypeInternal
struct  MPConstraintProtoDefaultTypeInternal
struct  MPArrayWithConstantConstraintDefaultTypeInternal
struct  MPArrayConstraintDefaultTypeInternal
struct  MPAbsConstraintDefaultTypeInternal
struct  MPSolverCommonParametersDefaultTypeInternal
struct  MPSolutionResponseDefaultTypeInternal
struct  MPModelDeltaProto_VariableOverridesEntry_DoNotUseDefaultTypeInternal
struct  MPModelDeltaProto_ConstraintOverridesEntry_DoNotUseDefaultTypeInternal
struct  MPIndicatorConstraintDefaultTypeInternal
struct  MPModelDeltaProtoDefaultTypeInternal
struct  MPGeneralConstraintProtoDefaultTypeInternal
struct  MPModelProtoDefaultTypeInternal
struct  MPModelRequestDefaultTypeInternal
class  MPVariableProto
class  MPConstraintProto
class  MPModelProto
class  PartialVariableAssignment
class  OptionalDouble
class  MPSosConstraint
class  MPSolveInfo
class  MPSolution
class  MPQuadraticObjective
class  MPQuadraticConstraint
class  MPModelProto_Annotation
class  MPArrayWithConstantConstraint
class  MPArrayConstraint
class  MPAbsConstraint
class  MPSolverCommonParameters
class  MPSolutionResponse
class  MPModelDeltaProto_VariableOverridesEntry_DoNotUse
class  MPModelDeltaProto_ConstraintOverridesEntry_DoNotUse
class  MPIndicatorConstraint
class  MPModelDeltaProto
class  MPGeneralConstraintProto
class  MPModelRequest
struct  GScipSolvingStatsDefaultTypeInternal
struct  GScipParameters_StringParamsEntry_DoNotUseDefaultTypeInternal
struct  GScipParameters_RealParamsEntry_DoNotUseDefaultTypeInternal
struct  GScipParameters_LongParamsEntry_DoNotUseDefaultTypeInternal
struct  GScipParameters_IntParamsEntry_DoNotUseDefaultTypeInternal
struct  GScipParameters_CharParamsEntry_DoNotUseDefaultTypeInternal
struct  GScipParameters_BoolParamsEntry_DoNotUseDefaultTypeInternal
struct  GScipParametersDefaultTypeInternal
struct  GScipOutputDefaultTypeInternal
class  GScipSolvingStats
class  GScipParameters_StringParamsEntry_DoNotUse
class  GScipParameters_RealParamsEntry_DoNotUse
class  GScipParameters_LongParamsEntry_DoNotUse
class  GScipParameters_IntParamsEntry_DoNotUse
class  GScipParameters_CharParamsEntry_DoNotUse
class  GScipParameters_BoolParamsEntry_DoNotUse
class  GScipParameters
class  GScipOutput
struct  TeacherDefaultTypeInternal
struct  StudentAssignmentDefaultTypeInternal
struct  StudentDefaultTypeInternal
struct  RoomDefaultTypeInternal
struct  CourseDefaultTypeInternal
struct  ClassAssignmentDefaultTypeInternal
struct  CourseSchedulingResultDefaultTypeInternal
struct  CourseSchedulingModelDefaultTypeInternal
class  Teacher
class  StudentAssignment
class  Student
class  Room
class  Course
class  ClassAssignment
class  CourseSchedulingResult
class  CourseSchedulingModel
struct  CapacityConstraintProto_CapacityTerm_ElementWeightPairDefaultTypeInternal
struct  CapacityConstraintProto_CapacityTermDefaultTypeInternal
struct  CapacityConstraintProtoDefaultTypeInternal
class  CapacityConstraintProto_CapacityTerm_ElementWeightPair
class  CapacityConstraintProto_CapacityTerm
class  CapacityConstraintProto
struct  SetCoverProto_SubsetDefaultTypeInternal
struct  SetCoverSolutionResponseDefaultTypeInternal
struct  SetCoverProtoDefaultTypeInternal
class  SetCoverProto_Subset
class  SetCoverSolutionResponse
class  SetCoverProto
struct  Int128DefaultTypeInternal
class  Int128
class  ReverseArcListGraph
class  CompleteGraph
class  unique_ptr
 STL class. More...
class  Message

Typedefs

typedef KnapsackItemKnapsackItemPtr
using NeighborAccessor
using VariableDomainId = LocalSearchState::VariableDomainId
using NodeId = SubDagComputer::NodeId
using ArcId = SubDagComputer::ArcId
typedef std::function< int64_t(int64_t)> RoutingTransitCallback1
typedef std::function< int64_t(int64_t, int64_t)> RoutingTransitCallback2
typedef std::function< const FloatSlopePiecewiseLinearFunction *(int64_t, int64_t)> RoutingCumulDependentTransitCallback2
typedef int PathNodeIndex
using NodeIndex = BlossomGraph::NodeIndex
using CostValue = BlossomGraph::CostValue
typedef uint32_t PathDistance
typedef util::ReverseArcStaticGraph Graph
typedef std::function< MPSolverInterface *(MPSolver *)> MPSolverInterfaceFactory
using GScipSolution = absl::flat_hash_map<SCIP_VAR*, double>
using GScipBranchingPriority = absl::flat_hash_map<SCIP_VAR*, int>
using GScipMessageHandler
typedef std::function< int64_t(RoutingNodeIndex, RoutingNodeIndex)> RoutingNodeEvaluator2
using Cost = double
using BaseInt = int32_t
using SubsetRange = util_intops::StrongIntRange<SubsetIndex>
using ElementRange = util_intops::StrongIntRange<ElementIndex>
using ColumnEntryRange = util_intops::StrongIntRange<ColumnEntryIndex>
using SubsetCostVector = util_intops::StrongVector<SubsetIndex, Cost>
using ElementCostVector = util_intops::StrongVector<ElementIndex, Cost>
using SparseColumn = util_intops::StrongVector<ColumnEntryIndex, ElementIndex>
using SparseRow = util_intops::StrongVector<RowEntryIndex, SubsetIndex>
using ElementToIntVector = util_intops::StrongVector<ElementIndex, BaseInt>
using SubsetToIntVector = util_intops::StrongVector<SubsetIndex, BaseInt>
using SparseColumnView = util_intops::StrongVector<SubsetIndex, SparseColumnSparseColumn>
using SparseRowView = util_intops::StrongVector<ElementIndex, SparseRow>
using SubsetBoolVector = util_intops::StrongVector<SubsetIndex, bool>
using ElementBoolVector = util_intops::StrongVector<ElementIndex, bool>
using ElementToSubsetVector
using CompressedColumn = CompressedStrongVector<ColumnEntryIndex, ElementIndex>
using CompressedRow = CompressedStrongVector<RowEntryIndex, SubsetIndex>
using CompressedColumnView
using CompressedRowView
using CompressedColumnIterator
using CompressedRowIterator
using CapacityWeight = int64_t
using CapacityElements
using CapacitySubsets
using CapacityWeights
using CL = SetCoverInvariant::ConsistencyLevel
template<typename IndexType, typename ValueType>
using StrictVector = glop::StrictITIVector<IndexType, ValueType>
using BenchmarksTableRow
using FullElementCostVector = util_intops::StrongVector<FullElementIndex, Cost>
using FullSubsetCostVector = util_intops::StrongVector<FullSubsetIndex, Cost>
using FullElementBoolVector = util_intops::StrongVector<FullElementIndex, bool>
using FullSubsetBoolVector = util_intops::StrongVector<FullSubsetIndex, bool>
using FullElementToIntVector
using FullSubsetToIntVector
using FullToCoreElementMapVector
using CoreToFullElementMapVector
using FullToCoreSubsetMapVector
using CoreToFullSubsetMapVector
template<typename T, size_t alignment_bytes>
using AlignedAllocator
template<typename T, size_t alignment_bytes>
using AlignedVector = std::vector<T, AlignedAllocator<T, alignment_bytes>>
template<typename T>
using UnsafeDenseSet = DenseSet<T, false>
using random_engine_t = std::mt19937_64
typedef std::pair< int64_t, int64_t > Fraction
template<class Iterator>
using value_type_t = typename std::iterator_traits<Iterator>::value_type
using ScopedTimeDistributionUpdater = DisabledScopedTimeDistributionUpdater
using ScopedTimeStats = DisabledScopedTimeStats
typedef ZVector< int8_t > Int8ZVector
typedef ZVector< int16_t > Int16ZVector
typedef ZVector< int32_t > Int32ZVector
typedef ZVector< int64_t > Int64ZVector
typedef ZVector< uint8_t > UInt8ZVector
typedef ZVector< uint16_t > UInt16ZVector
typedef ZVector< uint32_t > UInt32ZVector
typedef ZVector< uint64_t > UInt64ZVector

Enumerations

enum  VarTypes {
  UNSPECIFIED , DOMAIN_INT_VAR , BOOLEAN_VAR , CONST_VAR ,
  VAR_ADD_CST , VAR_TIMES_CST , CST_SUB_VAR , OPP_VAR ,
  TRACE_VAR
}
enum class  DimensionSchedulingStatus { OPTIMAL , RELAXED_OPTIMAL_ONLY , FEASIBLE , INFEASIBLE }
enum class  CliqueResponse { CONTINUE , STOP }
enum class  BronKerboschAlgorithmStatus { COMPLETED , INTERRUPTED }
enum class  MPCallbackEvent {
  kUnknown , kPolling , kPresolve , kSimplex ,
  kMip , kMipSolution , kMipNode , kBarrier ,
  kMessage , kMultiObj
}
enum class  ScipSeparationResult { kLazyConstraintAdded , kCuttingPlaneAdded , kDidNotFind }
enum  CUSTOM_INTERRUPT_REASON { CALLBACK_EXCEPTION = 0 }
enum class  MPSReaderFormat { kAutoDetect , kFree , kFixed }
enum class  GScipVarType { kContinuous , kBinary , kInteger , kImpliedInteger }
enum class  GScipHintResult { kInfeasible , kRejected , kAccepted }
enum class  GScipCallbackResult {
  kDidNotRun = 1 , kDelayed = 2 , kDidNotFind = 3 , kFeasible = 4 ,
  kInfeasible = 5 , kUnbounded = 6 , kCutOff = 7 , kSeparated = 8 ,
  kNewRound = 9 , kReducedDomain = 10 , kConstraintAdded = 11 , kConstraintChanged = 12 ,
  kBranched = 13 , kSolveLp = 14 , kFoundSolution = 15 , kSuspend = 16 ,
  kSuccess = 17 , kDelayNode = 18
}
enum class  RoundingLockDirection { kUp , kDown , kBoth }
enum class  ConstraintHandlerCallbackType {
  kSepaLp , kSepaSol , kEnfoLp , kEnfoPs ,
  kConsCheck , kConsLock
}
enum class  GScipMessageType { kInfoMessage , kDialogMessage , kWarningMessage }
enum class  SetCoverMipSolver : int {
  SCIP = 0 , SAT = 1 , GUROBI = 2 , GLOP = 3 ,
  PDLP = 4
}
enum class  FileFormat {
  EMPTY , ORLIB , RAIL , FIMI ,
  PROTO , PROTO_BIN , TXT
}
enum class  ProtoWriteFormat { kProtoText , kProtoBinary , kJson , kCanonicalJson }
enum  FirstSolutionStrategy_Value : int {
  FirstSolutionStrategy_Value_UNSET = 0 , FirstSolutionStrategy_Value_AUTOMATIC = 15 , FirstSolutionStrategy_Value_PATH_CHEAPEST_ARC = 3 , FirstSolutionStrategy_Value_PATH_MOST_CONSTRAINED_ARC = 4 ,
  FirstSolutionStrategy_Value_EVALUATOR_STRATEGY = 5 , FirstSolutionStrategy_Value_SAVINGS = 10 , FirstSolutionStrategy_Value_PARALLEL_SAVINGS = 17 , FirstSolutionStrategy_Value_SWEEP = 11 ,
  FirstSolutionStrategy_Value_CHRISTOFIDES = 13 , FirstSolutionStrategy_Value_ALL_UNPERFORMED = 6 , FirstSolutionStrategy_Value_BEST_INSERTION = 7 , FirstSolutionStrategy_Value_PARALLEL_CHEAPEST_INSERTION = 8 ,
  FirstSolutionStrategy_Value_SEQUENTIAL_CHEAPEST_INSERTION = 14 , FirstSolutionStrategy_Value_LOCAL_CHEAPEST_INSERTION = 9 , FirstSolutionStrategy_Value_LOCAL_CHEAPEST_COST_INSERTION = 16 , FirstSolutionStrategy_Value_GLOBAL_CHEAPEST_ARC = 1 ,
  FirstSolutionStrategy_Value_LOCAL_CHEAPEST_ARC = 2 , FirstSolutionStrategy_Value_FIRST_UNBOUND_MIN_VALUE = 12 , FirstSolutionStrategy_Value_FirstSolutionStrategy_Value_INT_MIN_SENTINEL_DO_NOT_USE_ , FirstSolutionStrategy_Value_FirstSolutionStrategy_Value_INT_MAX_SENTINEL_DO_NOT_USE_
}
enum  LocalSearchMetaheuristic_Value : int {
  LocalSearchMetaheuristic_Value_UNSET = 0 , LocalSearchMetaheuristic_Value_AUTOMATIC = 6 , LocalSearchMetaheuristic_Value_GREEDY_DESCENT = 1 , LocalSearchMetaheuristic_Value_GUIDED_LOCAL_SEARCH = 2 ,
  LocalSearchMetaheuristic_Value_SIMULATED_ANNEALING = 3 , LocalSearchMetaheuristic_Value_TABU_SEARCH = 4 , LocalSearchMetaheuristic_Value_GENERIC_TABU_SEARCH = 5 , LocalSearchMetaheuristic_Value_LocalSearchMetaheuristic_Value_INT_MIN_SENTINEL_DO_NOT_USE_ ,
  LocalSearchMetaheuristic_Value_LocalSearchMetaheuristic_Value_INT_MAX_SENTINEL_DO_NOT_USE_
}
enum  RoutingSearchStatus_Value : int {
  RoutingSearchStatus_Value_ROUTING_NOT_SOLVED = 0 , RoutingSearchStatus_Value_ROUTING_SUCCESS = 1 , RoutingSearchStatus_Value_ROUTING_PARTIAL_SUCCESS_LOCAL_OPTIMUM_NOT_REACHED = 2 , RoutingSearchStatus_Value_ROUTING_FAIL = 3 ,
  RoutingSearchStatus_Value_ROUTING_FAIL_TIMEOUT = 4 , RoutingSearchStatus_Value_ROUTING_INVALID = 5 , RoutingSearchStatus_Value_ROUTING_INFEASIBLE = 6 , RoutingSearchStatus_Value_ROUTING_OPTIMAL = 7 ,
  RoutingSearchStatus_Value_RoutingSearchStatus_Value_INT_MIN_SENTINEL_DO_NOT_USE_ , RoutingSearchStatus_Value_RoutingSearchStatus_Value_INT_MAX_SENTINEL_DO_NOT_USE_
}
enum  LocalCheapestInsertionParameters_PairInsertionStrategy : int {
  LocalCheapestInsertionParameters_PairInsertionStrategy_AUTOMATIC = 0 , LocalCheapestInsertionParameters_PairInsertionStrategy_BEST_PICKUP_THEN_BEST_DELIVERY = 1 , LocalCheapestInsertionParameters_PairInsertionStrategy_BEST_PICKUP_DELIVERY_PAIR = 2 , LocalCheapestInsertionParameters_PairInsertionStrategy_BEST_PICKUP_DELIVERY_PAIR_MULTITOUR = 3 ,
  LocalCheapestInsertionParameters_PairInsertionStrategy_LocalCheapestInsertionParameters_PairInsertionStrategy_INT_MIN_SENTINEL_DO_NOT_USE_ , LocalCheapestInsertionParameters_PairInsertionStrategy_LocalCheapestInsertionParameters_PairInsertionStrategy_INT_MAX_SENTINEL_DO_NOT_USE_
}
enum  LocalCheapestInsertionParameters_InsertionSortingProperty : int {
  LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_UNSPECIFIED = 0 , LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_ALLOWED_VEHICLES = 1 , LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_PENALTY = 2 , LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_PENALTY_OVER_ALLOWED_VEHICLES_RATIO = 3 ,
  LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_HIGHEST_AVG_ARC_COST_TO_VEHICLE_START_ENDS = 4 , LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_LOWEST_AVG_ARC_COST_TO_VEHICLE_START_ENDS = 5 , LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_LOWEST_MIN_ARC_COST_TO_VEHICLE_START_ENDS = 6 , LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_HIGHEST_DIMENSION_USAGE = 7 ,
  LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_RANDOM = 8 , LocalCheapestInsertionParameters_InsertionSortingProperty_LocalCheapestInsertionParameters_InsertionSortingProperty_INT_MIN_SENTINEL_DO_NOT_USE_ , LocalCheapestInsertionParameters_InsertionSortingProperty_LocalCheapestInsertionParameters_InsertionSortingProperty_INT_MAX_SENTINEL_DO_NOT_USE_
}
enum  RuinCompositionStrategy_Value : int {
  RuinCompositionStrategy_Value_UNSET = 0 , RuinCompositionStrategy_Value_RUN_ALL_SEQUENTIALLY = 1 , RuinCompositionStrategy_Value_RUN_ALL_RANDOMLY = 2 , RuinCompositionStrategy_Value_RUN_ONE_RANDOMLY = 3 ,
  RuinCompositionStrategy_Value_RuinCompositionStrategy_Value_INT_MIN_SENTINEL_DO_NOT_USE_ , RuinCompositionStrategy_Value_RuinCompositionStrategy_Value_INT_MAX_SENTINEL_DO_NOT_USE_
}
enum  PerturbationStrategy_Value : int { PerturbationStrategy_Value_UNSET = 0 , PerturbationStrategy_Value_RUIN_AND_RECREATE = 1 , PerturbationStrategy_Value_PerturbationStrategy_Value_INT_MIN_SENTINEL_DO_NOT_USE_ , PerturbationStrategy_Value_PerturbationStrategy_Value_INT_MAX_SENTINEL_DO_NOT_USE_ }
enum  CoolingScheduleStrategy_Value : int {
  CoolingScheduleStrategy_Value_UNSET = 0 , CoolingScheduleStrategy_Value_EXPONENTIAL = 1 , CoolingScheduleStrategy_Value_LINEAR = 2 , CoolingScheduleStrategy_Value_CoolingScheduleStrategy_Value_INT_MIN_SENTINEL_DO_NOT_USE_ ,
  CoolingScheduleStrategy_Value_CoolingScheduleStrategy_Value_INT_MAX_SENTINEL_DO_NOT_USE_
}
enum  RoutingSearchParameters_SchedulingSolver : int {
  RoutingSearchParameters_SchedulingSolver_SCHEDULING_UNSET = 0 , RoutingSearchParameters_SchedulingSolver_SCHEDULING_GLOP = 1 , RoutingSearchParameters_SchedulingSolver_SCHEDULING_CP_SAT = 2 , RoutingSearchParameters_SchedulingSolver_RoutingSearchParameters_SchedulingSolver_INT_MIN_SENTINEL_DO_NOT_USE_ ,
  RoutingSearchParameters_SchedulingSolver_RoutingSearchParameters_SchedulingSolver_INT_MAX_SENTINEL_DO_NOT_USE_
}
enum  ConstraintSolverParameters_TrailCompression : int { ConstraintSolverParameters_TrailCompression_NO_COMPRESSION = 0 , ConstraintSolverParameters_TrailCompression_COMPRESS_WITH_ZLIB = 1 , ConstraintSolverParameters_TrailCompression_ConstraintSolverParameters_TrailCompression_INT_MIN_SENTINEL_DO_NOT_USE_ , ConstraintSolverParameters_TrailCompression_ConstraintSolverParameters_TrailCompression_INT_MAX_SENTINEL_DO_NOT_USE_ }
enum  FlowModelProto_ProblemType : int { FlowModelProto_ProblemType_LINEAR_SUM_ASSIGNMENT = 0 , FlowModelProto_ProblemType_MAX_FLOW = 1 , FlowModelProto_ProblemType_MIN_COST_FLOW = 2 }
enum  MPSosConstraint_Type : int { MPSosConstraint_Type_SOS1_DEFAULT = 0 , MPSosConstraint_Type_SOS2 = 1 }
enum  MPModelProto_Annotation_TargetType : int { MPModelProto_Annotation_TargetType_VARIABLE_DEFAULT = 0 , MPModelProto_Annotation_TargetType_CONSTRAINT = 1 , MPModelProto_Annotation_TargetType_GENERAL_CONSTRAINT = 2 }
enum  MPSolverCommonParameters_LPAlgorithmValues : int { MPSolverCommonParameters_LPAlgorithmValues_LP_ALGO_UNSPECIFIED = 0 , MPSolverCommonParameters_LPAlgorithmValues_LP_ALGO_DUAL = 1 , MPSolverCommonParameters_LPAlgorithmValues_LP_ALGO_PRIMAL = 2 , MPSolverCommonParameters_LPAlgorithmValues_LP_ALGO_BARRIER = 3 }
enum  MPModelRequest_SolverType : int {
  MPModelRequest_SolverType_CLP_LINEAR_PROGRAMMING = 0 , MPModelRequest_SolverType_GLOP_LINEAR_PROGRAMMING = 2 , MPModelRequest_SolverType_GLPK_LINEAR_PROGRAMMING = 1 , MPModelRequest_SolverType_GUROBI_LINEAR_PROGRAMMING = 6 ,
  MPModelRequest_SolverType_XPRESS_LINEAR_PROGRAMMING = 101 , MPModelRequest_SolverType_CPLEX_LINEAR_PROGRAMMING = 10 , MPModelRequest_SolverType_HIGHS_LINEAR_PROGRAMMING = 15 , MPModelRequest_SolverType_SCIP_MIXED_INTEGER_PROGRAMMING = 3 ,
  MPModelRequest_SolverType_GLPK_MIXED_INTEGER_PROGRAMMING = 4 , MPModelRequest_SolverType_CBC_MIXED_INTEGER_PROGRAMMING = 5 , MPModelRequest_SolverType_GUROBI_MIXED_INTEGER_PROGRAMMING = 7 , MPModelRequest_SolverType_XPRESS_MIXED_INTEGER_PROGRAMMING = 102 ,
  MPModelRequest_SolverType_CPLEX_MIXED_INTEGER_PROGRAMMING = 11 , MPModelRequest_SolverType_HIGHS_MIXED_INTEGER_PROGRAMMING = 16 , MPModelRequest_SolverType_BOP_INTEGER_PROGRAMMING = 12 , MPModelRequest_SolverType_SAT_INTEGER_PROGRAMMING = 14 ,
  MPModelRequest_SolverType_PDLP_LINEAR_PROGRAMMING = 8 , MPModelRequest_SolverType_KNAPSACK_MIXED_INTEGER_PROGRAMMING = 13
}
enum  MPSolverResponseStatus : int {
  MPSOLVER_OPTIMAL = 0 , MPSOLVER_FEASIBLE = 1 , MPSOLVER_INFEASIBLE = 2 , MPSOLVER_UNBOUNDED = 3 ,
  MPSOLVER_ABNORMAL = 4 , MPSOLVER_NOT_SOLVED = 6 , MPSOLVER_MODEL_IS_VALID = 97 , MPSOLVER_CANCELLED_BY_USER = 98 ,
  MPSOLVER_UNKNOWN_STATUS = 99 , MPSOLVER_MODEL_INVALID = 5 , MPSOLVER_MODEL_INVALID_SOLUTION_HINT = 84 , MPSOLVER_MODEL_INVALID_SOLVER_PARAMETERS = 85 ,
  MPSOLVER_SOLVER_TYPE_UNAVAILABLE = 7 , MPSOLVER_INCOMPATIBLE_OPTIONS = 113
}
enum  GScipParameters_Emphasis : int {
  GScipParameters_Emphasis_DEFAULT_EMPHASIS = 0 , GScipParameters_Emphasis_COUNTER = 1 , GScipParameters_Emphasis_CP_SOLVER = 2 , GScipParameters_Emphasis_EASY_CIP = 3 ,
  GScipParameters_Emphasis_FEASIBILITY = 4 , GScipParameters_Emphasis_HARD_LP = 5 , GScipParameters_Emphasis_OPTIMALITY = 6 , GScipParameters_Emphasis_PHASE_FEAS = 7 ,
  GScipParameters_Emphasis_PHASE_IMPROVE = 8 , GScipParameters_Emphasis_PHASE_PROOF = 9 , GScipParameters_Emphasis_GScipParameters_Emphasis_INT_MIN_SENTINEL_DO_NOT_USE_ , GScipParameters_Emphasis_GScipParameters_Emphasis_INT_MAX_SENTINEL_DO_NOT_USE_
}
enum  GScipParameters_MetaParamValue : int {
  GScipParameters_MetaParamValue_DEFAULT_META_PARAM_VALUE = 0 , GScipParameters_MetaParamValue_AGGRESSIVE = 1 , GScipParameters_MetaParamValue_FAST = 2 , GScipParameters_MetaParamValue_OFF = 3 ,
  GScipParameters_MetaParamValue_GScipParameters_MetaParamValue_INT_MIN_SENTINEL_DO_NOT_USE_ , GScipParameters_MetaParamValue_GScipParameters_MetaParamValue_INT_MAX_SENTINEL_DO_NOT_USE_
}
enum  GScipOutput_Status : int {
  GScipOutput_Status_UNKNOWN = 0 , GScipOutput_Status_USER_INTERRUPT = 1 , GScipOutput_Status_NODE_LIMIT = 2 , GScipOutput_Status_TOTAL_NODE_LIMIT = 3 ,
  GScipOutput_Status_STALL_NODE_LIMIT = 4 , GScipOutput_Status_TIME_LIMIT = 5 , GScipOutput_Status_MEM_LIMIT = 6 , GScipOutput_Status_GAP_LIMIT = 7 ,
  GScipOutput_Status_SOL_LIMIT = 8 , GScipOutput_Status_BEST_SOL_LIMIT = 9 , GScipOutput_Status_RESTART_LIMIT = 10 , GScipOutput_Status_OPTIMAL = 11 ,
  GScipOutput_Status_INFEASIBLE = 12 , GScipOutput_Status_UNBOUNDED = 13 , GScipOutput_Status_INF_OR_UNBD = 14 , GScipOutput_Status_TERMINATE = 15 ,
  GScipOutput_Status_INVALID_SOLVER_PARAMETERS = 16 , GScipOutput_Status_GScipOutput_Status_INT_MIN_SENTINEL_DO_NOT_USE_ , GScipOutput_Status_GScipOutput_Status_INT_MAX_SENTINEL_DO_NOT_USE_
}
enum  CourseSchedulingResultStatus : int {
  COURSE_SCHEDULING_RESULT_STATUS_UNSPECIFIED = 0 , SOLVER_FEASIBLE = 1 , SOLVER_OPTIMAL = 2 , SOLVER_INFEASIBLE = 3 ,
  SOLVER_MODEL_INVALID = 4 , SOLVER_NOT_SOLVED = 5 , ABNORMAL = 6 , CourseSchedulingResultStatus_INT_MIN_SENTINEL_DO_NOT_USE_ ,
  CourseSchedulingResultStatus_INT_MAX_SENTINEL_DO_NOT_USE_
}
enum  SetCoverSolutionResponse_Status : int {
  SetCoverSolutionResponse_Status_UNDEFINED = 0 , SetCoverSolutionResponse_Status_OPTIMAL = 1 , SetCoverSolutionResponse_Status_FEASIBLE = 2 , SetCoverSolutionResponse_Status_INFEASIBLE = 3 ,
  SetCoverSolutionResponse_Status_INVALID = 4 , SetCoverSolutionResponse_Status_SetCoverSolutionResponse_Status_INT_MIN_SENTINEL_DO_NOT_USE_ , SetCoverSolutionResponse_Status_SetCoverSolutionResponse_Status_INT_MAX_SENTINEL_DO_NOT_USE_
}
enum  OptionalBoolean : int {
  BOOL_UNSPECIFIED = 0 , BOOL_FALSE = 2 , BOOL_TRUE = 3 , OptionalBoolean_INT_MIN_SENTINEL_DO_NOT_USE_ ,
  OptionalBoolean_INT_MAX_SENTINEL_DO_NOT_USE_
}

Functions

template<class Point, bool check_bounds = DEBUG_MODE>
Point BinarySearch (Point x_true, Point x_false, std::function< bool(Point)> f)
template<class Point>
Point BinarySearchMidpoint (Point x, Point y)
template<class Point, class Value>
std::pair< Point, Value > ConvexMinimum (absl::Span< const Point > sorted_points, std::function< Value(Point)> f)
template<class Point, class Value>
std::pair< Point, Value > ConvexMinimum (bool is_to_the_right, std::pair< Point, Value > current_min, absl::Span< const Point > sorted_points, std::function< Value(Point)> f)
template<class Point, class Value>
std::pair< Point, Value > RangeConvexMinimum (Point begin, Point end, absl::FunctionRef< Value(Point)> f)
template<class Point, class Value>
std::pair< Point, Value > RangeConvexMinimum (std::pair< Point, Value > current_min, Point begin, Point end, absl::FunctionRef< Value(Point)> f)
std::vector< int > CountTriangles (const ::util::StaticGraph< int, int > &graph, int max_degree)
void LocalBfs (const ::util::StaticGraph< int, int > &graph, int source, int stop_after_num_nodes, std::vector< int > *visited, std::vector< int > *num_within_radius, std::vector< bool > *tmp_mask)
bool InputContainsNan (absl::Span< const std::vector< double > > input)
void MinimizeLinearAssignment (absl::Span< const std::vector< double > > cost, absl::flat_hash_map< int, int > *direct_assignment, absl::flat_hash_map< int, int > *reverse_assignment)
void MaximizeLinearAssignment (absl::Span< const std::vector< double > > cost, absl::flat_hash_map< int, int > *direct_assignment, absl::flat_hash_map< int, int > *reverse_assignment)
bool CompareKnapsackItemWithEfficiencyInDecreasingEfficiencyOrder (const KnapsackItemWithEfficiency &item1, const KnapsackItemWithEfficiency &item2)
Select next search node to expand Select next item_i to assign (using primary propagator) - Generate a new search node where item_i is in the knapsack - Check validity of this new partial solution(using propagators) - If valid
Select next search node to expand Select next item_i to add this new search node to the search Generate a new search node where item_i is not in the knapsack Check validity of this new partial solution (using propagators) - If valid
absl::StatusOr< int64_t > NChooseK (int64_t n, int64_t k)
template<typename T>
void RadixSort (absl::Span< T > values, int num_bits=sizeof(T) *8)
template<typename T>
int NumBitsForZeroTo (T max_value)
template<typename T, int radix_width, int num_passes>
void RadixSortTpl (absl::Span< T > values)
uint64_t fasthash64 (const void *buf, size_t len, uint64_t seed)
static void mix (uint64_t &a, uint64_t &b, uint64_t &c)
void FixFlagsAndEnvironmentForSwig ()
int32_t strtoint32 (absl::string_view word)
int64_t strtoint64 (absl::string_view word)
int32_t atoi32 (absl::string_view word)
int64_t atoi64 (absl::string_view word)
int64_t GetProcessMemoryUsage ()
int OrToolsMajorVersion ()
int OrToolsMinorVersion ()
int OrToolsPatchVersion ()
std::string OrToolsVersionString ()
template<class Var, class Element, class Proto, class Container>
void RealLoad (const AssignmentProto &assignment_proto, Container *const container, int(AssignmentProto::*GetSize)() const, const Proto &(AssignmentProto::*GetElem)(int) const)
template<class Var, class Element, class Proto, class Container>
void RealSave (AssignmentProto *const assignment_proto, const Container &container, Proto *(AssignmentProto::*Add)())
template<class Container, class Element>
void RealDebugString (const Container &container, std::string *const out)
void SetAssignmentFromAssignment (Assignment *target_assignment, const std::vector< IntVar * > &target_vars, const Assignment *source_assignment, const std::vector< IntVar * > &source_vars)
 NOLINT.
std::ostream & operator<< (std::ostream &out, const Assignment &assignment)
void InstallDemonProfiler (DemonProfiler *monitor)
DemonProfilerBuildDemonProfiler (Solver *solver)
void DeleteDemonProfiler (DemonProfiler *monitor)
void InstallLocalSearchProfiler (LocalSearchProfiler *monitor)
LocalSearchProfilerBuildLocalSearchProfiler (Solver *solver)
void DeleteLocalSearchProfiler (LocalSearchProfiler *monitor)
void CleanVariableOnFail (IntVar *var)
void RestoreBoolValue (IntVar *var)
void InternalSaveBooleanVarValue (Solver *const solver, IntVar *const var)
bool ContinueAtLocalOptimum (Search *search)
bool AcceptDelta (Search *search, Assignment *delta, Assignment *deltadelta)
void AcceptNeighbor (Search *search)
void AcceptUncheckedNeighbor (Search *search)
PropagationMonitorBuildTrace (Solver *s)
LocalSearchMonitorBuildLocalSearchMonitorPrimary (Solver *s)
ModelCacheBuildModelCache (Solver *solver)
PropagationMonitorBuildPrintTrace (Solver *s)
std::ostream & operator<< (std::ostream &out, const Solver *const s)
std::ostream & operator<< (std::ostream &out, const BaseObject *const o)
int64_t CpRandomSeed ()
int64_t Zero ()
 NOLINT.
int64_t One ()
 This method returns 1.
uint64_t Hash1 (uint64_t value)
 Hash functions.
uint64_t Hash1 (uint32_t value)
uint64_t Hash1 (int64_t value)
uint64_t Hash1 (int value)
uint64_t Hash1 (void *const ptr)
template<class T>
uint64_t Hash1 (const std::vector< T * > &ptrs)
uint64_t Hash1 (const std::vector< int64_t > &ptrs)
LocalSearchOperatorMakeTwoOpt (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, std::function< const std::vector< int > &(int, int)> get_incoming_neighbors=nullptr, std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors=nullptr)
 --— 2Opt --—
LocalSearchOperatorMakeRelocate (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, std::function< const std::vector< int > &(int, int)> get_incoming_neighbors=nullptr, std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors=nullptr, int64_t chain_length=1LL, bool single_path=false, const std::string &name="Relocate")
 --— Relocate --—
LocalSearchOperatorMakeExchange (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, std::function< const std::vector< int > &(int, int)> get_incoming_neighbors=nullptr, std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors=nullptr)
 --— Exchange --—
LocalSearchOperatorMakeCross (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, std::function< const std::vector< int > &(int, int)> get_incoming_neighbors=nullptr, std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors=nullptr)
 --— Cross --—
LocalSearchOperatorMakeActive (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, std::function< const std::vector< int > &(int, int)> get_incoming_neighbors=nullptr, std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors=nullptr)
 --— MakeActive --—
LocalSearchOperatorRelocateAndMakeActive (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class)
 -— RelocateAndMakeActive --—
LocalSearchOperatorExchangeAndMakeActive (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class)
LocalSearchOperatorExchangePathStartEndsAndMakeActive (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class)
LocalSearchOperatorMakeActiveAndRelocate (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class)
 --— MakeActiveAndRelocate --—
LocalSearchOperatorMakeInactive (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class)
 --— MakeInactive --—
LocalSearchOperatorRelocateAndMakeInactive (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class)
 --— RelocateAndMakeInactive --—
LocalSearchOperatorMakeChainInactive (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class)
 --— MakeChainInactive --—
LocalSearchOperatorMakeSwapActive (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class)
 --— SwapActive --—
LocalSearchOperatorMakeSwapActiveChain (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, int max_chain_size)
 --— SwapActiveChain --—
LocalSearchOperatorMakeExtendedSwapActive (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class)
 --— ExtendedSwapActive --—
LocalSearchOperatorMakeTSPOpt (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, Solver::IndexEvaluator3 evaluator, int chain_length)
 --— TSP-based operators --—
LocalSearchOperatorMakeTSPLns (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, Solver::IndexEvaluator3 evaluator, int tsp_size)
LocalSearchOperatorMakeLinKernighan (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, const Solver::IndexEvaluator3 &evaluator, bool topt)
 --— Lin-Kernighan --—
LocalSearchOperatorMakePathLns (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, int number_of_chunks, int chunk_size, bool unactive_fragments)
 --— Path-based Large Neighborhood Search --—
template<class T>
bool IsArrayConstant (const std::vector< T > &values, const T &value)
template<class T>
bool IsArrayBoolean (const std::vector< T > &values)
template<class T>
bool AreAllOnes (const std::vector< T > &values)
template<class T>
bool AreAllNull (const std::vector< T > &values)
template<class T>
bool AreAllGreaterOrEqual (const std::vector< T > &values, const T &value)
template<class T>
bool AreAllLessOrEqual (const std::vector< T > &values, const T &value)
template<class T>
bool AreAllPositive (const std::vector< T > &values)
template<class T>
bool AreAllNegative (const std::vector< T > &values)
template<class T>
bool AreAllStrictlyPositive (const std::vector< T > &values)
template<class T>
bool AreAllStrictlyNegative (const std::vector< T > &values)
template<class T>
bool IsIncreasingContiguous (const std::vector< T > &values)
template<class T>
bool IsIncreasing (const std::vector< T > &values)
template<class T>
bool IsArrayInRange (const std::vector< IntVar * > &vars, T range_min, T range_max)
bool AreAllBound (const std::vector< IntVar * > &vars)
bool AreAllBooleans (const std::vector< IntVar * > &vars)
template<class T>
bool AreAllBoundOrNull (const std::vector< IntVar * > &vars, const std::vector< T > &values)
bool AreAllBoundTo (const std::vector< IntVar * > &vars, int64_t value)
 Returns true if all variables are assigned to 'value'.
int64_t MaxVarArray (const std::vector< IntVar * > &vars)
int64_t MinVarArray (const std::vector< IntVar * > &vars)
void FillValues (const std::vector< IntVar * > &vars, std::vector< int64_t > *const values)
int64_t PosIntDivUp (int64_t e, int64_t v)
int64_t PosIntDivDown (int64_t e, int64_t v)
std::vector< int64_t > ToInt64Vector (const std::vector< int > &input)
std::string DefaultPhaseStatString (DecisionBuilder *db)
void RegisterDemon (Solver *const solver, Demon *const demon, DemonProfiler *const monitor)
void DemonProfilerAddFakeRun (DemonProfiler *const monitor, Demon *const demon, int64_t start_time, int64_t end_time, bool is_fail)
void DemonProfilerExportInformation (DemonProfiler *const monitor, const Constraint *const constraint, int64_t *const fails, int64_t *const initial_propagation_runtime, int64_t *const demon_invocations, int64_t *const total_demon_runtime, int *const demon_count)
void DemonProfilerBeginInitialPropagation (DemonProfiler *const monitor, Constraint *const constraint)
void DemonProfilerEndInitialPropagation (DemonProfiler *const monitor, Constraint *const constraint)
void LinkVarExpr (Solver *s, IntExpr *expr, IntVar *var)
ConstraintSetIsEqual (IntVar *const var, absl::Span< const int64_t > values, const std::vector< IntVar * > &vars)
ConstraintSetIsGreaterOrEqual (IntVar *const var, absl::Span< const int64_t > values, const std::vector< IntVar * > &vars)
IntExprBuildStartExpr (IntervalVar *var)
IntExprBuildDurationExpr (IntervalVar *var)
IntExprBuildEndExpr (IntervalVar *var)
IntExprBuildSafeStartExpr (IntervalVar *var, int64_t unperformed_value)
IntExprBuildSafeDurationExpr (IntervalVar *var, int64_t unperformed_value)
IntExprBuildSafeEndExpr (IntervalVar *var, int64_t unperformed_value)
std::unique_ptr< BinCapacitiesMakeBinCapacities (const std::vector< RoutingDimension * > &dimensions, const PathsMetadata &paths_metadata)
void FillPathEvaluation (absl::Span< const int64_t > path, const RoutingModel::TransitCallback2 &evaluator, std::vector< int64_t > *values)
bool SolveModelWithSat (RoutingModel *model, RoutingSearchStats *search_stats, const RoutingSearchParameters &search_parameters, const operations_research::Assignment *initial_solution, operations_research::Assignment *solution)
ConstraintMakeDifferentFromValues (Solver *solver, IntVar *var, std::vector< int64_t > values)
ConstraintMakeResourceConstraint (const RoutingModel::ResourceGroup *resource_group, const std::vector< IntVar * > *vehicle_resource_vars, RoutingModel *model)
ConstraintMakePathSpansAndTotalSlacks (const RoutingDimension *dimension, std::vector< IntVar * > spans, std::vector< IntVar * > total_slacks)
ConstraintMakeRouteConstraint (RoutingModel *model, std::vector< IntVar * > route_cost_vars, std::function< std::optional< int64_t >(const std::vector< int64_t > &)> route_evaluator)
ConstraintMakeGlobalVehicleBreaksConstraint (Solver *solver, const RoutingDimension *dimension)
ConstraintMakeNumActiveVehiclesCapacityConstraint (Solver *solver, std::vector< IntVar * > transit_vars, std::vector< IntVar * > active_vars, std::vector< IntVar * > vehicle_active_vars, std::vector< int64_t > vehicle_capacities, int max_active_vehicles, bool enforce_active_vehicles)
DecisionBuilderMakeSetValuesFromTargets (Solver *solver, std::vector< IntVar * > variables, std::vector< int64_t > targets)
DecisionBuilderMakeSetCumulsFromLocalDimensionCosts (Solver *solver, LocalDimensionCumulOptimizer *lp_optimizer, LocalDimensionCumulOptimizer *mp_optimizer, bool optimize_and_pack, std::vector< RoutingModel::RouteDimensionTravelInfo > dimension_travel_info_per_route)
DecisionBuilderMakeSetCumulsFromGlobalDimensionCosts (Solver *solver, GlobalDimensionCumulOptimizer *global_optimizer, GlobalDimensionCumulOptimizer *global_mp_optimizer, bool optimize_and_pack=false, std::vector< RoutingModel::RouteDimensionTravelInfo > dimension_travel_info_per_route={})
 Variant based on global optimizers, handling all routes together.
DecisionBuilderMakeRestoreDimensionValuesForUnchangedRoutes (RoutingModel *model)
bool PropagateTransitAndSpan (int path, DimensionValues &dimension_values)
template<typename T>
void DefragmentRanges (std::vector< T > &mutable_input, CommittableArray< IndexRange > &ranges, std::vector< T > &temp_container)
IntVarLocalSearchFilterMakeRouteConstraintFilter (const RoutingModel &routing_model)
 Returns a filter tracking route constraints.
IntVarLocalSearchFilterMakeMaxActiveVehiclesFilter (const RoutingModel &routing_model)
 Returns a filter ensuring that max active vehicles constraints are enforced.
IntVarLocalSearchFilterMakeActiveNodeGroupFilter (const RoutingModel &routing_model)
IntVarLocalSearchFilterMakeOrderedActivityGroupFilter (const RoutingModel &routing_model)
IntVarLocalSearchFilterMakeNodeDisjunctionFilter (const RoutingModel &routing_model, bool filter_cost)
 Returns a filter ensuring that node disjunction constraints are enforced.
IntVarLocalSearchFilterMakeVehicleAmortizedCostFilter (const RoutingModel &routing_model)
 Returns a filter computing vehicle amortized costs.
IntVarLocalSearchFilterMakeSameVehicleCostFilter (const RoutingModel &routing_model)
 Returns a filter computing same vehicle costs.
IntVarLocalSearchFilterMakeTypeRegulationsFilter (const RoutingModel &routing_model)
 Returns a filter ensuring type regulation constraints are enforced.
bool FillDimensionValuesFromRoutingDimension (int path, int64_t capacity, int64_t span_upper_bound, absl::Span< const DimensionValues::Interval > cumul_of_node, absl::Span< const DimensionValues::Interval > slack_of_node, absl::AnyInvocable< int64_t(int64_t, int64_t) const > evaluator, DimensionValues &dimension_values)
void FillPrePostVisitValues (int path, const DimensionValues &dimension_values, std::optional< absl::AnyInvocable< int64_t(int64_t, int64_t) const > > pre_travel_evaluator, std::optional< absl::AnyInvocable< int64_t(int64_t, int64_t) const > > post_travel_evaluator, PrePostVisitValues &visit_values)
bool PropagateLightweightVehicleBreaks (int path, DimensionValues &dimension_values, absl::Span< const std::pair< int64_t, int64_t > > interbreaks)
IntVarLocalSearchFilterMakePathCumulFilter (const RoutingDimension &dimension, bool propagate_own_objective_value, bool filter_objective_cost, bool may_use_optimizers)
 Returns a filter handling dimension costs and constraints.
void AppendLightWeightDimensionFilters (const PathState *path_state, const std::vector< RoutingDimension * > &dimensions, std::vector< LocalSearchFilterManager::FilterEvent > *filters)
void AppendDimensionCumulFilters (const std::vector< RoutingDimension * > &dimensions, const RoutingSearchParameters &parameters, bool filter_objective_cost, bool use_chain_cumul_filter, std::vector< LocalSearchFilterManager::FilterEvent > *filters)
LocalSearchFilterMakePickupDeliveryFilter (const RoutingModel &routing_model, const PathState *path_state, absl::Span< const PickupDeliveryPair > pairs, const std::vector< RoutingModel::PickupAndDeliveryPolicy > &vehicle_policies)
LocalSearchFilterMakeVehicleVarFilter (const RoutingModel &routing_model, const PathState *path_state)
 Returns a filter checking that vehicle variable domains are respected.
IntVarLocalSearchFilterMakeCumulBoundsPropagatorFilter (const RoutingDimension &dimension)
 Returns a filter handling dimension cumul bounds.
IntVarLocalSearchFilterMakeGlobalLPCumulFilter (GlobalDimensionCumulOptimizer *lp_optimizer, GlobalDimensionCumulOptimizer *mp_optimizer, bool filter_objective_cost)
 Returns a filter checking global linear constraints and costs.
LocalSearchFilterMakeResourceAssignmentFilter (LocalDimensionCumulOptimizer *lp_optimizer, LocalDimensionCumulOptimizer *mp_optimizer, bool propagate_own_objective_value, bool filter_objective_cost)
IntVarLocalSearchFilterMakeCPFeasibilityFilter (RoutingModel *routing_model)
 Returns a filter checking the current solution using CP propagation.
LocalSearchFilterMakePathStateFilter (Solver *solver, std::unique_ptr< PathState > path_state, const std::vector< IntVar * > &nexts)
LocalSearchFilterMakeDimensionFilter (Solver *solver, std::unique_ptr< DimensionChecker > checker, absl::string_view dimension_name)
LocalSearchFilterMakeLightVehicleBreaksFilter (Solver *solver, std::unique_ptr< LightVehicleBreaksChecker > checker, absl::string_view dimension_name)
LocalSearchFilterMakePathEnergyCostFilter (Solver *solver, std::unique_ptr< PathEnergyCostChecker > checker, absl::string_view dimension_name)
DecisionBuilderMakeRuinAndRecreateDecisionBuilder (const RoutingSearchParameters &parameters, RoutingModel *model, std::mt19937 *rnd, const Assignment *assignment, std::function< bool()> stop_search, LocalSearchFilterManager *filter_manager)
DecisionBuilderMakePerturbationDecisionBuilder (const RoutingSearchParameters &parameters, RoutingModel *model, std::mt19937 *rnd, const Assignment *assignment, std::function< bool()> stop_search, LocalSearchFilterManager *filter_manager)
std::unique_ptr< NeighborAcceptanceCriterionMakeNeighborAcceptanceCriterion (const RoutingModel &model, const AcceptanceStrategy &acceptance_strategy, const NeighborAcceptanceCriterion::SearchState &final_search_state, std::mt19937 *rnd)
std::pair< double, double > GetSimulatedAnnealingTemperatures (const RoutingModel &model, const SimulatedAnnealingAcceptanceStrategy &sa_params, std::mt19937 *rnd)
RecreateParameters::ParametersCase GetParameterCaseForRecreateHeuristic (FirstSolutionStrategy::Value recreate_heuristic)
std::vector< RecreateParameters::ParametersCaseGetSupportedRecreateParametersCases ()
std::string GetRecreateParametersName (RecreateParameters::ParametersCase parameters_case)
std::vector< SlopeAndYInterceptPiecewiseLinearFunctionToSlopeAndYIntercept (const FloatSlopePiecewiseLinearFunction &pwl_function, int index_start, int index_end)
std::vector< bool > SlopeAndYInterceptToConvexityRegions (absl::Span< const SlopeAndYIntercept > slope_and_y_intercept)
bool ComputeVehicleToResourceClassAssignmentCosts (int v, double solve_duration_ratio, const RoutingModel::ResourceGroup &resource_group, const util_intops::StrongVector< RoutingModel::ResourceClassIndex, absl::flat_hash_set< int > > &ignored_resources_per_class, const std::function< int64_t(int64_t)> &next_accessor, const std::function< int64_t(int64_t, int64_t)> &transit_accessor, bool optimize_vehicle_costs, LocalDimensionCumulOptimizer *lp_optimizer, LocalDimensionCumulOptimizer *mp_optimizer, std::vector< int64_t > *assignment_costs, std::vector< std::vector< int64_t > > *cumul_values, std::vector< std::vector< int64_t > > *break_values)
int64_t ComputeBestVehicleToResourceAssignment (absl::Span< const int > vehicles, const util_intops::StrongVector< RoutingModel::ResourceClassIndex, std::vector< int > > &resource_indices_per_class, const util_intops::StrongVector< RoutingModel::ResourceClassIndex, absl::flat_hash_set< int > > &ignored_resources_per_class, std::function< const std::vector< int64_t > *(int)> vehicle_to_resource_class_assignment_costs, std::vector< int > *resource_indices)
std::string Int64ToStr (int64_t number)
std::string DomainToString (const ::google::protobuf::RepeatedField< int64_t > *domain)
std::string VariableToString (std::pair< sat::IntegerVariableProto, int > &variable_pair, const sat::CpSolverResponse &response_)
std::string ConstraintToString (const sat::ConstraintProto &constraint, const sat::CpModelProto &model_, bool show_enforcement=true)
std::string VariablesToString (absl::flat_hash_map< std::string, std::pair< sat::IntegerVariableProto, int > > &variables, absl::flat_hash_map< std::string, std::vector< int > > &variable_instances, absl::flat_hash_map< std::string, absl::flat_hash_set< std::string > > &variable_childs, const sat::CpSolverResponse &response_, absl::string_view variable, std::string prefix="")
LocalSearchOperatorMakeRelocateNeighbors (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, std::function< const std::vector< int > &(int, int)> get_incoming_neighbors, std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors, RoutingTransitCallback2 arc_evaluator)
LocalSearchOperatorMakeRelocateNeighbors (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, RoutingTransitCallback2 arc_evaluator)
LocalSearchOperatorMakeTwoOptWithShortestPath (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, std::vector< std::vector< int64_t > > alternative_sets, RoutingTransitCallback2 arc_evaluator)
LocalSearchOperatorMakeSwapActiveToShortestPath (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, std::vector< std::vector< int64_t > > alternative_sets, RoutingTransitCallback2 arc_evaluator)
LocalSearchOperatorMakePairActive (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, const std::vector< PickupDeliveryPair > &pairs)
LocalSearchOperatorMakePairInactive (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, const std::vector< PickupDeliveryPair > &pairs)
LocalSearchOperatorMakePairRelocate (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, const std::vector< PickupDeliveryPair > &pairs)
LocalSearchOperatorMakeGroupPairAndRelocate (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, std::function< const std::vector< int > &(int, int)> get_incoming_neighbors, std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors, const std::vector< PickupDeliveryPair > &pairs)
LocalSearchOperatorMakeGroupPairAndRelocate (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, const std::vector< PickupDeliveryPair > &pairs)
LocalSearchOperatorMakeLightPairRelocate (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, std::function< const std::vector< int > &(int, int)> get_incoming_neighbors, std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors, const std::vector< PickupDeliveryPair > &pairs, std::function< bool(int64_t)> force_lifo)
LocalSearchOperatorMakeLightPairRelocate (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, const std::vector< PickupDeliveryPair > &pairs, std::function< bool(int64_t)> force_lifo)
LocalSearchOperatorMakePairExchange (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, std::function< const std::vector< int > &(int, int)> get_incoming_neighbors, std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors, const std::vector< PickupDeliveryPair > &pairs)
LocalSearchOperatorMakePairExchange (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, const std::vector< PickupDeliveryPair > &pairs)
LocalSearchOperatorMakePairExchangeRelocate (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, const std::vector< PickupDeliveryPair > &pairs)
LocalSearchOperatorMakeIndexPairSwapActive (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, const std::vector< PickupDeliveryPair > &pairs)
LocalSearchOperatorMakeRelocateExpensiveChain (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, int num_arcs_to_consider, std::function< int64_t(int64_t, int64_t, int64_t)> arc_cost_for_path_start)
LocalSearchOperatorMakeRelocateSubtrip (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, std::function< const std::vector< int > &(int, int)> get_incoming_neighbors, std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors, absl::Span< const PickupDeliveryPair > pairs)
LocalSearchOperatorMakeRelocateSubtrip (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, absl::Span< const PickupDeliveryPair > pairs)
LocalSearchOperatorMakeExchangeSubtrip (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, std::function< const std::vector< int > &(int, int)> get_incoming_neighbors, std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors, absl::Span< const PickupDeliveryPair > pairs)
LocalSearchOperatorMakeExchangeSubtrip (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, absl::Span< const PickupDeliveryPair > pairs)
template<bool swap_first>
LocalSearchOperatorMakePairNodeSwapActive (Solver *solver, const std::vector< IntVar * > &vars, const std::vector< IntVar * > &secondary_vars, std::function< int(int64_t)> start_empty_path_class, const std::vector< PickupDeliveryPair > &pairs)
RoutingModelParameters DefaultRoutingModelParameters ()
RoutingSearchParameters DefaultRoutingSearchParameters ()
RoutingSearchParameters DefaultSecondaryRoutingSearchParameters ()
std::string FindErrorInRoutingSearchParameters (const RoutingSearchParameters &search_parameters)
std::vector< std::string > FindErrorsInRoutingSearchParameters (const RoutingSearchParameters &search_parameters)
std::vector< LocalCheapestInsertionParameters::InsertionSortingPropertyGetLocalCheapestInsertionSortingProperties (absl::Span< const int > lci_insertion_sorting_properties)
void DisableAllLocalSearchOperators (RoutingSearchParameters::LocalSearchNeighborhoodOperators *operators)
const AssignmentSolveWithAlternativeSolvers (RoutingModel *primary_model, const std::vector< RoutingModel * > &alternative_models, const RoutingSearchParameters &parameters, int max_non_improving_iterations)
const AssignmentSolveFromAssignmentWithAlternativeSolvers (const Assignment *assignment, RoutingModel *primary_model, const std::vector< RoutingModel * > &alternative_models, const RoutingSearchParameters &parameters, int max_non_improving_iterations)
const AssignmentSolveFromAssignmentWithAlternativeSolversAndParameters (const Assignment *assignment, RoutingModel *primary_model, const RoutingSearchParameters &primary_parameters, const std::vector< RoutingModel * > &alternative_models, const std::vector< RoutingSearchParameters > &alternative_parameters, int max_non_improving_iterations)
FirstSolutionStrategy::Value AutomaticFirstSolutionStrategy (bool has_pickup_deliveries, bool has_node_precedences, bool has_single_vehicle_node)
std::vector< int64_t > ComputeVehicleEndChainStarts (const RoutingModel &model)
DecisionBuilderMakeSweepDecisionBuilder (RoutingModel *model, bool check_assignment)
DecisionBuilderMakeAllUnperformed (RoutingModel *model)
 DEFINE_STRONG_INDEX_TYPE (RoutingNodeIndex)
 DEFINE_STRONG_INDEX_TYPE (RoutingCostClassIndex)
 DEFINE_STRONG_INDEX_TYPE (RoutingDimensionIndex)
 DEFINE_STRONG_INDEX_TYPE (RoutingDisjunctionIndex)
 DEFINE_STRONG_INDEX_TYPE (RoutingVehicleClassIndex)
 DEFINE_STRONG_INDEX_TYPE (RoutingResourceClassIndex)
bool FindMostExpensiveArcsOnRoute (int num_arcs, int64_t start, const std::function< int64_t(int64_t)> &next_accessor, const std::function< bool(int64_t)> &is_end, const std::function< int64_t(int64_t, int64_t, int64_t)> &arc_cost_for_route_start, std::vector< std::pair< int64_t, int > > *most_expensive_arc_starts_and_ranks, std::pair< int, int > *first_expensive_arc_indices)
BaseAssignVariables::Mode ChooseMode (Solver::IntValueStrategy val_str)
template<typename NodeIndex, typename DistanceType>
std::pair< DistanceType, std::vector< NodeIndex > > SimpleOneToOneShortestPath (NodeIndex source, NodeIndex destination, absl::Span< const NodeIndex > tails, absl::Span< const NodeIndex > heads, absl::Span< const DistanceType > lengths, DistanceType limit=std::numeric_limits< DistanceType >::max())
template<typename CostType, typename WeightFunctionType, typename GraphType>
absl::StatusOr< std::vector< std::pair< typename GraphType::NodeIndex, typename GraphType::NodeIndex > > > ComputeMinimumWeightMatching (const GraphType &graph, const WeightFunctionType &weight)
template<typename WeightFunctionType, typename GraphType>
absl::StatusOr< std::vector< std::pair< typename GraphType::NodeIndex, typename GraphType::NodeIndex > > > ComputeMinimumWeightMatchingWithMIP (const GraphType &graph, const WeightFunctionType &weight)
void FindCliques (std::function< bool(int, int)> graph, int node_count, std::function< bool(const std::vector< int > &)> callback)
void CoverArcsByCliques (std::function< bool(int, int)> graph, int node_count, std::function< bool(const std::vector< int > &)> callback)
std::vector< Bitset64< int64_t > > ComputeDagConnectivity (absl::Span< const std::pair< int, int > > arcs, bool *error_was_cyclic, std::vector< int > *error_cycle_out)
std::vector< Bitset64< int64_t > > ComputeDagConnectivityOrDie (absl::Span< const std::pair< int, int > > arcs)
PathWithLength ConstrainedShortestPathsOnDag (const int num_nodes, absl::Span< const ArcWithLengthAndResources > arcs_with_length_and_resources, int source, int destination, const std::vector< double > &max_resources)
PathWithLength ShortestPathsOnDag (const int num_nodes, absl::Span< const ArcWithLength > arcs_with_length, const int source, const int destination)
std::vector< PathWithLengthKShortestPathsOnDag (const int num_nodes, absl::Span< const ArcWithLength > arcs_with_length, const int source, const int destination, const int path_count)
template<class GraphType, typename ArcLengths>
absl::Status TopologicalOrderIsValid (const GraphType &graph, absl::Span< const typename GraphType::NodeIndex > topological_order)
template<typename GraphType>
std::vector< typename GraphType::NodeIndex > NodePathImpliedBy (absl::Span< const typename GraphType::ArcIndex > arc_path, const GraphType &graph)
template<class GraphType>
void CheckNodeIsValid (typename GraphType::NodeIndex node, const GraphType &graph)
template<class GraphType>
absl::Status TopologicalOrderIsValid (const GraphType &graph, absl::Span< const typename GraphType::NodeIndex > topological_order)
template<typename Graph>
bool IsEulerianGraph (const Graph &graph, bool assume_connectivity=true)
template<typename NodeIndex, typename Graph>
bool IsSemiEulerianGraph (const Graph &graph, std::vector< NodeIndex > *odd_nodes, bool assume_connectivity=true)
template<typename NodeIndex, typename Graph>
std::vector< NodeIndexBuildEulerianPathFromNode (const Graph &graph, NodeIndex root)
template<typename NodeIndex, typename Graph>
std::vector< NodeIndexBuildEulerianTourFromNode (const Graph &graph, NodeIndex root, bool assume_connectivity=true)
template<typename Graph>
std::vector< typename Graph::NodeIndexBuildEulerianTour (const Graph &graph, bool assume_connectivity=true)
template<typename Graph>
std::vector< typename Graph::NodeIndexBuildEulerianPath (const Graph &graph, bool assume_connectivity=true)
template<typename CostType, typename CostFunction>
HamiltonianPathSolver< CostType, CostFunction > MakeHamiltonianPathSolver (int num_nodes, CostFunction cost)
template<class GraphType>
KShortestPaths< GraphType > YenKShortestPaths (const GraphType &graph, const std::vector< PathDistance > &arc_lengths, typename GraphType::NodeIndex source, typename GraphType::NodeIndex destination, unsigned k)
template<typename Graph>
std::vector< typename Graph::ArcIndexBuildKruskalMinimumSpanningTreeFromSortedArcs (const Graph &graph, absl::Span< const typename Graph::ArcIndex > sorted_arcs)
template<typename Graph, typename ArcComparator>
std::vector< typename Graph::ArcIndexBuildKruskalMinimumSpanningTree (const Graph &graph, const ArcComparator &arc_comparator)
template<typename Graph, typename ArcValue>
std::vector< typename Graph::ArcIndexBuildPrimMinimumSpanningTree (const Graph &graph, const ArcValue &arc_value)
std::vector< bool > BipartiteMinimumVertexCover (const std::vector< std::vector< int > > &left_to_right_arcs, int num_right)
template<class DistanceType>
std::ostream & operator<< (std::ostream &out, DistanceAndParentArc< DistanceType > distance_and_parent_arc)
template<class DistanceType, class Graph, class ArcLengthFunctor, class SettledNodeCallbackType>
std::vector< absl::flat_hash_map< int, DistanceAndParentArc< DistanceType > > > MultiDijkstra (const Graph &graph, ArcLengthFunctor arc_length_functor, const std::vector< std::vector< int > > &source_sets, SettledNodeCallbackType settled_node_callback)
template<typename Graph>
absl::StatusOr< RootedTree< typename Graph::NodeType > > RootedTreeFromGraph (typename Graph::NodeType root, const Graph &graph, std::vector< typename Graph::NodeType > *topological_order=nullptr, std::vector< typename Graph::NodeType > *depths=nullptr)
template<typename Graph>
absl::StatusOr< RootedTree< typename Graph::NodeIndex > > RootedTreeFromGraph (const typename Graph::NodeIndex root, const Graph &graph, std::vector< typename Graph::NodeIndex > *const topological_order, std::vector< typename Graph::NodeIndex > *const depths)
template<class GraphType>
void GetGraphNodes (const GraphType &graph, std::vector< typename GraphType::NodeIndex > *nodes)
template<class GraphType>
void GetGraphNodesFromGraph (const GraphType &graph, std::vector< typename GraphType::NodeIndex > *nodes)
template<class GraphType>
void ComputeOneToAllShortestPaths (const GraphType &graph, const std::vector< PathDistance > &arc_lengths, typename GraphType::NodeIndex source, GenericPathContainer< GraphType > *const path_container)
template<class GraphType>
void ComputeOneToManyShortestPaths (const GraphType &graph, const std::vector< PathDistance > &arc_lengths, typename GraphType::NodeIndex source, const std::vector< typename GraphType::NodeIndex > &destinations, GenericPathContainer< GraphType > *const path_container)
template<class GraphType>
std::vector< typename GraphType::NodeIndex > ComputeOneToOneShortestPath (const GraphType &graph, const std::vector< PathDistance > &arc_lengths, typename GraphType::NodeIndex source, typename GraphType::NodeIndex destination)
template<class GraphType>
void ComputeManyToAllShortestPathsWithMultipleThreads (const GraphType &graph, const std::vector< PathDistance > &arc_lengths, const std::vector< typename GraphType::NodeIndex > &sources, int num_threads, GenericPathContainer< GraphType > *const path_container)
template<class GraphType>
void ComputeAllToAllShortestPathsWithMultipleThreads (const GraphType &graph, const std::vector< PathDistance > &arc_lengths, int num_threads, GenericPathContainer< GraphType > *const path_container)
template<class GraphType>
void ComputeManyToManyShortestPathsWithMultipleThreads (const GraphType &graph, const std::vector< PathDistance > &arc_lengths, const std::vector< typename GraphType::NodeIndex > &sources, const std::vector< typename GraphType::NodeIndex > &destinations, int num_threads, GenericPathContainer< GraphType > *const paths)
void ConvertFlowModelToDimacs (const FlowModelProto &flow_model, std::string *dimacs)
bool ConvertDimacsToFlowModel (absl::string_view file, FlowModelProto *flow_model)
void SolveMinCostFlow (const FlowModelProto &flow_model, double *loading_time, double *solving_time)
template<typename GraphType>
void SolveMaxFlow (const FlowModelProto &flow_model, double *loading_time, double *solving_time, std::function< void(GraphType *graph)> configure_graph_options=nullptr)
testing::Matcher< std::string > EmptyOrGurobiLicenseWarning ()
testing::Matcher< std::string > EmptyOrGurobiLicenseWarningIfGurobi (const bool is_gurobi)
MPSolver::ResultStatus GlopToMPSolverResultStatus (glop::ProblemStatus s)
MPSolver::BasisStatus GlopToMPSolverVariableStatus (glop::VariableStatus s)
glop::VariableStatus MPSolverToGlopVariableStatus (MPSolver::BasisStatus s)
MPSolver::BasisStatus GlopToMPSolverConstraintStatus (glop::ConstraintStatus s)
glop::ConstraintStatus MPSolverToGlopConstraintStatus (MPSolver::BasisStatus s)
void GLPKGatherInformationCallback (glp_tree *tree, void *info)
bool GurobiIsCorrectlyInstalled ()
absl::StatusOr< GRBenv * > GetGurobiEnv ()
std::string GurobiParamInfoForLogging (GRBenv *grb, bool one_liner_output)
std::ostream & operator<< (std::ostream &stream, const LinearExpr &linear_expr)
LinearExpr operator+ (LinearExpr lhs, const LinearExpr &rhs)
LinearExpr operator- (LinearExpr lhs, const LinearExpr &rhs)
LinearExpr operator* (LinearExpr lhs, double rhs)
LinearExpr operator/ (LinearExpr lhs, double rhs)
LinearExpr operator* (double lhs, LinearExpr rhs)
LinearRange operator<= (const LinearExpr &lhs, const LinearExpr &rhs)
LinearRange operator== (const LinearExpr &lhs, const LinearExpr &rhs)
LinearRange operator>= (const LinearExpr &lhs, const LinearExpr &rhs)
bool SolverTypeIsMip (MPModelRequest::SolverType solver_type)
absl::string_view ToString (MPSolver::OptimizationProblemType optimization_problem_type)
bool AbslParseFlag (const absl::string_view text, MPSolver::OptimizationProblemType *solver_type, std::string *error)
bool MPSolverResponseStatusIsRpcError (MPSolverResponseStatus status)
bool SolverTypeIsMip (MPSolver::OptimizationProblemType solver_type)
std::ostream & operator<< (std::ostream &os, MPSolver::OptimizationProblemType optimization_problem_type)
std::ostream & operator<< (std::ostream &os, MPSolver::ResultStatus status)
std::string AbslUnparseFlag (MPSolver::OptimizationProblemType solver_type)
std::string ToString (MPCallbackEvent event)
absl::StatusOr< std::string > ExportModelAsLpFormat (const MPModelProto &model, const MPModelExportOptions &options)
absl::StatusOr< std::string > ExportModelAsMpsFormat (const MPModelProto &model, const MPModelExportOptions &options)
absl::Status WriteModelToMpsFile (absl::string_view filename, const MPModelProto &model, const MPModelExportOptions &options)
std::string FindErrorInMPModelProto (const MPModelProto &model, double abs_value_threshold, const bool accept_trivially_infeasible_bounds)
std::optional< LazyMutableCopy< MPModelProto > > ExtractValidMPModelOrPopulateResponseStatus (const MPModelRequest &request, MPSolutionResponse *response)
std::optional< LazyMutableCopy< MPModelProto > > GetMPModelOrPopulateResponse (LazyMutableCopy< MPModelRequest > &request, MPSolutionResponse *response)
std::string FindFeasibilityErrorInSolutionHint (const MPModelProto &model, double tolerance)
std::string FindErrorInMPModelDeltaProto (const MPModelDeltaProto &delta, const MPModelProto &model)
void MergeMPConstraintProtoExceptTerms (const MPConstraintProto &from, MPConstraintProto *to)
void ApplyVerifiedMPModelDelta (const MPModelDeltaProto &delta, MPModelProto *model)
MPSolutionResponse GlopSolveProto (LazyMutableCopy< MPModelRequest > request, std::atomic< bool > *interrupt_solve, std::function< void(const std::string &)> logging_callback)
std::string GlopSolverVersion ()
absl::Status SetSolverSpecificParameters (absl::string_view parameters, GRBenv *gurobi)
absl::StatusOr< MPSolutionResponseGurobiSolveProto (LazyMutableCopy< MPModelRequest > request, GRBenv *gurobi_env)
absl::Status SetSolverSpecificParameters (const std::string &parameters, Highs &highs)
absl::StatusOr< MPSolutionResponseHighsSolveProto (LazyMutableCopy< MPModelRequest > request, HighsSolveInfo *solve_info)
absl::StatusOr< MPSolutionResponsePdlpSolveProto (LazyMutableCopy< MPModelRequest > request, const bool relax_integer_variables, const std::atomic< bool > *interrupt_solve)
bool AreBoundsValid (Fractional lower_bound, Fractional upper_bound)
MPSolutionResponse ConvertStatusOrMPSolutionResponse (bool log_error, absl::StatusOr< MPSolutionResponse > response)
template<typename P>
std::string EncodeParametersAsString (const P &parameters)
MPSolutionResponse SatSolveProtoInternal (LazyMutableCopy< MPModelRequest > request, sat::Model *sat_model, sat::CpSolverResponse *cp_response, std::function< void(const MPSolution &)> solution_callback)
MPSolutionResponse SatSolveProto (LazyMutableCopy< MPModelRequest > request, std::atomic< bool > *interrupt_solve, std::function< void(const std::string &)> logging_callback, std::function< void(const MPSolution &)> solution_callback, std::function< void(const double)> best_bound_callback)
std::string SatSolverVersion ()
glop::ProblemStatus ApplyMipPresolveSteps (const glop::GlopParameters &glop_params, MPModelProto *model, std::vector< std::unique_ptr< glop::Preprocessor > > *for_postsolve, SolverLogger *logger)
absl::Status LegacyScipSetSolverSpecificParameters (absl::string_view parameters, SCIP *scip)
std::string FindErrorInMPModelForScip (const MPModelProto &model, SCIP *scip)
absl::StatusOr< MPSolutionResponseScipSolveProto (LazyMutableCopy< MPModelRequest > request)
bool LinearConstraintIsViolated (const ScipConstraintHandlerContext &context, const LinearRange &constraint)
ScipSeparationResult RunSeparation (internal::ScipCallbackRunner *runner, const ScipConstraintHandlerContext &context, absl::Span< SCIP_CONS * > constraints, bool is_integral)
template<typename Constraint>
void RegisterConstraintHandler (ScipConstraintHandler< Constraint > *handler, SCIP *scip)
template<typename ConstraintData>
void AddCallbackConstraint (SCIP *scip, ScipConstraintHandler< ConstraintData > *handler, const std::string &constraint_name, const ConstraintData *constraint_data, const ScipCallbackConstraintOptions &options)
template<typename ConstraintData>
void RegisterConstraintHandler (ScipConstraintHandler< ConstraintData > *handler, SCIP *scip)
MPSolutionResponse SolveMPModel (LazyMutableCopy< MPModelRequest > request, const SolveInterrupter *absl_nullable interrupter)
bool SolverTypeSupportsInterruption (const MPModelRequest::SolverType solver)
std::string MPModelRequestLoggingInfo (const MPModelRequest &request)
std::string getSolverVersion (XPRSprob const &prob)
bool readParameter (XPRSprob const &prob, std::string const &name, std::string const &value)
void printError (const XPRSprob &mLp, int line)
void XPRS_CC XpressIntSolCallbackImpl (XPRSprob cbprob, void *cbdata)
void XPRS_CC optimizermsg (XPRSprob prob, void *data, const char *sMsg, int nLen, int nMsgLvl)
int getnumcols (const XPRSprob &mLp)
int getnumrows (const XPRSprob &mLp)
int getitcnt (const XPRSprob &mLp)
int getnodecnt (const XPRSprob &mLp)
int setobjoffset (const XPRSprob &mLp, double value)
void addhint (const XPRSprob &mLp, int length, const double solval[], const int colind[])
void interruptXPRESS (XPRSprob &xprsProb, CUSTOM_INTERRUPT_REASON reason)
static int MPSolverToXpressBasisStatus (MPSolver::BasisStatus mpsolver_basis_status)
static MPSolver::BasisStatus XpressToMPSolverBasisStatus (int xpress_basis_status)
static std::map< std::string, int > & getMapStringControls ()
static std::map< std::string, int > & getMapDoubleControls ()
static std::map< std::string, int > & getMapIntControls ()
static std::map< std::string, int > & getMapInt64Controls ()
std::vector< int > XpressBasisStatusesFrom (const std::vector< MPSolver::BasisStatus > &statuses)
template<class Container>
void splitMyString (const std::string &str, Container &cont, char delim=' ')
bool stringToCharPtr (const std::string &var, const char **out)
absl::StatusOr< MPModelProtoModelProtoFromLpFormat (absl::string_view model)
absl::StatusOr< glop::DenseRowParseSolFile (absl::string_view file_name, const glop::LinearProgram &model)
absl::StatusOr< MPSolutionResponseParseSolFile (absl::string_view file_name, const MPModelProto &model)
absl::StatusOr< glop::DenseRowParseSolString (const std::string &solution, const glop::LinearProgram &model)
absl::StatusOr< MPSolutionResponseParseSolString (const std::string &solution, const MPModelProto &model)
const GScipVariableOptionsDefaultGScipVariableOptions ()
const GScipConstraintOptionsDefaultGScipConstraintOptions ()
SCIP_RESULT ConvertGScipCallbackResult (const GScipCallbackResult result)
int ConstraintHandlerResultPriority (const GScipCallbackResult result, const ConstraintHandlerCallbackType callback_type)
GScipCallbackResult MergeConstraintHandlerResults (const GScipCallbackResult result1, const GScipCallbackResult result2, const ConstraintHandlerCallbackType callback_type)
SCIP_RETCODE DropAllEvents (GScipEventHandler &handler)
GScipLinearExpr GScipDifference (GScipLinearExpr left, const GScipLinearExpr &right)
GScipLinearExpr GScipNegate (GScipLinearExpr expr)
GScipLinearRange GScipLe (const GScipLinearExpr left, const GScipLinearExpr &right)
absl::Status GScipCreateAbs (GScip *gscip, SCIP_Var *x, SCIP_Var *abs_x, absl::string_view name)
absl::Status GScipCreateMaximum (GScip *gscip, const GScipLinearExpr &resultant, absl::Span< const GScipLinearExpr > terms, absl::string_view name)
absl::Status GScipCreateMinimum (GScip *gscip, const GScipLinearExpr &resultant, absl::Span< const GScipLinearExpr > terms, absl::string_view name)
absl::Status GScipAddQuadraticObjectiveTerm (GScip *gscip, std::vector< SCIP_Var * > quadratic_variables1, std::vector< SCIP_Var * > quadratic_variables2, std::vector< double > quadratic_coefficients, absl::string_view name)
absl::Status GScipCreateIndicatorRange (GScip *gscip, const GScipIndicatorRangeConstraint &indicator_range, absl::string_view name, const GScipConstraintOptions &options)
void GScipSetTimeLimit (absl::Duration time_limit, GScipParameters *parameters)
absl::Duration GScipTimeLimit (const GScipParameters &parameters)
bool GScipTimeLimitSet (const GScipParameters &parameters)
void GScipSetMaxNumThreads (int num_threads, GScipParameters *parameters)
int GScipMaxNumThreads (const GScipParameters &parameters)
bool GScipMaxNumThreadsSet (const GScipParameters &parameters)
void GScipSetLogLevel (GScipParameters *parameters, int log_level)
int GScipLogLevel (const GScipParameters &parameters)
bool GScipLogLevelSet (const GScipParameters &parameters)
void GScipSetOutputEnabled (GScipParameters *parameters, bool output_enabled)
bool GScipOutputEnabled (const GScipParameters &parameters)
bool GScipOutputEnabledSet (const GScipParameters &parameters)
void GScipSetRandomSeed (GScipParameters *parameters, int random_seed)
int GScipRandomSeed (const GScipParameters &parameters)
bool GScipRandomSeedSet (const GScipParameters &parameters)
void GScipSetCatchCtrlC (const bool catch_ctrl_c, GScipParameters *const parameters)
bool GScipCatchCtrlC (const GScipParameters &parameters)
bool GScipCatchCtrlCSet (const GScipParameters &parameters)
void DisableAllCutsExceptUserDefined (GScipParameters *parameters)
GScipParameters TestGScipParameters ()
std::string SolutionToString (const GScipSolution &solution)
bool SolutionsAlmostEqual (const GScipSolution &left, const GScipSolution &right, const double tolerance)
testing::Matcher< GScipSolutionGScipSolutionEquals (const GScipSolution &rhs)
testing::Matcher< GScipSolutionGScipSolutionAlmostEquals (const GScipSolution &rhs, double tolerance)
void AssertOptimalWithBestSolution (const GScipResult &actual_result, const double expected_objective_value, const GScipSolution &expected_solution, const double tolerance)
void AssertOptimalWithPartialBestSolution (const GScipResult &actual_result, const double expected_objective_value, const GScipSolution &expected_solution, const double tolerance)
void ParseAndSolve (const std::string &filename, absl::string_view solver, const std::string &params)
::absl::Status PortableFileSetContents (absl::string_view file_name, absl::string_view content)
::absl::Status PortableFileGetContents (absl::string_view file_name, std::string *output)
::absl::Status PortableDeleteFile (absl::string_view file_name)
std::string ProtobufTextFormatPrintToStringForFlag (const google::protobuf::Message &proto)
std::string ProtobufTextFormatPrintToStringForFlag (const google::protobuf::MessageLite &proto)
template<class P>
std::string ProtobufDebugString (const P &message)
template<class P>
std::string ProtobufShortDebugString (const P &message)
template<typename ProtoEnumType>
std::string ProtoEnumToString (ProtoEnumType enum_value)
template<typename ProtoType>
bool ProtobufTextFormatMergeFromString (absl::string_view proto_text_string, ProtoType *proto)
template<typename ProtoType>
bool ProtobufParseTextProtoForFlag (absl::string_view text, ProtoType *message_out, std::string *error_out)
int32_t GetSeed (bool deterministic)
void DisplayPlan (const RoutingIndexManager &manager, const RoutingModel &routing, const operations_research::Assignment &plan, bool use_same_vehicle_costs, int64_t max_nodes_per_group, int64_t same_vehicle_cost, absl::Span< const std::string > dimension_names)
void Main ()
 DEFINE_STRONG_INT_TYPE (SubsetIndex, BaseInt)
 DEFINE_STRONG_INT_TYPE (ElementIndex, BaseInt)
 DEFINE_STRONG_INT_TYPE (ColumnEntryIndex, BaseInt)
 DEFINE_STRONG_INT_TYPE (RowEntryIndex, BaseInt)
template<class Index>
 IndexRange (Index a, Index b) -> IndexRange< Index >
template<typename T>
 IterableContainer (const T &data_source) -> IterableContainer< T >
 DEFINE_STRONG_INT_TYPE (CapacityTermIndex, BaseInt)
constexpr SubsetIndex kNotFound (-1)
std::vector< SubsetIndex > ClearRandomSubsets (BaseInt num_subsets, SetCoverInvariant *inv)
std::vector< SubsetIndex > ClearRandomSubsets (absl::Span< const SubsetIndex > focus, BaseInt num_subsets_to_choose, SetCoverInvariant *inv)
std::vector< SubsetIndex > ClearMostCoveredElements (BaseInt max_num_subsets, SetCoverInvariant *inv)
std::vector< SubsetIndex > ClearMostCoveredElements (absl::Span< const SubsetIndex > focus, BaseInt max_num_subsets, SetCoverInvariant *inv)
template<typename T>
SetCoverModel::Stats ComputeStats (std::vector< T > samples)
template<typename T>
std::vector< T > ComputeDeciles (std::vector< T > values)
SetCoverModel ReadOrlibScp (absl::string_view filename)
SetCoverModel ReadOrlibRail (absl::string_view filename)
SetCoverModel ReadFimiDat (absl::string_view filename)
SetCoverModel ReadSetCoverProto (absl::string_view filename, bool binary)
void WriteOrlibScp (const SetCoverModel &model, absl::string_view filename)
void WriteOrlibRail (const SetCoverModel &model, absl::string_view filename)
void WriteSetCoverProto (const SetCoverModel &model, absl::string_view filename, bool binary)
SubsetBoolVector ReadSetCoverSolutionText (absl::string_view filename)
SubsetBoolVector ReadSetCoverSolutionProto (absl::string_view filename, bool binary)
void WriteSetCoverSolutionText (const SetCoverModel &model, const SubsetBoolVector &solution, absl::string_view filename)
void WriteSetCoverSolutionProto (const SetCoverModel &model, const SubsetBoolVector &solution, absl::string_view filename, bool binary)
int64_t RunTimeInMicroseconds (const SetCoverSolutionGenerator &gen)
int64_t RunTimeInNanoseconds (const SetCoverSolutionGenerator &gen)
void LogStats (const SetCoverModel &model)
void LogCostAndTiming (const absl::string_view problem_name, absl::string_view alg_name, const SetCoverInvariant &inv, int64_t run_time)
void LogCostAndTiming (const SetCoverSolutionGenerator &generator)
FileFormat ParseFileFormat (const std::string &format_name)
SetCoverModel ReadModel (absl::string_view filename, FileFormat format)
SubsetBoolVector ReadSolution (absl::string_view filename, FileFormat format)
void WriteModel (const SetCoverModel &model, const std::string &filename, FileFormat format)
void WriteSolution (const SetCoverModel &model, const SubsetBoolVector &solution, absl::string_view filename, FileFormat format)
SetCoverInvariant RunLazyElementDegree (SetCoverModel *model)
SetCoverInvariant RunGreedy (SetCoverModel *model)
std::vector< BenchmarksTableRowBenchmarksTable ()
void Benchmarks ()
void Run ()
 DEFINE_STRONG_INT_TYPE (FullSubsetIndex, BaseInt)
 DEFINE_STRONG_INT_TYPE (FullElementIndex, BaseInt)
 ENABLE_EXPLICIT_STRONG_TYPE_CAST (SubsetIndex, FullSubsetIndex)
 ENABLE_EXPLICIT_STRONG_TYPE_CAST (FullSubsetIndex, SubsetIndex)
 ENABLE_EXPLICIT_STRONG_TYPE_CAST (ElementIndex, FullElementIndex)
 ENABLE_EXPLICIT_STRONG_TYPE_CAST (FullElementIndex, ElementIndex)
int ComputeFormVarStatus (glp_prob *const problem, const int num_cstrs, const int k)
double ComputeFormVarReducedCost (glp_prob *const problem, const int num_cstrs, const int k)
double ComputeFormVarPrimalValue (glp_prob *const problem, const int num_cstrs, const int k)
double ComputeFormVarLowerBound (glp_prob *const problem, const int num_cstrs, const int k)
double ComputeFormVarUpperBound (glp_prob *const problem, const int num_cstrs, const int k)
void SetupGlpkEnvAutomaticDeletion ()
std::string SolutionStatusString (const int status)
std::string BasisStatusString (const int stat)
std::string ReturnCodeString (const int rc)
std::string TruncateAndQuoteGLPKName (const std::string_view original_name)
void LoadGurobiFunctions (DynamicLibrary *gurobi_dynamic_library)
std::vector< std::string > GurobiDynamicLibraryPotentialPaths ()
absl::Status LoadGurobiDynamicLibrary (std::vector< absl::string_view > potential_paths)
void LoadXpressFunctions (DynamicLibrary *xpress_dynamic_library)
void printXpressBanner (bool error)
std::vector< std::string > XpressDynamicLibraryPotentialPaths ()
absl::Status LoadXpressDynamicLibrary (std::string &xpresspath)
void log_message_about_XPRSinit_argument ()
void log_full_license_error (int code, const std::string &xpress_lib_dir)
bool initXpressEnv (bool verbose, int xpress_oem_license_key)
 init XPRESS environment.
bool XpressIsCorrectlyInstalled ()
template<size_t alignment_bytes, typename Value>
Value * AlignUp (Value *ptr)
template<size_t alignment_bytes, typename Value>
Value * AlignDown (Value *ptr)
template<size_t alignment_bytes, typename Value>
bool IsAligned (Value *ptr)
uint64_t OneBit64 (int pos)
uint32_t OneBit32 (int pos)
uint64_t BitCount64 (uint64_t n)
uint32_t BitCount32 (uint32_t n)
uint64_t LeastSignificantBitWord64 (uint64_t n)
uint32_t LeastSignificantBitWord32 (uint32_t n)
int LeastSignificantBitPosition64DeBruijn (uint64_t n)
int LeastSignificantBitPosition64Default (uint64_t n)
int LeastSignificantBitPosition64 (uint64_t n)
int LeastSignificantBitPosition32DeBruijn (uint32_t n)
int LeastSignificantBitPosition32Default (uint32_t n)
int LeastSignificantBitPosition32 (uint32_t n)
int MostSignificantBitPosition64Default (uint64_t n)
int MostSignificantBitPosition64 (uint64_t n)
int MostSignificantBitPosition32Default (uint32_t n)
int MostSignificantBitPosition32 (uint32_t n)
uint64_t OneRange64 (uint64_t s, uint64_t e)
uint32_t OneRange32 (uint32_t s, uint32_t e)
uint64_t IntervalUp64 (uint64_t s)
uint32_t IntervalUp32 (uint32_t s)
uint64_t IntervalDown64 (uint64_t s)
uint32_t IntervalDown32 (uint32_t s)
uint32_t BitPos64 (uint64_t pos)
uint32_t BitPos32 (uint32_t pos)
uint64_t BitOffset64 (uint64_t pos)
uint32_t BitOffset32 (uint32_t pos)
uint64_t BitLength64 (uint64_t size)
uint32_t BitLength32 (uint32_t size)
uint64_t BitShift64 (uint64_t v)
uint32_t BitShift32 (uint32_t v)
bool IsBitSet64 (const uint64_t *const bitset, uint64_t pos)
bool IsBitSet32 (const uint32_t *const bitset, uint32_t pos)
void SetBit64 (uint64_t *const bitset, uint64_t pos)
void SetBit32 (uint32_t *const bitset, uint32_t pos)
void ClearBit64 (uint64_t *const bitset, uint64_t pos)
void ClearBit32 (uint32_t *const bitset, uint32_t pos)
uint64_t BitCountRange64 (const uint64_t *bitset, uint64_t start, uint64_t end)
uint32_t BitCountRange32 (const uint32_t *bitset, uint32_t start, uint32_t end)
bool IsEmptyRange64 (const uint64_t *bitset, uint64_t start, uint64_t end)
bool IsEmptyRange32 (const uint32_t *bitset, uint32_t start, uint32_t end)
int64_t LeastSignificantBitPosition64 (const uint64_t *bitset, uint64_t start, uint64_t end)
int LeastSignificantBitPosition32 (const uint32_t *bitset, uint32_t start, uint32_t end)
int64_t MostSignificantBitPosition64 (const uint64_t *bitset, uint64_t start, uint64_t end)
int MostSignificantBitPosition32 (const uint32_t *bitset, uint32_t start, uint32_t end)
int64_t UnsafeLeastSignificantBitPosition64 (const uint64_t *bitset, uint64_t start, uint64_t end)
int32_t UnsafeLeastSignificantBitPosition32 (const uint32_t *bitset, uint32_t start, uint32_t end)
int64_t UnsafeMostSignificantBitPosition64 (const uint64_t *bitset, uint64_t start, uint64_t end)
int32_t UnsafeMostSignificantBitPosition32 (const uint32_t *bitset, uint32_t start, uint32_t end)
uint64_t TwoBitsFromPos64 (uint64_t pos)
absl::StatusOr< std::string > ReadFileToString (absl::string_view filename)
absl::Status ReadFileToProto (absl::string_view filename, google::protobuf::Message *proto, bool allow_partial)
absl::Status StringToProto (absl::string_view data, google::protobuf::Message *proto, bool allow_partial)
absl::Status WriteProtoToFile (absl::string_view filename, const google::protobuf::Message &proto, ProtoWriteFormat proto_write_format, bool gzipped, bool append_extension_to_file_name)
template<typename Proto>
absl::StatusOr< Proto > ReadFileToProto (absl::string_view filename, bool allow_partial=false)
template<typename Proto>
std::vector< Proto > ReadAllRecordsOrDie (absl::string_view filename)
template<typename Proto>
std::vector< Proto > ReadAllRecordsOrDie (File *file)
template<typename Proto>
Proto ReadOneRecordOrDie (absl::string_view filename)
template<typename Proto>
void WriteRecordsOrDie (absl::string_view filename, const std::vector< Proto > &protos)
 DEFINE_STRONG_INDEX_TYPE (TreeNodeIndex)
 DEFINE_STRONG_INDEX_TYPE (LeafIndex)
std::ostream & operator<< (std::ostream &out, const RoundTripDoubleFormat &format)
void ComputeScalingErrors (absl::Span< const double > input, absl::Span< const double > lb, absl::Span< const double > ub, double scaling_factor, double *max_relative_coeff_error, double *max_scaled_sum_error)
double GetBestScalingOfDoublesToInt64 (absl::Span< const double > input, absl::Span< const double > lb, absl::Span< const double > ub, int64_t max_absolute_sum)
void GetBestScalingOfDoublesToInt64 (absl::Span< const double > input, int64_t max_absolute_sum, double *scaling_factor, double *max_relative_coeff_error)
int64_t ComputeGcdOfRoundedDoubles (absl::Span< const double > x, double scaling_factor)
template<typename FloatType>
bool IsPositiveOrNegativeInfinity (FloatType x)
template<typename FloatType>
bool AreWithinAbsoluteOrRelativeTolerances (FloatType x, FloatType y, FloatType relative_tolerance, FloatType absolute_tolerance)
template<typename FloatType>
bool AreWithinAbsoluteTolerance (FloatType x, FloatType y, FloatType absolute_tolerance)
template<typename FloatType>
bool IsSmallerWithinTolerance (FloatType x, FloatType y, FloatType tolerance)
template<typename FloatType>
bool IsIntegerWithinTolerance (FloatType x, FloatType tolerance)
template<typename FloatType>
FloatType Interpolate (FloatType x, FloatType y, FloatType alpha)
int fast_ilogb (double value)
double fast_scalbn (double value, int exponent)
std::string FormatCounter (int64_t num)
bool ParseTextProtoForFlag (const absl::string_view text, google::protobuf::Message *const message_out, std::string *const error_out)
std::string FullProtocolMessageAsString (const google::protobuf::Message &message, int indent_level)
template<class Proto>
absl::StatusOr< Proto * > SafeProtoDownCast (google::protobuf::Message *proto)
template<class Proto>
absl::StatusOr< const Proto * > SafeProtoConstDownCast (const google::protobuf::Message *proto)
void ExploreAndCountAllProtoPathsInInstance (const google::protobuf::Message &message, absl::flat_hash_map< std::string, int > *proto_path_counts)
QapProblem ReadQapProblemOrDie (absl::string_view filepath)
RangeIntToIntFunctionMakeBareIntToIntFunction (std::function< int64_t(int64_t)> f)
RangeIntToIntFunctionMakeCachedIntToIntFunction (const std::function< int64_t(int64_t)> &f, int64_t domain_start, int64_t domain_end)
RangeMinMaxIndexFunctionMakeCachedRangeMinMaxIndexFunction (const std::function< int64_t(int64_t)> &f, int64_t domain_start, int64_t domain_end)
Fraction RationalApproximation (const double x, const double precision)
bool AtMinOrMaxInt64 (int64_t x)
int64_t CapOpp (int64_t v)
int64_t CapAbs (int64_t v)
int64_t TwosComplementAddition (int64_t x, int64_t y)
int64_t TwosComplementSubtraction (int64_t x, int64_t y)
bool AddHadOverflow (int64_t x, int64_t y, int64_t sum)
bool SubHadOverflow (int64_t x, int64_t y, int64_t diff)
bool AddOverflows (int64_t x, int64_t y)
int64_t SubOverflows (int64_t x, int64_t y)
template<typename IntegerType>
bool SafeAddInto (IntegerType a, IntegerType *b)
int64_t CapWithSignOf (int64_t x)
int64_t CapAddGeneric (int64_t x, int64_t y)
int64_t CapSubGeneric (int64_t x, int64_t y)
int64_t CapProdGeneric (int64_t x, int64_t y)
template<typename T>
CapOrFloatAdd (T x, T y)
int64_t CapAdd (int64_t x, int64_t y)
bool AddIntoOverflow (int64_t x, int64_t *y)
void CapAddTo (int64_t x, int64_t *y)
int64_t CapSub (int64_t x, int64_t y)
void CapSubFrom (int64_t amount, int64_t *target)
int64_t CapProd (int64_t x, int64_t y)
template<class Iterator, class Compare = std::less<value_type_t<Iterator>>>
void IncrementalSort (int max_comparisons, Iterator begin, Iterator end, Compare comp=Compare{}, bool is_stable=false)
template<class Iterator, class Compare = std::less<value_type_t<Iterator>>>
void InsertionSort (Iterator begin, Iterator end, Compare comp=Compare{})
template<class Iterator, class Compare = std::less<value_type_t<Iterator>>>
void IncrementalSort (Iterator begin, Iterator end, Compare comp=Compare{}, bool is_stable=false)
bool IntervalsAreSortedAndNonAdjacent (absl::Span< const ClosedInterval > intervals)
int64_t CeilRatio (int64_t value, int64_t positive_coeff)
int64_t FloorRatio (int64_t value, int64_t positive_coeff)
std::ostream & operator<< (std::ostream &out, const ClosedInterval &interval)
std::ostream & operator<< (std::ostream &out, const std::vector< ClosedInterval > &intervals)
std::ostream & operator<< (std::ostream &out, const Domain &domain)
int64_t SumOfKMinValueInDomain (const Domain &domain, int k)
int64_t SumOfKMaxValueInDomain (const Domain &domain, int k)
ClosedInterval::Iterator begin (ClosedInterval interval)
ClosedInterval::Iterator end (ClosedInterval interval)
std::string MemoryUsage ()
template<class T>
std::string JoinDebugString (const std::vector< T > &v, absl::string_view separator)
template<class T>
std::string JoinDebugStringPtr (const std::vector< T > &v, absl::string_view separator)
template<class T>
std::string JoinNamePtr (const std::vector< T > &v, absl::string_view separator)
template<class T>
std::string JoinNameFieldPtr (const std::vector< T > &v, absl::string_view separator)
std::string CropMultiLineString (const std::string &s, int max_line_length, int max_num_lines)
template<typename StrongIndexName>
std::ostream & operator<< (std::ostream &os, StrongIndex< StrongIndexName > arg)
template<typename Sink, typename... T>
void AbslStringify (Sink &sink, StrongIndex< T... > arg)
template<typename StrongIntegerName>
std::ostream & operator<< (std::ostream &os, StrongInt64< StrongIntegerName > arg)
template<typename Sink, typename... T>
void AbslStringify (Sink &sink, StrongInt64< T... > arg)
 STRONG_TYPE_ARITHMETIC_OP (StrongIndex, int,+)
 STRONG_TYPE_ARITHMETIC_OP (StrongIndex, int, -)
 STRONG_TYPE_ARITHMETIC_OP (StrongIndex, int, *)
 STRONG_TYPE_ARITHMETIC_OP (StrongIndex, int, %)
 STRONG_TYPE_ARITHMETIC_OP (StrongInt64, int64_t,+)
 STRONG_TYPE_ARITHMETIC_OP (StrongInt64, int64_t, -)
 STRONG_TYPE_ARITHMETIC_OP (StrongInt64, int64_t, *)
 STRONG_TYPE_ARITHMETIC_OP (StrongInt64, int64_t,/)
 STRONG_TYPE_ARITHMETIC_OP (StrongInt64, int64_t,<<)
 STRONG_TYPE_ARITHMETIC_OP (StrongInt64, int64_t, > >)
 STRONG_TYPE_ARITHMETIC_OP (StrongInt64, int64_t, %)
 STRONG_TYPE_COMPARISON_OP (StrongIndex, int,==)
 STRONG_TYPE_COMPARISON_OP (StrongIndex, int, !=)
 STRONG_TYPE_COMPARISON_OP (StrongIndex, int,<=)
 STRONG_TYPE_COMPARISON_OP (StrongIndex, int, >=)
 STRONG_TYPE_COMPARISON_OP (StrongInt64, int64_t,==)
 STRONG_TYPE_COMPARISON_OP (StrongInt64, int64_t, !=)
 STRONG_TYPE_COMPARISON_OP (StrongInt64, int64_t,<=)
 STRONG_TYPE_COMPARISON_OP (StrongInt64, int64_t, >=)
template<typename StrongIndexName, typename H>
AbslHashValue (H h, const StrongIndex< StrongIndexName > &i)
template<typename StrongIntegerName, typename H>
AbslHashValue (H h, const StrongInt64< StrongIntegerName > &i)
bool ProbablyRunningInsideUnitTest ()
float AlignedVectorSum (absl::Span< const float > values)
float VectorSum (absl::Span< const float > values)
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL FirstSolutionStrategy_Value_descriptor ()
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL LocalSearchMetaheuristic_Value_descriptor ()
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL RoutingSearchStatus_Value_descriptor ()
bool FirstSolutionStrategy_Value_IsValid (int value)
template<typename T>
const ::std::string & FirstSolutionStrategy_Value_Name (T value)
template<>
const ::std::string & FirstSolutionStrategy_Value_Name (FirstSolutionStrategy_Value value)
bool FirstSolutionStrategy_Value_Parse (::absl::string_view name, FirstSolutionStrategy_Value *PROTOBUF_NONNULL value)
bool LocalSearchMetaheuristic_Value_IsValid (int value)
template<typename T>
const ::std::string & LocalSearchMetaheuristic_Value_Name (T value)
template<>
const ::std::string & LocalSearchMetaheuristic_Value_Name (LocalSearchMetaheuristic_Value value)
bool LocalSearchMetaheuristic_Value_Parse (::absl::string_view name, LocalSearchMetaheuristic_Value *PROTOBUF_NONNULL value)
bool RoutingSearchStatus_Value_IsValid (int value)
template<typename T>
const ::std::string & RoutingSearchStatus_Value_Name (T value)
template<>
const ::std::string & RoutingSearchStatus_Value_Name (RoutingSearchStatus_Value value)
bool RoutingSearchStatus_Value_Parse (::absl::string_view name, RoutingSearchStatus_Value *PROTOBUF_NONNULL value)
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL LocalCheapestInsertionParameters_PairInsertionStrategy_descriptor ()
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL LocalCheapestInsertionParameters_InsertionSortingProperty_descriptor ()
bool LocalCheapestInsertionParameters_PairInsertionStrategy_IsValid (int value)
template<typename T>
const ::std::string & LocalCheapestInsertionParameters_PairInsertionStrategy_Name (T value)
template<>
const ::std::string & LocalCheapestInsertionParameters_PairInsertionStrategy_Name (LocalCheapestInsertionParameters_PairInsertionStrategy value)
bool LocalCheapestInsertionParameters_PairInsertionStrategy_Parse (::absl::string_view name, LocalCheapestInsertionParameters_PairInsertionStrategy *PROTOBUF_NONNULL value)
bool LocalCheapestInsertionParameters_InsertionSortingProperty_IsValid (int value)
template<typename T>
const ::std::string & LocalCheapestInsertionParameters_InsertionSortingProperty_Name (T value)
template<>
const ::std::string & LocalCheapestInsertionParameters_InsertionSortingProperty_Name (LocalCheapestInsertionParameters_InsertionSortingProperty value)
bool LocalCheapestInsertionParameters_InsertionSortingProperty_Parse (::absl::string_view name, LocalCheapestInsertionParameters_InsertionSortingProperty *PROTOBUF_NONNULL value)
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL RuinCompositionStrategy_Value_descriptor ()
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL PerturbationStrategy_Value_descriptor ()
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL CoolingScheduleStrategy_Value_descriptor ()
bool RuinCompositionStrategy_Value_IsValid (int value)
template<typename T>
const ::std::string & RuinCompositionStrategy_Value_Name (T value)
template<>
const ::std::string & RuinCompositionStrategy_Value_Name (RuinCompositionStrategy_Value value)
bool RuinCompositionStrategy_Value_Parse (::absl::string_view name, RuinCompositionStrategy_Value *PROTOBUF_NONNULL value)
bool PerturbationStrategy_Value_IsValid (int value)
template<typename T>
const ::std::string & PerturbationStrategy_Value_Name (T value)
template<>
const ::std::string & PerturbationStrategy_Value_Name (PerturbationStrategy_Value value)
bool PerturbationStrategy_Value_Parse (::absl::string_view name, PerturbationStrategy_Value *PROTOBUF_NONNULL value)
bool CoolingScheduleStrategy_Value_IsValid (int value)
template<typename T>
const ::std::string & CoolingScheduleStrategy_Value_Name (T value)
template<>
const ::std::string & CoolingScheduleStrategy_Value_Name (CoolingScheduleStrategy_Value value)
bool CoolingScheduleStrategy_Value_Parse (::absl::string_view name, CoolingScheduleStrategy_Value *PROTOBUF_NONNULL value)
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL RoutingSearchParameters_SchedulingSolver_descriptor ()
bool RoutingSearchParameters_SchedulingSolver_IsValid (int value)
template<typename T>
const ::std::string & RoutingSearchParameters_SchedulingSolver_Name (T value)
template<>
const ::std::string & RoutingSearchParameters_SchedulingSolver_Name (RoutingSearchParameters_SchedulingSolver value)
bool RoutingSearchParameters_SchedulingSolver_Parse (::absl::string_view name, RoutingSearchParameters_SchedulingSolver *PROTOBUF_NONNULL value)
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL ConstraintSolverParameters_TrailCompression_descriptor ()
bool ConstraintSolverParameters_TrailCompression_IsValid (int value)
template<typename T>
const ::std::string & ConstraintSolverParameters_TrailCompression_Name (T value)
template<>
const ::std::string & ConstraintSolverParameters_TrailCompression_Name (ConstraintSolverParameters_TrailCompression value)
bool ConstraintSolverParameters_TrailCompression_Parse (::absl::string_view name, ConstraintSolverParameters_TrailCompression *PROTOBUF_NONNULL value)
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL FlowModelProto_ProblemType_descriptor ()
bool FlowModelProto_ProblemType_IsValid (int value)
template<typename T>
const ::std::string & FlowModelProto_ProblemType_Name (T value)
template<>
const ::std::string & FlowModelProto_ProblemType_Name (FlowModelProto_ProblemType value)
bool FlowModelProto_ProblemType_Parse (::absl::string_view name, FlowModelProto_ProblemType *PROTOBUF_NONNULL value)
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL MPSosConstraint_Type_descriptor ()
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL MPModelProto_Annotation_TargetType_descriptor ()
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL MPSolverCommonParameters_LPAlgorithmValues_descriptor ()
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL MPModelRequest_SolverType_descriptor ()
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL MPSolverResponseStatus_descriptor ()
bool MPSosConstraint_Type_IsValid (int value)
template<typename T>
const ::std::string & MPSosConstraint_Type_Name (T value)
template<>
const ::std::string & MPSosConstraint_Type_Name (MPSosConstraint_Type value)
bool MPSosConstraint_Type_Parse (::absl::string_view name, MPSosConstraint_Type *PROTOBUF_NONNULL value)
bool MPModelProto_Annotation_TargetType_IsValid (int value)
template<typename T>
const ::std::string & MPModelProto_Annotation_TargetType_Name (T value)
template<>
const ::std::string & MPModelProto_Annotation_TargetType_Name (MPModelProto_Annotation_TargetType value)
bool MPModelProto_Annotation_TargetType_Parse (::absl::string_view name, MPModelProto_Annotation_TargetType *PROTOBUF_NONNULL value)
bool MPSolverCommonParameters_LPAlgorithmValues_IsValid (int value)
template<typename T>
const ::std::string & MPSolverCommonParameters_LPAlgorithmValues_Name (T value)
template<>
const ::std::string & MPSolverCommonParameters_LPAlgorithmValues_Name (MPSolverCommonParameters_LPAlgorithmValues value)
bool MPSolverCommonParameters_LPAlgorithmValues_Parse (::absl::string_view name, MPSolverCommonParameters_LPAlgorithmValues *PROTOBUF_NONNULL value)
bool MPModelRequest_SolverType_IsValid (int value)
template<typename T>
const ::std::string & MPModelRequest_SolverType_Name (T value)
bool MPModelRequest_SolverType_Parse (::absl::string_view name, MPModelRequest_SolverType *PROTOBUF_NONNULL value)
bool MPSolverResponseStatus_IsValid (int value)
template<typename T>
const ::std::string & MPSolverResponseStatus_Name (T value)
bool MPSolverResponseStatus_Parse (::absl::string_view name, MPSolverResponseStatus *PROTOBUF_NONNULL value)
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL GScipParameters_Emphasis_descriptor ()
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL GScipParameters_MetaParamValue_descriptor ()
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL GScipOutput_Status_descriptor ()
bool GScipParameters_Emphasis_IsValid (int value)
template<typename T>
const ::std::string & GScipParameters_Emphasis_Name (T value)
template<>
const ::std::string & GScipParameters_Emphasis_Name (GScipParameters_Emphasis value)
bool GScipParameters_Emphasis_Parse (::absl::string_view name, GScipParameters_Emphasis *PROTOBUF_NONNULL value)
bool GScipParameters_MetaParamValue_IsValid (int value)
template<typename T>
const ::std::string & GScipParameters_MetaParamValue_Name (T value)
template<>
const ::std::string & GScipParameters_MetaParamValue_Name (GScipParameters_MetaParamValue value)
bool GScipParameters_MetaParamValue_Parse (::absl::string_view name, GScipParameters_MetaParamValue *PROTOBUF_NONNULL value)
bool GScipOutput_Status_IsValid (int value)
template<typename T>
const ::std::string & GScipOutput_Status_Name (T value)
template<>
const ::std::string & GScipOutput_Status_Name (GScipOutput_Status value)
bool GScipOutput_Status_Parse (::absl::string_view name, GScipOutput_Status *PROTOBUF_NONNULL value)
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL CourseSchedulingResultStatus_descriptor ()
bool CourseSchedulingResultStatus_IsValid (int value)
template<typename T>
const ::std::string & CourseSchedulingResultStatus_Name (T value)
template<>
const ::std::string & CourseSchedulingResultStatus_Name (CourseSchedulingResultStatus value)
bool CourseSchedulingResultStatus_Parse (::absl::string_view name, CourseSchedulingResultStatus *PROTOBUF_NONNULL value)
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL SetCoverSolutionResponse_Status_descriptor ()
bool SetCoverSolutionResponse_Status_IsValid (int value)
template<typename T>
const ::std::string & SetCoverSolutionResponse_Status_Name (T value)
template<>
const ::std::string & SetCoverSolutionResponse_Status_Name (SetCoverSolutionResponse_Status value)
bool SetCoverSolutionResponse_Status_Parse (::absl::string_view name, SetCoverSolutionResponse_Status *PROTOBUF_NONNULL value)
const ::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL OptionalBoolean_descriptor ()
bool OptionalBoolean_IsValid (int value)
template<typename T>
const ::std::string & OptionalBoolean_Name (T value)
template<>
const ::std::string & OptionalBoolean_Name (OptionalBoolean value)
bool OptionalBoolean_Parse (::absl::string_view name, OptionalBoolean *PROTOBUF_NONNULL value)
template<class Graph>
bool GraphIsSymmetric (const Graph &graph)
template<class T>
DemonMakeConstraintDemon0 (Solver *const s, T *const ct, void(T::*method)(), const std::string &name)
template<class P>
std::string ParameterDebugString (P param)
template<class P>
std::string ParameterDebugString (P *param)
 Support limited to pointers to classes which define DebugString().
template<class T, class P>
DemonMakeConstraintDemon1 (Solver *const s, T *const ct, void(T::*method)(P), const std::string &name, P param1)
template<class T, class P, class Q>
DemonMakeConstraintDemon2 (Solver *const s, T *const ct, void(T::*method)(P, Q), const std::string &name, P param1, Q param2)
template<class T, class P, class Q, class R>
DemonMakeConstraintDemon3 (Solver *const s, T *const ct, void(T::*method)(P, Q, R), const std::string &name, P param1, Q param2, R param3)
template<class T>
DemonMakeDelayedConstraintDemon0 (Solver *const s, T *const ct, void(T::*method)(), const std::string &name)
template<class T, class P>
DemonMakeDelayedConstraintDemon1 (Solver *const s, T *const ct, void(T::*method)(P), const std::string &name, P param1)
template<class T, class P, class Q>
DemonMakeDelayedConstraintDemon2 (Solver *const s, T *const ct, void(T::*method)(P, Q), const std::string &name, P param1, Q param2)

Variables

const bool DEBUG_MODE = true
static const int kUnassigned = -1
template<typename NodeIndex>
const double BronKerboschAlgorithm< NodeIndex >::kPushStateDeterministicTimeSecondsPerCandidate = 0.54663e-7
const PathDistance kDisconnectedPathDistance
constexpr NamedOptimizationProblemType kOptimizationProblemTypeNames []
constexpr double kDefaultPrimalTolerance = 1e-07
static constexpr Cost kMaxPossibleCost = std::numeric_limits<Cost>::max()
static constexpr double kInfinity = std::numeric_limits<float>::infinity()
 num_uncovered_elements_
 num_free_elements_ [subset]
static const char *const kRailFiles []
static const char *const kScp4To6Files []
static const char *const kScpAToEFiles []
static const char *const kScpNrFiles []
static const char *const kScpClrFiles []
static const char *const kScpCycFiles []
static const char *const kWedelinFiles []
static const char *const kBalasFiles []
static const char *const kFimiFiles []
constexpr std::size_t kMaxGLPKNameLen = 255
std::function< int(GRBmodel *model, const char *attrname)> GRBisattravailable
std::function< int(GRBmodel *model, const char *attrname, int *valueP)> GRBgetintattr = nullptr
std::function< int(GRBmodel *model, const char *attrname, int newvalue)> GRBsetintattr = nullptr
std::function< int(GRBmodel *model, const char *attrname, int element, int *valueP)> GRBgetintattrelement = nullptr
std::function< int(GRBmodel *model, const char *attrname, int element, int newvalue)> GRBsetintattrelement = nullptr
std::function< int(GRBmodel *model, const char *attrname, int first, int len, int *values)> GRBgetintattrarray = nullptr
std::function< int(GRBmodel *model, const char *attrname, int first, int len, int *newvalues)> GRBsetintattrarray = nullptr
std::function< int(GRBmodel *model, const char *attrname, int len, int *ind, int *newvalues)> GRBsetintattrlist = nullptr
std::function< int(GRBmodel *model, const char *attrname, int element, char *valueP)> GRBgetcharattrelement = nullptr
std::function< int(GRBmodel *model, const char *attrname, int element, char newvalue)> GRBsetcharattrelement = nullptr
std::function< int(GRBmodel *model, const char *attrname, int first, int len, char *values)> GRBgetcharattrarray = nullptr
std::function< int(GRBmodel *model, const char *attrname, int first, int len, char *newvalues)> GRBsetcharattrarray = nullptr
std::function< int(GRBmodel *model, const char *attrname, int len, int *ind, char *newvalues)> GRBsetcharattrlist = nullptr
std::function< int(GRBmodel *model, const char *attrname, double *valueP)> GRBgetdblattr = nullptr
std::function< int(GRBmodel *model, const char *attrname, double newvalue)> GRBsetdblattr = nullptr
std::function< int(GRBmodel *model, const char *attrname, int element, double *valueP)> GRBgetdblattrelement = nullptr
std::function< int(GRBmodel *model, const char *attrname, int element, double newvalue)> GRBsetdblattrelement = nullptr
std::function< int(GRBmodel *model, const char *attrname, int first, int len, double *values)> GRBgetdblattrarray = nullptr
std::function< int(GRBmodel *model, const char *attrname, int first, int len, double *newvalues)> GRBsetdblattrarray = nullptr
std::function< int(GRBmodel *model, const char *attrname, int len, int *ind, double *newvalues)> GRBsetdblattrlist = nullptr
std::function< int(GRBmodel *model, const char *attrname, char **valueP)> GRBgetstrattr = nullptr
std::function< int(GRBmodel *model, const char *attrname, const char *newvalue)> GRBsetstrattr = nullptr
std::function< int(GRBmodel *model, int(GUROBI_STDCALL *cb)(CB_ARGS), void *usrdata)> GRBsetcallbackfunc = nullptr
std::function< int(void *cbdata, int where, int what, void *resultP)> GRBcbget
std::function< int(void *cbdata, const double *solution, double *objvalP)> GRBcbsolution = nullptr
std::function< int(void *cbdata, int cutlen, const int *cutind, const double *cutval, char cutsense, double cutrhs)> GRBcbcut = nullptr
std::function< int(void *cbdata, int lazylen, const int *lazyind, const double *lazyval, char lazysense, double lazyrhs)> GRBcblazy = nullptr
std::function< int(GRBmodel *model, int *numnzP, int *vbeg, int *vind, double *vval, int start, int len)> GRBgetvars = nullptr
std::function< int(GRBmodel *model)> GRBoptimize = nullptr
std::function< int(GRBmodel *model)> GRBcomputeIIS = nullptr
std::function< int(GRBmodel *model, const char *filename)> GRBwrite = nullptr
std::function< int(GRBenv *env, GRBmodel **modelP, const char *Pname, int numvars, double *obj, double *lb, double *ub, char *vtype, char **varnames)> GRBnewmodel = nullptr
std::function< int(GRBmodel *model, int numnz, int *vind, double *vval, double obj, double lb, double ub, char vtype, const char *varname)> GRBaddvar = nullptr
std::function< int(GRBmodel *model, int numvars, int numnz, int *vbeg, int *vind, double *vval, double *obj, double *lb, double *ub, char *vtype, char **varnames)> GRBaddvars = nullptr
std::function< int(GRBmodel *model, int numnz, int *cind, double *cval, char sense, double rhs, const char *constrname)> GRBaddconstr = nullptr
std::function< int(GRBmodel *model, int numconstrs, int numnz, int *cbeg, int *cind, double *cval, char *sense, double *rhs, char **constrnames)> GRBaddconstrs = nullptr
std::function< int(GRBmodel *model, int numnz, int *cind, double *cval, double lower, double upper, const char *constrname)> GRBaddrangeconstr = nullptr
std::function< int(GRBmodel *model, int numsos, int nummembers, int *types, int *beg, int *ind, double *weight)> GRBaddsos = nullptr
std::function< int(GRBmodel *model, const char *name, int resvar, int nvars, const int *vars, double constant)> GRBaddgenconstrMax = nullptr
std::function< int(GRBmodel *model, const char *name, int resvar, int nvars, const int *vars, double constant)> GRBaddgenconstrMin = nullptr
std::function< int(GRBmodel *model, const char *name, int resvar, int argvar)> GRBaddgenconstrAbs = nullptr
std::function< int(GRBmodel *model, const char *name, int resvar, int nvars, const int *vars)> GRBaddgenconstrAnd = nullptr
std::function< int(GRBmodel *model, const char *name, int resvar, int nvars, const int *vars)> GRBaddgenconstrOr = nullptr
std::function< int(GRBmodel *model, const char *name, int binvar, int binval, int nvars, const int *vars, const double *vals, char sense, double rhs)> GRBaddgenconstrIndicator = nullptr
std::function< int(GRBmodel *model, int numlnz, int *lind, double *lval, int numqnz, int *qrow, int *qcol, double *qval, char sense, double rhs, const char *QCname)> GRBaddqconstr = nullptr
std::function< int(GRBmodel *model, int numqnz, int *qrow, int *qcol, double *qval)> GRBaddqpterms = nullptr
std::function< int(GRBmodel *model, int len, int *ind)> GRBdelvars = nullptr
std::function< int(GRBmodel *model, int len, int *ind)> GRBdelconstrs = nullptr
std::function< int(GRBmodel *model, int len, int *ind)> GRBdelsos = nullptr
std::function< int(GRBmodel *model, int len, int *ind)> GRBdelgenconstrs
std::function< int(GRBmodel *model, int len, int *ind)> GRBdelqconstrs = nullptr
std::function< int(GRBmodel *model)> GRBdelq = nullptr
std::function< int(GRBmodel *model, int cnt, int *cind, int *vind, double *val)> GRBchgcoeffs = nullptr
std::function< int(GRBmodel *model)> GRBupdatemodel = nullptr
std::function< int(GRBmodel *model)> GRBfreemodel = nullptr
std::function< void(GRBmodel *model)> GRBterminate = nullptr
std::function< int(GRBmodel *model, int index, int priority, double weight, double abstol, double reltol, const char *name, double constant, int lnz, int *lind, double *lval)> GRBsetobjectiven = nullptr
std::function< int(GRBenv *env, const char *paramname, int *valueP)> GRBgetintparam = nullptr
std::function< int(GRBenv *env, const char *paramname, double *valueP)> GRBgetdblparam = nullptr
std::function< int(GRBenv *env, const char *paramname, char *valueP)> GRBgetstrparam = nullptr
std::function< int(GRBenv *env, const char *paramname, int *valueP, int *minP, int *maxP, int *defP)> GRBgetintparaminfo = nullptr
std::function< int(GRBenv *env, const char *paramname, double *valueP, double *minP, double *maxP, double *defP)> GRBgetdblparaminfo = nullptr
std::function< int(GRBenv *env, const char *paramname, char *valueP, char *defP)> GRBgetstrparaminfo = nullptr
std::function< int(GRBenv *env, const char *paramname)> GRBgetparamtype
std::function< int(GRBenv *env, int i, char **paramnameP)> GRBgetparamname
std::function< int(GRBenv *env, const char *paramname, const char *value)> GRBsetparam = nullptr
std::function< int(GRBenv *env, const char *paramname, int value)> GRBsetintparam = nullptr
std::function< int(GRBenv *env, const char *paramname, double value)> GRBsetdblparam = nullptr
std::function< int(GRBenv *env, const char *paramname, const char *value)> GRBsetstrparam = nullptr
std::function< int(GRBenv *env)> GRBresetparams = nullptr
std::function< int(GRBenv *dest, GRBenv *src)> GRBcopyparams = nullptr
std::function< int(GRBenv *env)> GRBgetnumparams = nullptr
std::function< int(GRBenv **envP)> GRBemptyenv = nullptr
std::function< int(GRBenv **envP, const char *logfilename)> GRBloadenv = nullptr
std::function< int(GRBenv *env)> GRBstartenv = nullptr
std::function< GRBenv *(GRBmodel *model)> GRBgetenv = nullptr
std::function< GRBenv *(GRBmodel *model, int num)> GRBgetmultiobjenv = nullptr
std::function< GRBenv *(GRBmodel *model)> GRBdiscardmultiobjenvs = nullptr
std::function< void(GRBenv *env)> GRBfreeenv = nullptr
std::function< const char *(GRBenv *env)> GRBgeterrormsg = nullptr
std::function< void(int *majorP, int *minorP, int *technicalP)> GRBversion
std::function< char *(void)> GRBplatform = nullptr
std::function< int(XPRSprob *p_prob)> XPRScreateprob = nullptr
std::function< int(XPRSprob prob)> XPRSdestroyprob = nullptr
std::function< int(const char *path)> XPRSinit = nullptr
std::function< int(void)> XPRSfree = nullptr
std::function< int(char *buffer, int maxbytes)> XPRSgetlicerrmsg = nullptr
std::function< int(int *p_i, char *p_c)> XPRSlicense = nullptr
std::function< int(char *banner)> XPRSgetbanner = nullptr
std::function< int(char *version)> XPRSgetversion = nullptr
std::function< int(int *p_major, int *p_minor, int *p_build)> XPRSgetversionnumbers = nullptr
std::function< int(XPRSprob prob, const char *probname)> XPRSsetprobname = nullptr
std::function< int(XPRSprob prob, int control)> XPRSsetdefaultcontrol = nullptr
std::function< int(XPRSprob prob, int reason)> XPRSinterrupt = nullptr
std::function< int(XPRSprob prob, int control, int value)> XPRSsetintcontrol = nullptr
std::function< int(XPRSprob prob, int control, XPRSint64 value)> XPRSsetintcontrol64 = nullptr
std::function< int(XPRSprob prob, int control, double value)> XPRSsetdblcontrol = nullptr
std::function< int(XPRSprob prob, int control, const char *value)> XPRSsetstrcontrol = nullptr
std::function< int(XPRSprob prob, int objidx, int control, int value)> XPRSsetobjintcontrol = nullptr
std::function< int(XPRSprob prob, int objidx, int control, double value)> XPRSsetobjdblcontrol = nullptr
std::function< int(XPRSprob prob, int control, int *p_value)> XPRSgetintcontrol = nullptr
std::function< int(XPRSprob prob, int control, XPRSint64 *p_value)> XPRSgetintcontrol64 = nullptr
std::function< int(XPRSprob prob, int control, double *p_value)> XPRSgetdblcontrol = nullptr
std::function< int(XPRSprob prob, int control, char *value, int maxbytes, int *p_nbytes)> XPRSgetstringcontrol = nullptr
std::function< int(XPRSprob prob, int attrib, int *p_value)> XPRSgetintattrib = nullptr
std::function< int(XPRSprob prob, int attrib, char *value, int maxbytes, int *p_nbytes)> XPRSgetstringattrib = nullptr
std::function< int(XPRSprob prob, int attrib, double *p_value)> XPRSgetdblattrib = nullptr
std::function< int(XPRSprob prob, int objidx, int attrib, double *p_value)> XPRSgetobjdblattrib = nullptr
std::function< int(XPRSprob prob, int objidx, const double solution[], double *p_objval)> XPRScalcobjn = nullptr
std::function< int(XPRSprob prob, const char *name, int *p_id, int *p_type)> XPRSgetcontrolinfo = nullptr
std::function< int(XPRSprob prob, double objcoef[], int first, int last)> XPRSgetobj = nullptr
std::function< int(XPRSprob prob, double rhs[], int first, int last)> XPRSgetrhs = nullptr
std::function< int(XPRSprob prob, double rng[], int first, int last)> XPRSgetrhsrange = nullptr
std::function< int(XPRSprob prob, double lb[], int first, int last)> XPRSgetlb = nullptr
std::function< int(XPRSprob prob, double ub[], int first, int last)> XPRSgetub = nullptr
std::function< int(XPRSprob prob, int row, int col, double *p_coef)> XPRSgetcoef = nullptr
std::function< int(XPRSprob prob, int *status, double x[], int first, int last)> XPRSgetsolution = nullptr
std::function< int(XPRSprob prob, int *status, double duals[], int first, int last)> XPRSgetduals = nullptr
std::function< int(XPRSprob prob, int *status, double djs[], int first, int last)> XPRSgetredcosts = nullptr
std::function< int(XPRSprob prob, int nrows, int ncoefs, const char rowtype[], const double rhs[], const double rng[], const int start[], const int colind[], const double rowcoef[])> XPRSaddrows = nullptr
std::function< int(XPRSprob prob, int nrows, int ncoefs, const char rowtype[], const double rhs[], const double rng[], const XPRSint64 start[], const int colind[], const double rowcoef[])> XPRSaddrows64 = nullptr
std::function< int(XPRSprob prob, int nrows, const int rowind[])> XPRSdelrows = nullptr
std::function< int(XPRSprob prob, int ncols, int ncoefs, const double objcoef[], const int start[], const int rowind[], const double rowcoef[], const double lb[], const double ub[])> XPRSaddcols = nullptr
std::function< int(XPRSprob prob, int ncols, const int colind[], const double objcoef[], int priority, double weight)> XPRSaddobj = nullptr
std::function< int(XPRSprob prob, int row, int ncoefs, const int rowqcol1[], int const rowqcol2[], const double rowqcoef[])> XPRSaddqmatrix64 = nullptr
std::function< int(XPRSprob prob, int type, const char names[], int first, int last)> XPRSaddnames = nullptr
std::function< int(XPRSprob prob, int type, char names[], int first, int last)> XPRSgetnames = nullptr
std::function< int(XPRSprob prob, int nsets, XPRSint64 nelems, const char settype[], const XPRSint64 start[], const int colind[], const double refval[])> XPRSaddsets64 = nullptr
std::function< int(XPRSprob prob, int ncols, const int colind[])> XPRSdelcols = nullptr
std::function< int(XPRSprob prob, int ncols, const int colind[], const char coltype[])> XPRSchgcoltype = nullptr
std::function< int(XPRSprob prob, const int rowstat[], const int colstat[])> XPRSloadbasis = nullptr
std::function< int(XPRSprob prob)> XPRSpostsolve = nullptr
std::function< int(XPRSprob prob, int objsense)> XPRSchgobjsense = nullptr
std::function< int(XPRSprob prob, char *errmsg)> XPRSgetlasterror = nullptr
std::function< int(XPRSprob prob, int rowstat[], int colstat[])> XPRSgetbasis = nullptr
std::function< int(XPRSprob prob, const char *filename, const char *flags)> XPRSwriteprob = nullptr
std::function< int(XPRSprob prob, const char *filename)> XPRSsaveas = nullptr
std::function< int(XPRSprob prob, char rowtype[], int first, int last)> XPRSgetrowtype = nullptr
std::function< int(XPRSprob prob, char coltype[], int first, int last)> XPRSgetcoltype = nullptr
std::function< int(XPRSprob prob, int nbounds, const int colind[], const char bndtype[], const double bndval[])> XPRSchgbounds = nullptr
std::function< int(XPRSprob prob, int length, const double solval[], const int colind[], const char *name)> XPRSaddmipsol = nullptr
std::function< int(XPRSprob prob, int nrows, const int rowind[])> XPRSloaddelayedrows = nullptr
std::function< int(XPRSprob prob, int nrows, const int rowind[], const int colind[], const int complement[])> XPRSsetindicators = nullptr
std::function< int(XPRSprob prob, int ndirs, const int colind[], const int priority[], const char dir[], const double uppseudo[], const double downpseudo[])> XPRSloaddirs
std::function< int(XPRSprob prob, double x[], double slack[], double duals[], double djs[])> XPRSgetlpsol = nullptr
std::function< int(XPRSprob prob, double x[], double slack[])> XPRSgetmipsol = nullptr
std::function< int(XPRSprob prob, int ncols, const int colind[], const double objcoef[])> XPRSchgobj = nullptr
std::function< int(XPRSprob prob, int row, int col, double coef)> XPRSchgcoef = nullptr
std::function< int(XPRSprob prob, int ncoefs, const int rowind[], const int colind[], const double rowcoef[])> XPRSchgmcoef = nullptr
std::function< int(XPRSprob prob, XPRSint64 ncoefs, const int rowind[], const int colind[], const double rowcoef[])> XPRSchgmcoef64 = nullptr
std::function< int(XPRSprob prob, int ncoefs, const int objqcol1[], const int objqcol2[], const double objqcoef[])> XPRSchgmqobj = nullptr
std::function< int(XPRSprob prob, int nrows, const int rowind[], const double rhs[])> XPRSchgrhs = nullptr
std::function< int(XPRSprob prob, int nrows, const int rowind[], const double rng[])> XPRSchgrhsrange = nullptr
std::function< int(XPRSprob prob, int nrows, const int rowind[], const char rowtype[])> XPRSchgrowtype = nullptr
std::function< int(XPRSprob prob, int objidx)> XPRSdelobj = nullptr
std::function< int(XPRSprob prob, void(XPRS_CC *f_intsol)(XPRSprob cbprob, void *cbdata), void *p, int priority)> XPRSaddcbintsol = nullptr
std::function< int(XPRSprob prob, void(XPRS_CC *f_intsol)(XPRSprob cbprob, void *cbdata), void *p)> XPRSremovecbintsol = nullptr
std::function< int(XPRSprob prob, void(XPRS_CC *f_message)(XPRSprob cbprob, void *cbdata, const char *msg, int msglen, int msgtype), void *p, int priority)> XPRSaddcbmessage = nullptr
std::function< int(XPRSprob prob, void(XPRS_CC *f_message)(XPRSprob cbprob, void *cbdata, const char *msg, int msglen, int msgtype), void *p)> XPRSremovecbmessage = nullptr
std::function< int(XPRSprob prob, int(XPRS_CC *f_checktime)(XPRSprob cbprob, void *cbdata), void *p, int priority)> XPRSaddcbchecktime = nullptr
std::function< int(XPRSprob prob, int(XPRS_CC *f_checktime)(XPRSprob cbprob, void *cbdata), void *p)> XPRSremovecbchecktime = nullptr
std::function< int(XPRSprob prob, const char *flags)> XPRSlpoptimize = nullptr
std::function< int(XPRSprob prob, const char *flags)> XPRSmipoptimize = nullptr
std::function< int(XPRSprob prob, const char *flags, int *solvestatus, int *solstatus)> XPRSoptimize = nullptr
static const uint64_t kAllBits64 = uint64_t{0xFFFFFFFFFFFFFFFF}
static const uint64_t kAllBitsButLsb64 = uint64_t{0xFFFFFFFFFFFFFFFE}
static const uint32_t kAllBits32 = 0xFFFFFFFFU
ABSL_CONST_INIT const bool kStdToCharsDoubleIsSupported
constexpr double kRoundTripTestNumber = 0.10000000000000002
constexpr absl::string_view kRoundTripTestNumberStr
constexpr bool kAsanEnabled = false
constexpr bool kMsanEnabled = false
constexpr bool kTsanEnabled = false
constexpr bool kAnyXsanEnabled
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 WorkerInfoDefaultTypeInternal _WorkerInfo_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 SequenceVarAssignmentDefaultTypeInternal _SequenceVarAssignment_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 IntervalVarAssignmentDefaultTypeInternal _IntervalVarAssignment_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 IntVarAssignmentDefaultTypeInternal _IntVarAssignment_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 AssignmentProtoDefaultTypeInternal _AssignmentProto_default_instance_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull IntVarAssignment_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull IntervalVarAssignment_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull SequenceVarAssignment_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull WorkerInfo_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull AssignmentProto_class_data_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 DemonRunsDefaultTypeInternal _DemonRuns_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 ConstraintRunsDefaultTypeInternal _ConstraintRuns_default_instance_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull DemonRuns_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull ConstraintRuns_class_data_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 RoutingSearchStatusDefaultTypeInternal _RoutingSearchStatus_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 LocalSearchMetaheuristicDefaultTypeInternal _LocalSearchMetaheuristic_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 FirstSolutionStrategyDefaultTypeInternal _FirstSolutionStrategy_default_instance_
PROTOBUF_CONSTINIT const uint32_t FirstSolutionStrategy_Value_internal_data_ []
PROTOBUF_CONSTINIT const uint32_t LocalSearchMetaheuristic_Value_internal_data_ []
PROTOBUF_CONSTINIT const uint32_t RoutingSearchStatus_Value_internal_data_ []
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull FirstSolutionStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull LocalSearchMetaheuristic_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull RoutingSearchStatus_class_data_
constexpr FirstSolutionStrategy_Value FirstSolutionStrategy_Value_Value_MIN
constexpr FirstSolutionStrategy_Value FirstSolutionStrategy_Value_Value_MAX
constexpr int FirstSolutionStrategy_Value_Value_ARRAYSIZE = 17 + 1
constexpr LocalSearchMetaheuristic_Value LocalSearchMetaheuristic_Value_Value_MIN
constexpr LocalSearchMetaheuristic_Value LocalSearchMetaheuristic_Value_Value_MAX
constexpr int LocalSearchMetaheuristic_Value_Value_ARRAYSIZE = 6 + 1
constexpr RoutingSearchStatus_Value RoutingSearchStatus_Value_Value_MIN
constexpr RoutingSearchStatus_Value RoutingSearchStatus_Value_Value_MAX
constexpr int RoutingSearchStatus_Value_Value_ARRAYSIZE = 7 + 1
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 SavingsParametersDefaultTypeInternal _SavingsParameters_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 LocalCheapestInsertionParametersDefaultTypeInternal _LocalCheapestInsertionParameters_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 GlobalCheapestInsertionParametersDefaultTypeInternal _GlobalCheapestInsertionParameters_default_instance_
PROTOBUF_CONSTINIT const uint32_t LocalCheapestInsertionParameters_PairInsertionStrategy_internal_data_ []
PROTOBUF_CONSTINIT const uint32_t LocalCheapestInsertionParameters_InsertionSortingProperty_internal_data_ []
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull LocalCheapestInsertionParameters_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull SavingsParameters_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull GlobalCheapestInsertionParameters_class_data_
constexpr LocalCheapestInsertionParameters_PairInsertionStrategy LocalCheapestInsertionParameters_PairInsertionStrategy_PairInsertionStrategy_MIN
constexpr LocalCheapestInsertionParameters_PairInsertionStrategy LocalCheapestInsertionParameters_PairInsertionStrategy_PairInsertionStrategy_MAX
constexpr int LocalCheapestInsertionParameters_PairInsertionStrategy_PairInsertionStrategy_ARRAYSIZE = 3 + 1
constexpr LocalCheapestInsertionParameters_InsertionSortingProperty LocalCheapestInsertionParameters_InsertionSortingProperty_InsertionSortingProperty_MIN
constexpr LocalCheapestInsertionParameters_InsertionSortingProperty LocalCheapestInsertionParameters_InsertionSortingProperty_InsertionSortingProperty_MAX
constexpr int LocalCheapestInsertionParameters_InsertionSortingProperty_InsertionSortingProperty_ARRAYSIZE = 8 + 1
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 SpatiallyCloseRoutesRuinStrategyDefaultTypeInternal _SpatiallyCloseRoutesRuinStrategy_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 SimulatedAnnealingAcceptanceStrategyDefaultTypeInternal _SimulatedAnnealingAcceptanceStrategy_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 SISRRuinStrategyDefaultTypeInternal _SISRRuinStrategy_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 RuinCompositionStrategyDefaultTypeInternal _RuinCompositionStrategy_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 RandomWalkRuinStrategyDefaultTypeInternal _RandomWalkRuinStrategy_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 PerturbationStrategyDefaultTypeInternal _PerturbationStrategy_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MoreNodesPerformedAcceptanceStrategyDefaultTypeInternal _MoreNodesPerformedAcceptanceStrategy_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 GreedyDescentAcceptanceStrategyDefaultTypeInternal _GreedyDescentAcceptanceStrategy_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 CoolingScheduleStrategyDefaultTypeInternal _CoolingScheduleStrategy_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 AllNodesPerformedAcceptanceStrategyDefaultTypeInternal _AllNodesPerformedAcceptanceStrategy_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 AbsencesBasedAcceptanceStrategyDefaultTypeInternal _AbsencesBasedAcceptanceStrategy_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 RuinStrategyDefaultTypeInternal _RuinStrategy_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 RecreateParametersDefaultTypeInternal _RecreateParameters_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 AcceptanceStrategyDefaultTypeInternal _AcceptanceStrategy_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 RecreateStrategyDefaultTypeInternal _RecreateStrategy_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 RuinRecreateParametersDefaultTypeInternal _RuinRecreateParameters_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 IteratedLocalSearchParametersDefaultTypeInternal _IteratedLocalSearchParameters_default_instance_
PROTOBUF_CONSTINIT const uint32_t RuinCompositionStrategy_Value_internal_data_ []
PROTOBUF_CONSTINIT const uint32_t PerturbationStrategy_Value_internal_data_ []
PROTOBUF_CONSTINIT const uint32_t CoolingScheduleStrategy_Value_internal_data_ []
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull SpatiallyCloseRoutesRuinStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull RandomWalkRuinStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull SISRRuinStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull RuinStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull RecreateParameters_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull RecreateStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull RuinCompositionStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull RuinRecreateParameters_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull PerturbationStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull CoolingScheduleStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull GreedyDescentAcceptanceStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull SimulatedAnnealingAcceptanceStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull AllNodesPerformedAcceptanceStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MoreNodesPerformedAcceptanceStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull AbsencesBasedAcceptanceStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull AcceptanceStrategy_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull IteratedLocalSearchParameters_class_data_
constexpr RuinCompositionStrategy_Value RuinCompositionStrategy_Value_Value_MIN
constexpr RuinCompositionStrategy_Value RuinCompositionStrategy_Value_Value_MAX
constexpr int RuinCompositionStrategy_Value_Value_ARRAYSIZE = 3 + 1
constexpr PerturbationStrategy_Value PerturbationStrategy_Value_Value_MIN
constexpr PerturbationStrategy_Value PerturbationStrategy_Value_Value_MAX
constexpr int PerturbationStrategy_Value_Value_ARRAYSIZE = 1 + 1
constexpr CoolingScheduleStrategy_Value CoolingScheduleStrategy_Value_Value_MIN
constexpr CoolingScheduleStrategy_Value CoolingScheduleStrategy_Value_Value_MAX
constexpr int CoolingScheduleStrategy_Value_Value_ARRAYSIZE = 2 + 1
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 RoutingSearchParameters_LocalSearchNeighborhoodOperatorsDefaultTypeInternal _RoutingSearchParameters_LocalSearchNeighborhoodOperators_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 RoutingSearchParameters_ImprovementSearchLimitParametersDefaultTypeInternal _RoutingSearchParameters_ImprovementSearchLimitParameters_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 RoutingModelParametersDefaultTypeInternal _RoutingModelParameters_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 RoutingSearchParametersDefaultTypeInternal _RoutingSearchParameters_default_instance_
PROTOBUF_CONSTINIT const uint32_t RoutingSearchParameters_SchedulingSolver_internal_data_ []
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull RoutingSearchParameters_LocalSearchNeighborhoodOperators_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull RoutingSearchParameters_ImprovementSearchLimitParameters_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull RoutingSearchParameters_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull RoutingModelParameters_class_data_
constexpr RoutingSearchParameters_SchedulingSolver RoutingSearchParameters_SchedulingSolver_SchedulingSolver_MIN
constexpr RoutingSearchParameters_SchedulingSolver RoutingSearchParameters_SchedulingSolver_SchedulingSolver_MAX
constexpr int RoutingSearchParameters_SchedulingSolver_SchedulingSolver_ARRAYSIZE = 2 + 1
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 RegularLimitParametersDefaultTypeInternal _RegularLimitParameters_default_instance_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull RegularLimitParameters_class_data_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 SubSolverStatisticsDefaultTypeInternal _SubSolverStatistics_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 LocalSearchStatistics_LocalSearchOperatorStatisticsDefaultTypeInternal _LocalSearchStatistics_LocalSearchOperatorStatistics_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 LocalSearchStatistics_LocalSearchFilterStatisticsDefaultTypeInternal _LocalSearchStatistics_LocalSearchFilterStatistics_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 LocalSearchStatistics_FirstSolutionStatisticsDefaultTypeInternal _LocalSearchStatistics_FirstSolutionStatistics_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 ConstraintSolverStatisticsDefaultTypeInternal _ConstraintSolverStatistics_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 LocalSearchStatisticsDefaultTypeInternal _LocalSearchStatistics_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 SearchStatisticsDefaultTypeInternal _SearchStatistics_default_instance_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull LocalSearchStatistics_FirstSolutionStatistics_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull LocalSearchStatistics_LocalSearchOperatorStatistics_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull LocalSearchStatistics_LocalSearchFilterStatistics_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull LocalSearchStatistics_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull ConstraintSolverStatistics_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull SubSolverStatistics_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull SearchStatistics_class_data_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 ConstraintSolverParametersDefaultTypeInternal _ConstraintSolverParameters_default_instance_
PROTOBUF_CONSTINIT const uint32_t ConstraintSolverParameters_TrailCompression_internal_data_ []
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull ConstraintSolverParameters_class_data_
constexpr ConstraintSolverParameters_TrailCompression ConstraintSolverParameters_TrailCompression_TrailCompression_MIN
constexpr ConstraintSolverParameters_TrailCompression ConstraintSolverParameters_TrailCompression_TrailCompression_MAX
constexpr int ConstraintSolverParameters_TrailCompression_TrailCompression_ARRAYSIZE = 1 + 1
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 FlowNodeProtoDefaultTypeInternal _FlowNodeProto_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 FlowArcProtoDefaultTypeInternal _FlowArcProto_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 FlowModelProtoDefaultTypeInternal _FlowModelProto_default_instance_
PROTOBUF_CONSTINIT const uint32_t FlowModelProto_ProblemType_internal_data_ []
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull FlowArcProto_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull FlowNodeProto_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull FlowModelProto_class_data_
constexpr FlowModelProto_ProblemType FlowModelProto_ProblemType_ProblemType_MIN
constexpr FlowModelProto_ProblemType FlowModelProto_ProblemType_ProblemType_MAX
constexpr int FlowModelProto_ProblemType_ProblemType_ARRAYSIZE = 2 + 1
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 PartialVariableAssignmentDefaultTypeInternal _PartialVariableAssignment_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 OptionalDoubleDefaultTypeInternal _OptionalDouble_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPVariableProtoDefaultTypeInternal _MPVariableProto_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPSosConstraintDefaultTypeInternal _MPSosConstraint_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPSolveInfoDefaultTypeInternal _MPSolveInfo_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPSolutionDefaultTypeInternal _MPSolution_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPQuadraticObjectiveDefaultTypeInternal _MPQuadraticObjective_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPQuadraticConstraintDefaultTypeInternal _MPQuadraticConstraint_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPModelProto_AnnotationDefaultTypeInternal _MPModelProto_Annotation_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPConstraintProtoDefaultTypeInternal _MPConstraintProto_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPArrayWithConstantConstraintDefaultTypeInternal _MPArrayWithConstantConstraint_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPArrayConstraintDefaultTypeInternal _MPArrayConstraint_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPAbsConstraintDefaultTypeInternal _MPAbsConstraint_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPSolverCommonParametersDefaultTypeInternal _MPSolverCommonParameters_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPSolutionResponseDefaultTypeInternal _MPSolutionResponse_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPModelDeltaProto_VariableOverridesEntry_DoNotUseDefaultTypeInternal _MPModelDeltaProto_VariableOverridesEntry_DoNotUse_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPModelDeltaProto_ConstraintOverridesEntry_DoNotUseDefaultTypeInternal _MPModelDeltaProto_ConstraintOverridesEntry_DoNotUse_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPIndicatorConstraintDefaultTypeInternal _MPIndicatorConstraint_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPModelDeltaProtoDefaultTypeInternal _MPModelDeltaProto_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPGeneralConstraintProtoDefaultTypeInternal _MPGeneralConstraintProto_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPModelProtoDefaultTypeInternal _MPModelProto_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 MPModelRequestDefaultTypeInternal _MPModelRequest_default_instance_
PROTOBUF_CONSTINIT const uint32_t MPSosConstraint_Type_internal_data_ []
PROTOBUF_CONSTINIT const uint32_t MPModelProto_Annotation_TargetType_internal_data_ []
PROTOBUF_CONSTINIT const uint32_t MPSolverCommonParameters_LPAlgorithmValues_internal_data_ []
PROTOBUF_CONSTINIT const uint32_t MPModelRequest_SolverType_internal_data_ []
PROTOBUF_CONSTINIT const uint32_t MPSolverResponseStatus_internal_data_ []
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPVariableProto_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPConstraintProto_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPGeneralConstraintProto_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPIndicatorConstraint_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPSosConstraint_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPQuadraticConstraint_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPAbsConstraint_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPArrayConstraint_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPArrayWithConstantConstraint_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPQuadraticObjective_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull PartialVariableAssignment_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPModelProto_Annotation_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPModelProto_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull OptionalDouble_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPSolverCommonParameters_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPModelDeltaProto_VariableOverridesEntry_DoNotUse_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPModelDeltaProto_ConstraintOverridesEntry_DoNotUse_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPModelDeltaProto_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPModelRequest_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPSolution_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPSolveInfo_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull MPSolutionResponse_class_data_
constexpr MPSosConstraint_Type MPSosConstraint_Type_Type_MIN
constexpr MPSosConstraint_Type MPSosConstraint_Type_Type_MAX
constexpr int MPSosConstraint_Type_Type_ARRAYSIZE = 1 + 1
constexpr MPModelProto_Annotation_TargetType MPModelProto_Annotation_TargetType_TargetType_MIN
constexpr MPModelProto_Annotation_TargetType MPModelProto_Annotation_TargetType_TargetType_MAX
constexpr int MPModelProto_Annotation_TargetType_TargetType_ARRAYSIZE = 2 + 1
constexpr MPSolverCommonParameters_LPAlgorithmValues MPSolverCommonParameters_LPAlgorithmValues_LPAlgorithmValues_MIN
constexpr MPSolverCommonParameters_LPAlgorithmValues MPSolverCommonParameters_LPAlgorithmValues_LPAlgorithmValues_MAX
constexpr int MPSolverCommonParameters_LPAlgorithmValues_LPAlgorithmValues_ARRAYSIZE = 3 + 1
constexpr MPModelRequest_SolverType MPModelRequest_SolverType_SolverType_MIN
constexpr MPModelRequest_SolverType MPModelRequest_SolverType_SolverType_MAX
constexpr int MPModelRequest_SolverType_SolverType_ARRAYSIZE = 102 + 1
constexpr MPSolverResponseStatus MPSolverResponseStatus_MIN
constexpr MPSolverResponseStatus MPSolverResponseStatus_MAX
constexpr int MPSolverResponseStatus_ARRAYSIZE = 113 + 1
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 GScipSolvingStatsDefaultTypeInternal _GScipSolvingStats_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 GScipParameters_StringParamsEntry_DoNotUseDefaultTypeInternal _GScipParameters_StringParamsEntry_DoNotUse_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 GScipParameters_RealParamsEntry_DoNotUseDefaultTypeInternal _GScipParameters_RealParamsEntry_DoNotUse_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 GScipParameters_LongParamsEntry_DoNotUseDefaultTypeInternal _GScipParameters_LongParamsEntry_DoNotUse_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 GScipParameters_IntParamsEntry_DoNotUseDefaultTypeInternal _GScipParameters_IntParamsEntry_DoNotUse_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 GScipParameters_CharParamsEntry_DoNotUseDefaultTypeInternal _GScipParameters_CharParamsEntry_DoNotUse_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 GScipParameters_BoolParamsEntry_DoNotUseDefaultTypeInternal _GScipParameters_BoolParamsEntry_DoNotUse_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 GScipParametersDefaultTypeInternal _GScipParameters_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 GScipOutputDefaultTypeInternal _GScipOutput_default_instance_
PROTOBUF_CONSTINIT const uint32_t GScipParameters_Emphasis_internal_data_ []
PROTOBUF_CONSTINIT const uint32_t GScipParameters_MetaParamValue_internal_data_ []
PROTOBUF_CONSTINIT const uint32_t GScipOutput_Status_internal_data_ []
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull GScipParameters_BoolParamsEntry_DoNotUse_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull GScipParameters_IntParamsEntry_DoNotUse_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull GScipParameters_LongParamsEntry_DoNotUse_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull GScipParameters_RealParamsEntry_DoNotUse_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull GScipParameters_CharParamsEntry_DoNotUse_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull GScipParameters_StringParamsEntry_DoNotUse_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull GScipParameters_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull GScipSolvingStats_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull GScipOutput_class_data_
constexpr GScipParameters_Emphasis GScipParameters_Emphasis_Emphasis_MIN
constexpr GScipParameters_Emphasis GScipParameters_Emphasis_Emphasis_MAX
constexpr int GScipParameters_Emphasis_Emphasis_ARRAYSIZE = 9 + 1
constexpr GScipParameters_MetaParamValue GScipParameters_MetaParamValue_MetaParamValue_MIN
constexpr GScipParameters_MetaParamValue GScipParameters_MetaParamValue_MetaParamValue_MAX
constexpr int GScipParameters_MetaParamValue_MetaParamValue_ARRAYSIZE = 3 + 1
constexpr GScipOutput_Status GScipOutput_Status_Status_MIN
constexpr GScipOutput_Status GScipOutput_Status_Status_MAX
constexpr int GScipOutput_Status_Status_ARRAYSIZE = 16 + 1
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 TeacherDefaultTypeInternal _Teacher_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 StudentAssignmentDefaultTypeInternal _StudentAssignment_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 StudentDefaultTypeInternal _Student_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 RoomDefaultTypeInternal _Room_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 CourseDefaultTypeInternal _Course_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 ClassAssignmentDefaultTypeInternal _ClassAssignment_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 CourseSchedulingResultDefaultTypeInternal _CourseSchedulingResult_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 CourseSchedulingModelDefaultTypeInternal _CourseSchedulingModel_default_instance_
PROTOBUF_CONSTINIT const uint32_t CourseSchedulingResultStatus_internal_data_ []
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull CourseSchedulingModel_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull CourseSchedulingResult_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull ClassAssignment_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull StudentAssignment_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull Course_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull Teacher_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull Student_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull Room_class_data_
constexpr CourseSchedulingResultStatus CourseSchedulingResultStatus_MIN
constexpr CourseSchedulingResultStatus CourseSchedulingResultStatus_MAX
constexpr int CourseSchedulingResultStatus_ARRAYSIZE = 6 + 1
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 CapacityConstraintProto_CapacityTerm_ElementWeightPairDefaultTypeInternal _CapacityConstraintProto_CapacityTerm_ElementWeightPair_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 CapacityConstraintProto_CapacityTermDefaultTypeInternal _CapacityConstraintProto_CapacityTerm_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 CapacityConstraintProtoDefaultTypeInternal _CapacityConstraintProto_default_instance_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull CapacityConstraintProto_CapacityTerm_ElementWeightPair_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull CapacityConstraintProto_CapacityTerm_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull CapacityConstraintProto_class_data_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 SetCoverProto_SubsetDefaultTypeInternal _SetCoverProto_Subset_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 SetCoverSolutionResponseDefaultTypeInternal _SetCoverSolutionResponse_default_instance_
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 SetCoverProtoDefaultTypeInternal _SetCoverProto_default_instance_
PROTOBUF_CONSTINIT const uint32_t SetCoverSolutionResponse_Status_internal_data_ []
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull SetCoverProto_Subset_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull SetCoverProto_class_data_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull SetCoverSolutionResponse_class_data_
constexpr SetCoverSolutionResponse_Status SetCoverSolutionResponse_Status_Status_MIN
constexpr SetCoverSolutionResponse_Status SetCoverSolutionResponse_Status_Status_MAX
constexpr int SetCoverSolutionResponse_Status_Status_ARRAYSIZE = 4 + 1
PROTOBUF_ATTRIBUTE_NO_DESTROY PROTOBUF_CONSTINIT OR_PROTO_DLL PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 Int128DefaultTypeInternal _Int128_default_instance_
PROTOBUF_CONSTINIT PROTOBUF_ATTRIBUTE_INIT_PRIORITY1 const::google::protobuf::internal::ClassDataFull Int128_class_data_
PROTOBUF_CONSTINIT const uint32_t OptionalBoolean_internal_data_ []
constexpr OptionalBoolean OptionalBoolean_MIN
constexpr OptionalBoolean OptionalBoolean_MAX
constexpr int OptionalBoolean_ARRAYSIZE = 3 + 1

Typedef Documentation

◆ AlignedAllocator

◆ AlignedVector

template<typename T, size_t alignment_bytes>
using operations_research::AlignedVector = std::vector<T, AlignedAllocator<T, alignment_bytes>>

Definition at line 78 of file aligned_memory.h.

◆ ArcId

using operations_research::ArcId = SubDagComputer::ArcId

Definition at line 3165 of file local_search.cc.

◆ BaseInt

Definition at line 39 of file base_types.h.

◆ BenchmarksTableRow

Initial value:
std::tuple<std::string, std::vector<std::string>, FileFormat>

Definition at line 492 of file set_cover_solve.cc.

◆ CapacityElements

◆ CapacitySubsets

◆ CapacityWeight

Definition at line 41 of file capacity_model.h.

◆ CapacityWeights

◆ CL

◆ ColumnEntryRange

using operations_research::ColumnEntryRange = util_intops::StrongIntRange<ColumnEntryIndex>

Definition at line 56 of file base_types.h.

◆ CompressedColumn

using operations_research::CompressedColumn = CompressedStrongVector<ColumnEntryIndex, ElementIndex>

Definition at line 259 of file base_types.h.

◆ CompressedColumnIterator

◆ CompressedColumnView

◆ CompressedRow

using operations_research::CompressedRow = CompressedStrongVector<RowEntryIndex, SubsetIndex>

Definition at line 260 of file base_types.h.

◆ CompressedRowIterator

◆ CompressedRowView

◆ CoreToFullElementMapVector

◆ CoreToFullSubsetMapVector

◆ Cost

using operations_research::Cost = double

Definition at line 32 of file base_types.h.

◆ CostValue

using operations_research::CostValue = BlossomGraph::CostValue

Definition at line 121 of file perfect_matching.cc.

◆ ElementBoolVector

Definition at line 72 of file base_types.h.

◆ ElementCostVector

Definition at line 59 of file base_types.h.

◆ ElementRange

using operations_research::ElementRange = util_intops::StrongIntRange<ElementIndex>

Definition at line 55 of file base_types.h.

◆ ElementToIntVector

Definition at line 64 of file base_types.h.

◆ ElementToSubsetVector

◆ Fraction

typedef std::pair<int64_t, int64_t> operations_research::Fraction

Definition at line 25 of file rational_approximation.h.

◆ FullElementBoolVector

Definition at line 58 of file set_cover_views.h.

◆ FullElementCostVector

Definition at line 56 of file set_cover_views.h.

◆ FullElementToIntVector

◆ FullSubsetBoolVector

Definition at line 59 of file set_cover_views.h.

◆ FullSubsetCostVector

Definition at line 57 of file set_cover_views.h.

◆ FullSubsetToIntVector

◆ FullToCoreElementMapVector

◆ FullToCoreSubsetMapVector

◆ Graph

◆ GScipBranchingPriority

using operations_research::GScipBranchingPriority = absl::flat_hash_map<SCIP_VAR*, int>

Definition at line 133 of file gscip.h.

◆ GScipMessageHandler

Initial value:
std::function<void(GScipMessageType type, absl::string_view message)>

Definition at line 36 of file gscip_message_handler.h.

◆ GScipSolution

using operations_research::GScipSolution = absl::flat_hash_map<SCIP_VAR*, double>

Definition at line 89 of file gscip.h.

◆ Int16ZVector

Definition at line 159 of file zvector.h.

◆ Int32ZVector

Definition at line 160 of file zvector.h.

◆ Int64ZVector

Definition at line 161 of file zvector.h.

◆ Int8ZVector

Definition at line 158 of file zvector.h.

◆ KnapsackItemPtr

◆ MPSolverInterfaceFactory

Definition at line 1936 of file linear_solver.h.

◆ NeighborAccessor

typedef std::function< const std::vector< int > &(int, int)> operations_research::NeighborAccessor
Initial value:
std::function<const std::vector<int>&(int, int)>

Definition at line 346 of file local_search.cc.

◆ NodeId

using operations_research::NodeId = SubDagComputer::NodeId

Definition at line 3119 of file local_search.cc.

◆ NodeIndex

Definition at line 120 of file perfect_matching.cc.

◆ PathDistance

Definition at line 90 of file shortest_paths.h.

◆ PathNodeIndex

Definition at line 455 of file hamiltonian_path.h.

◆ random_engine_t

using operations_research::random_engine_t = std::mt19937_64

Definition at line 23 of file random_engine.h.

◆ RoutingCumulDependentTransitCallback2

Definition at line 54 of file routing_types.h.

◆ RoutingNodeEvaluator2

typedef std::function<int64_t(RoutingNodeIndex, RoutingNodeIndex)> operations_research::RoutingNodeEvaluator2

Definition at line 33 of file cvrptw_lib.h.

◆ RoutingTransitCallback1

typedef std::function<int64_t(int64_t)> operations_research::RoutingTransitCallback1

Definition at line 50 of file routing_types.h.

◆ RoutingTransitCallback2

typedef std::function<int64_t(int64_t, int64_t)> operations_research::RoutingTransitCallback2

Definition at line 51 of file routing_types.h.

◆ ScopedTimeDistributionUpdater

◆ ScopedTimeStats

◆ SparseColumn

using operations_research::SparseColumn = util_intops::StrongVector<ColumnEntryIndex, ElementIndex>

Definition at line 61 of file base_types.h.

◆ SparseColumnView

◆ SparseRow

using operations_research::SparseRow = util_intops::StrongVector<RowEntryIndex, SubsetIndex>

Definition at line 62 of file base_types.h.

◆ SparseRowView

Definition at line 69 of file base_types.h.

◆ StrictVector

template<typename IndexType, typename ValueType>
using operations_research::StrictVector = glop::StrictITIVector<IndexType, ValueType>

Definition at line 44 of file set_cover_mip.cc.

◆ SubsetBoolVector

Definition at line 71 of file base_types.h.

◆ SubsetCostVector

Definition at line 58 of file base_types.h.

◆ SubsetRange

using operations_research::SubsetRange = util_intops::StrongIntRange<SubsetIndex>

Definition at line 54 of file base_types.h.

◆ SubsetToIntVector

Definition at line 65 of file base_types.h.

◆ UInt16ZVector

Definition at line 163 of file zvector.h.

◆ UInt32ZVector

Definition at line 164 of file zvector.h.

◆ UInt64ZVector

Definition at line 165 of file zvector.h.

◆ UInt8ZVector

Definition at line 162 of file zvector.h.

◆ UnsafeDenseSet

template<typename T>
using operations_research::UnsafeDenseSet = DenseSet<T, false>

Definition at line 135 of file dense_set.h.

◆ value_type_t

template<class Iterator>
using operations_research::value_type_t = typename std::iterator_traits<Iterator>::value_type

Definition at line 24 of file sort.h.

◆ VariableDomainId

using operations_research::VariableDomainId = LocalSearchState::VariableDomainId

Definition at line 2988 of file local_search.cc.

Enumeration Type Documentation

◆ BronKerboschAlgorithmStatus

Enumerator
COMPLETED 
INTERRUPTED 

Definition at line 73 of file cliques.h.

◆ CliqueResponse

Enumerator
CONTINUE 
STOP 

Definition at line 63 of file cliques.h.

◆ ConstraintHandlerCallbackType

Enumerator
kSepaLp 
kSepaSol 
kEnfoLp 
kEnfoPs 
kConsCheck 
kConsLock 

Definition at line 462 of file gscip_constraint_handler.h.

◆ ConstraintSolverParameters_TrailCompression

Enumerator
ConstraintSolverParameters_TrailCompression_NO_COMPRESSION 
ConstraintSolverParameters_TrailCompression_COMPRESS_WITH_ZLIB 
ConstraintSolverParameters_TrailCompression_ConstraintSolverParameters_TrailCompression_INT_MIN_SENTINEL_DO_NOT_USE_ 
ConstraintSolverParameters_TrailCompression_ConstraintSolverParameters_TrailCompression_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 73 of file solver_parameters.pb.h.

◆ CoolingScheduleStrategy_Value

Enumerator
CoolingScheduleStrategy_Value_UNSET 
CoolingScheduleStrategy_Value_EXPONENTIAL 
CoolingScheduleStrategy_Value_LINEAR 
CoolingScheduleStrategy_Value_CoolingScheduleStrategy_Value_INT_MIN_SENTINEL_DO_NOT_USE_ 
CoolingScheduleStrategy_Value_CoolingScheduleStrategy_Value_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 224 of file routing_ils.pb.h.

◆ CourseSchedulingResultStatus

Enumerator
COURSE_SCHEDULING_RESULT_STATUS_UNSPECIFIED 
SOLVER_FEASIBLE 
SOLVER_OPTIMAL 
SOLVER_INFEASIBLE 
SOLVER_MODEL_INVALID 
SOLVER_NOT_SOLVED 
ABNORMAL 
CourseSchedulingResultStatus_INT_MIN_SENTINEL_DO_NOT_USE_ 
CourseSchedulingResultStatus_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 101 of file course_scheduling.pb.h.

◆ CUSTOM_INTERRUPT_REASON

Enumerator
CALLBACK_EXCEPTION 

Definition at line 201 of file xpress_interface.cc.

◆ DimensionSchedulingStatus

Enumerator
OPTIMAL 
RELAXED_OPTIMAL_ONLY 
FEASIBLE 
INFEASIBLE 

Definition at line 158 of file routing_lp_scheduling.h.

◆ FileFormat

Enumerator
EMPTY 
ORLIB 
RAIL 
FIMI 
PROTO 
PROTO_BIN 
TXT 

Definition at line 157 of file set_cover_solve.cc.

◆ FirstSolutionStrategy_Value

Enumerator
FirstSolutionStrategy_Value_UNSET 
FirstSolutionStrategy_Value_AUTOMATIC 
FirstSolutionStrategy_Value_PATH_CHEAPEST_ARC 
FirstSolutionStrategy_Value_PATH_MOST_CONSTRAINED_ARC 
FirstSolutionStrategy_Value_EVALUATOR_STRATEGY 
FirstSolutionStrategy_Value_SAVINGS 
FirstSolutionStrategy_Value_PARALLEL_SAVINGS 
FirstSolutionStrategy_Value_SWEEP 
FirstSolutionStrategy_Value_CHRISTOFIDES 
FirstSolutionStrategy_Value_ALL_UNPERFORMED 
FirstSolutionStrategy_Value_BEST_INSERTION 
FirstSolutionStrategy_Value_PARALLEL_CHEAPEST_INSERTION 
FirstSolutionStrategy_Value_SEQUENTIAL_CHEAPEST_INSERTION 
FirstSolutionStrategy_Value_LOCAL_CHEAPEST_INSERTION 
FirstSolutionStrategy_Value_LOCAL_CHEAPEST_COST_INSERTION 
FirstSolutionStrategy_Value_GLOBAL_CHEAPEST_ARC 
FirstSolutionStrategy_Value_LOCAL_CHEAPEST_ARC 
FirstSolutionStrategy_Value_FIRST_UNBOUND_MIN_VALUE 
FirstSolutionStrategy_Value_FirstSolutionStrategy_Value_INT_MIN_SENTINEL_DO_NOT_USE_ 
FirstSolutionStrategy_Value_FirstSolutionStrategy_Value_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 92 of file routing_enums.pb.h.

◆ FlowModelProto_ProblemType

Enumerator
FlowModelProto_ProblemType_LINEAR_SUM_ASSIGNMENT 
FlowModelProto_ProblemType_MAX_FLOW 
FlowModelProto_ProblemType_MIN_COST_FLOW 

Definition at line 81 of file flow_problem.pb.h.

◆ GScipCallbackResult

Enumerator
kDidNotRun 
kDelayed 
kDidNotFind 
kFeasible 
kInfeasible 
kUnbounded 
kCutOff 
kSeparated 
kNewRound 
kReducedDomain 
kConstraintAdded 
kConstraintChanged 
kBranched 
kSolveLp 
kFoundSolution 
kSuspend 
kSuccess 
kDelayNode 

Definition at line 23 of file gscip_callback_result.h.

◆ GScipHintResult

Enumerator
kInfeasible 
kRejected 
kAccepted 

Definition at line 587 of file gscip.h.

◆ GScipMessageType

Enumerator
kInfoMessage 
kDialogMessage 
kWarningMessage 

Definition at line 28 of file gscip_message_handler.h.

◆ GScipOutput_Status

Enumerator
GScipOutput_Status_UNKNOWN 
GScipOutput_Status_USER_INTERRUPT 
GScipOutput_Status_NODE_LIMIT 
GScipOutput_Status_TOTAL_NODE_LIMIT 
GScipOutput_Status_STALL_NODE_LIMIT 
GScipOutput_Status_TIME_LIMIT 
GScipOutput_Status_MEM_LIMIT 
GScipOutput_Status_GAP_LIMIT 
GScipOutput_Status_SOL_LIMIT 
GScipOutput_Status_BEST_SOL_LIMIT 
GScipOutput_Status_RESTART_LIMIT 
GScipOutput_Status_OPTIMAL 
GScipOutput_Status_INFEASIBLE 
GScipOutput_Status_UNBOUNDED 
GScipOutput_Status_INF_OR_UNBD 
GScipOutput_Status_TERMINATE 
GScipOutput_Status_INVALID_SOLVER_PARAMETERS 
GScipOutput_Status_GScipOutput_Status_INT_MIN_SENTINEL_DO_NOT_USE_ 
GScipOutput_Status_GScipOutput_Status_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 201 of file gscip.pb.h.

◆ GScipParameters_Emphasis

Enumerator
GScipParameters_Emphasis_DEFAULT_EMPHASIS 
GScipParameters_Emphasis_COUNTER 
GScipParameters_Emphasis_CP_SOLVER 
GScipParameters_Emphasis_EASY_CIP 
GScipParameters_Emphasis_FEASIBILITY 
GScipParameters_Emphasis_HARD_LP 
GScipParameters_Emphasis_OPTIMALITY 
GScipParameters_Emphasis_PHASE_FEAS 
GScipParameters_Emphasis_PHASE_IMPROVE 
GScipParameters_Emphasis_PHASE_PROOF 
GScipParameters_Emphasis_GScipParameters_Emphasis_INT_MIN_SENTINEL_DO_NOT_USE_ 
GScipParameters_Emphasis_GScipParameters_Emphasis_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 119 of file gscip.pb.h.

◆ GScipParameters_MetaParamValue

Enumerator
GScipParameters_MetaParamValue_DEFAULT_META_PARAM_VALUE 
GScipParameters_MetaParamValue_AGGRESSIVE 
GScipParameters_MetaParamValue_FAST 
GScipParameters_MetaParamValue_OFF 
GScipParameters_MetaParamValue_GScipParameters_MetaParamValue_INT_MIN_SENTINEL_DO_NOT_USE_ 
GScipParameters_MetaParamValue_GScipParameters_MetaParamValue_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 163 of file gscip.pb.h.

◆ GScipVarType

Enumerator
kContinuous 
kBinary 
kInteger 
kImpliedInteger 

Definition at line 120 of file gscip.h.

◆ LocalCheapestInsertionParameters_InsertionSortingProperty

Enumerator
LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_UNSPECIFIED 
LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_ALLOWED_VEHICLES 
LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_PENALTY 
LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_PENALTY_OVER_ALLOWED_VEHICLES_RATIO 
LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_HIGHEST_AVG_ARC_COST_TO_VEHICLE_START_ENDS 
LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_LOWEST_AVG_ARC_COST_TO_VEHICLE_START_ENDS 
LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_LOWEST_MIN_ARC_COST_TO_VEHICLE_START_ENDS 
LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_HIGHEST_DIMENSION_USAGE 
LocalCheapestInsertionParameters_InsertionSortingProperty_SORTING_PROPERTY_RANDOM 
LocalCheapestInsertionParameters_InsertionSortingProperty_LocalCheapestInsertionParameters_InsertionSortingProperty_INT_MIN_SENTINEL_DO_NOT_USE_ 
LocalCheapestInsertionParameters_InsertionSortingProperty_LocalCheapestInsertionParameters_InsertionSortingProperty_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 124 of file routing_heuristic_parameters.pb.h.

◆ LocalCheapestInsertionParameters_PairInsertionStrategy

Enumerator
LocalCheapestInsertionParameters_PairInsertionStrategy_AUTOMATIC 
LocalCheapestInsertionParameters_PairInsertionStrategy_BEST_PICKUP_THEN_BEST_DELIVERY 
LocalCheapestInsertionParameters_PairInsertionStrategy_BEST_PICKUP_DELIVERY_PAIR 
LocalCheapestInsertionParameters_PairInsertionStrategy_BEST_PICKUP_DELIVERY_PAIR_MULTITOUR 
LocalCheapestInsertionParameters_PairInsertionStrategy_LocalCheapestInsertionParameters_PairInsertionStrategy_INT_MIN_SENTINEL_DO_NOT_USE_ 
LocalCheapestInsertionParameters_PairInsertionStrategy_LocalCheapestInsertionParameters_PairInsertionStrategy_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 86 of file routing_heuristic_parameters.pb.h.

◆ LocalSearchMetaheuristic_Value

Enumerator
LocalSearchMetaheuristic_Value_UNSET 
LocalSearchMetaheuristic_Value_AUTOMATIC 
LocalSearchMetaheuristic_Value_GREEDY_DESCENT 
LocalSearchMetaheuristic_Value_GUIDED_LOCAL_SEARCH 
LocalSearchMetaheuristic_Value_SIMULATED_ANNEALING 
LocalSearchMetaheuristic_Value_TABU_SEARCH 
LocalSearchMetaheuristic_Value_GENERIC_TABU_SEARCH 
LocalSearchMetaheuristic_Value_LocalSearchMetaheuristic_Value_INT_MIN_SENTINEL_DO_NOT_USE_ 
LocalSearchMetaheuristic_Value_LocalSearchMetaheuristic_Value_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 144 of file routing_enums.pb.h.

◆ MPCallbackEvent

Enumerator
kUnknown 
kPolling 
kPresolve 
kSimplex 
kMip 
kMipSolution 
kMipNode 
kBarrier 
kMessage 
kMultiObj 

Definition at line 34 of file linear_solver_callback.h.

◆ MPModelProto_Annotation_TargetType

Enumerator
MPModelProto_Annotation_TargetType_VARIABLE_DEFAULT 
MPModelProto_Annotation_TargetType_CONSTRAINT 
MPModelProto_Annotation_TargetType_GENERAL_CONSTRAINT 

Definition at line 214 of file linear_solver.pb.h.

◆ MPModelRequest_SolverType

Enumerator
MPModelRequest_SolverType_CLP_LINEAR_PROGRAMMING 
MPModelRequest_SolverType_GLOP_LINEAR_PROGRAMMING 
MPModelRequest_SolverType_GLPK_LINEAR_PROGRAMMING 
MPModelRequest_SolverType_GUROBI_LINEAR_PROGRAMMING 
MPModelRequest_SolverType_XPRESS_LINEAR_PROGRAMMING 
MPModelRequest_SolverType_CPLEX_LINEAR_PROGRAMMING 
MPModelRequest_SolverType_HIGHS_LINEAR_PROGRAMMING 
MPModelRequest_SolverType_SCIP_MIXED_INTEGER_PROGRAMMING 
MPModelRequest_SolverType_GLPK_MIXED_INTEGER_PROGRAMMING 
MPModelRequest_SolverType_CBC_MIXED_INTEGER_PROGRAMMING 
MPModelRequest_SolverType_GUROBI_MIXED_INTEGER_PROGRAMMING 
MPModelRequest_SolverType_XPRESS_MIXED_INTEGER_PROGRAMMING 
MPModelRequest_SolverType_CPLEX_MIXED_INTEGER_PROGRAMMING 
MPModelRequest_SolverType_HIGHS_MIXED_INTEGER_PROGRAMMING 
MPModelRequest_SolverType_BOP_INTEGER_PROGRAMMING 
MPModelRequest_SolverType_SAT_INTEGER_PROGRAMMING 
MPModelRequest_SolverType_PDLP_LINEAR_PROGRAMMING 
MPModelRequest_SolverType_KNAPSACK_MIXED_INTEGER_PROGRAMMING 

Definition at line 281 of file linear_solver.pb.h.

◆ MPSolverCommonParameters_LPAlgorithmValues

Enumerator
MPSolverCommonParameters_LPAlgorithmValues_LP_ALGO_UNSPECIFIED 
MPSolverCommonParameters_LPAlgorithmValues_LP_ALGO_DUAL 
MPSolverCommonParameters_LPAlgorithmValues_LP_ALGO_PRIMAL 
MPSolverCommonParameters_LPAlgorithmValues_LP_ALGO_BARRIER 

Definition at line 247 of file linear_solver.pb.h.

◆ MPSolverResponseStatus

Enumerator
MPSOLVER_OPTIMAL 
MPSOLVER_FEASIBLE 
MPSOLVER_INFEASIBLE 
MPSOLVER_UNBOUNDED 
MPSOLVER_ABNORMAL 
MPSOLVER_NOT_SOLVED 
MPSOLVER_MODEL_IS_VALID 
MPSOLVER_CANCELLED_BY_USER 
MPSOLVER_UNKNOWN_STATUS 
MPSOLVER_MODEL_INVALID 
MPSOLVER_MODEL_INVALID_SOLUTION_HINT 
MPSOLVER_MODEL_INVALID_SOLVER_PARAMETERS 
MPSOLVER_SOLVER_TYPE_UNAVAILABLE 
MPSOLVER_INCOMPATIBLE_OPTIONS 

Definition at line 324 of file linear_solver.pb.h.

◆ MPSosConstraint_Type

Enumerator
MPSosConstraint_Type_SOS1_DEFAULT 
MPSosConstraint_Type_SOS2 

Definition at line 182 of file linear_solver.pb.h.

◆ MPSReaderFormat

Enumerator
kAutoDetect 
kFree 
kFixed 

Definition at line 302 of file mps_reader_template.h.

◆ OptionalBoolean

Enumerator
BOOL_UNSPECIFIED 
BOOL_FALSE 
BOOL_TRUE 
OptionalBoolean_INT_MIN_SENTINEL_DO_NOT_USE_ 
OptionalBoolean_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 66 of file optional_boolean.pb.h.

◆ PerturbationStrategy_Value

Enumerator
PerturbationStrategy_Value_UNSET 
PerturbationStrategy_Value_RUIN_AND_RECREATE 
PerturbationStrategy_Value_PerturbationStrategy_Value_INT_MIN_SENTINEL_DO_NOT_USE_ 
PerturbationStrategy_Value_PerturbationStrategy_Value_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 188 of file routing_ils.pb.h.

◆ ProtoWriteFormat

Enumerator
kProtoText 
kProtoBinary 
kJson 
kCanonicalJson 

Definition at line 61 of file file_util.h.

◆ RoundingLockDirection

Enumerator
kUp 
kDown 
kBoth 

Definition at line 109 of file gscip_constraint_handler.h.

◆ RoutingSearchParameters_SchedulingSolver

Enumerator
RoutingSearchParameters_SchedulingSolver_SCHEDULING_UNSET 
RoutingSearchParameters_SchedulingSolver_SCHEDULING_GLOP 
RoutingSearchParameters_SchedulingSolver_SCHEDULING_CP_SAT 
RoutingSearchParameters_SchedulingSolver_RoutingSearchParameters_SchedulingSolver_INT_MIN_SENTINEL_DO_NOT_USE_ 
RoutingSearchParameters_SchedulingSolver_RoutingSearchParameters_SchedulingSolver_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 92 of file routing_parameters.pb.h.

◆ RoutingSearchStatus_Value

Enumerator
RoutingSearchStatus_Value_ROUTING_NOT_SOLVED 
RoutingSearchStatus_Value_ROUTING_SUCCESS 
RoutingSearchStatus_Value_ROUTING_PARTIAL_SUCCESS_LOCAL_OPTIMUM_NOT_REACHED 
RoutingSearchStatus_Value_ROUTING_FAIL 
RoutingSearchStatus_Value_ROUTING_FAIL_TIMEOUT 
RoutingSearchStatus_Value_ROUTING_INVALID 
RoutingSearchStatus_Value_ROUTING_INFEASIBLE 
RoutingSearchStatus_Value_ROUTING_OPTIMAL 
RoutingSearchStatus_Value_RoutingSearchStatus_Value_INT_MIN_SENTINEL_DO_NOT_USE_ 
RoutingSearchStatus_Value_RoutingSearchStatus_Value_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 185 of file routing_enums.pb.h.

◆ RuinCompositionStrategy_Value

Enumerator
RuinCompositionStrategy_Value_UNSET 
RuinCompositionStrategy_Value_RUN_ALL_SEQUENTIALLY 
RuinCompositionStrategy_Value_RUN_ALL_RANDOMLY 
RuinCompositionStrategy_Value_RUN_ONE_RANDOMLY 
RuinCompositionStrategy_Value_RuinCompositionStrategy_Value_INT_MIN_SENTINEL_DO_NOT_USE_ 
RuinCompositionStrategy_Value_RuinCompositionStrategy_Value_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 150 of file routing_ils.pb.h.

◆ ScipSeparationResult

Enumerator
kLazyConstraintAdded 
kCuttingPlaneAdded 
kDidNotFind 

Definition at line 93 of file scip_callback.cc.

◆ SetCoverMipSolver

enum class operations_research::SetCoverMipSolver : int
strong
Enumerator
SCIP 
SAT 
GUROBI 
GLOP 
PDLP 

Definition at line 25 of file set_cover_mip.h.

◆ SetCoverSolutionResponse_Status

Enumerator
SetCoverSolutionResponse_Status_UNDEFINED 
SetCoverSolutionResponse_Status_OPTIMAL 
SetCoverSolutionResponse_Status_FEASIBLE 
SetCoverSolutionResponse_Status_INFEASIBLE 
SetCoverSolutionResponse_Status_INVALID 
SetCoverSolutionResponse_Status_SetCoverSolutionResponse_Status_INT_MIN_SENTINEL_DO_NOT_USE_ 
SetCoverSolutionResponse_Status_SetCoverSolutionResponse_Status_INT_MAX_SENTINEL_DO_NOT_USE_ 

Definition at line 82 of file set_cover.pb.h.

◆ VarTypes

This enum is used internally to do dynamic typing on subclasses of integer variables.

Enumerator
UNSPECIFIED 
DOMAIN_INT_VAR 
BOOLEAN_VAR 
CONST_VAR 
VAR_ADD_CST 
VAR_TIMES_CST 
CST_SUB_VAR 
OPP_VAR 
TRACE_VAR 

Definition at line 130 of file constraint_solveri.h.

Function Documentation

◆ AbslHashValue() [1/2]

template<typename StrongIndexName, typename H>
H operations_research::AbslHashValue ( H h,
const StrongIndex< StrongIndexName > & i )

Definition at line 339 of file strong_integers.h.

◆ AbslHashValue() [2/2]

template<typename StrongIntegerName, typename H>
H operations_research::AbslHashValue ( H h,
const StrongInt64< StrongIntegerName > & i )

Definition at line 344 of file strong_integers.h.

◆ AbslParseFlag()

bool operations_research::AbslParseFlag ( const absl::string_view text,
MPSolver::OptimizationProblemType * solver_type,
std::string * error )

Definition at line 505 of file linear_solver.cc.

◆ AbslStringify() [1/2]

template<typename Sink, typename... T>
void operations_research::AbslStringify ( Sink & sink,
StrongIndex< T... > arg )

Definition at line 257 of file strong_integers.h.

◆ AbslStringify() [2/2]

template<typename Sink, typename... T>
void operations_research::AbslStringify ( Sink & sink,
StrongInt64< T... > arg )

Definition at line 268 of file strong_integers.h.

◆ AbslUnparseFlag()

std::string operations_research::AbslUnparseFlag ( MPSolver::OptimizationProblemType solver_type)
inline

Definition at line 1017 of file linear_solver.h.

◆ AcceptDelta()

bool operations_research::AcceptDelta ( Search * search,
Assignment * delta,
Assignment * deltadelta )

Definition at line 1380 of file constraint_solver.cc.

◆ AcceptNeighbor()

void operations_research::AcceptNeighbor ( Search * search)

Definition at line 1384 of file constraint_solver.cc.

◆ AcceptUncheckedNeighbor()

void operations_research::AcceptUncheckedNeighbor ( Search * search)

Definition at line 1386 of file constraint_solver.cc.

◆ AddCallbackConstraint()

template<typename ConstraintData>
void operations_research::AddCallbackConstraint ( SCIP * scip,
ScipConstraintHandler< ConstraintData > * handler,
const std::string & constraint_name,
const ConstraintData * constraint_data,
const ScipCallbackConstraintOptions & options )

Definition at line 261 of file scip_callback.h.

◆ AddHadOverflow()

bool operations_research::AddHadOverflow ( int64_t x,
int64_t y,
int64_t sum )
inline

Definition at line 98 of file saturated_arithmetic.h.

◆ addhint()

void operations_research::addhint ( const XPRSprob & mLp,
int length,
const double solval[],
const int colind[] )

Definition at line 192 of file xpress_interface.cc.

◆ AddIntoOverflow()

bool operations_research::AddIntoOverflow ( int64_t x,
int64_t * y )
inline

Definition at line 304 of file saturated_arithmetic.h.

◆ AddOverflows()

bool operations_research::AddOverflows ( int64_t x,
int64_t y )
inline

Definition at line 122 of file saturated_arithmetic.h.

◆ AlignDown()

template<size_t alignment_bytes, typename Value>
Value * operations_research::AlignDown ( Value * ptr)
inline

Definition at line 56 of file aligned_memory.h.

◆ AlignedVectorSum()

float operations_research::AlignedVectorSum ( absl::Span< const float > values)
inline

Definition at line 32 of file vector_sum.h.

◆ AlignUp()

template<size_t alignment_bytes, typename Value>
Value * operations_research::AlignUp ( Value * ptr)
inline

Definition at line 45 of file aligned_memory.h.

◆ AppendDimensionCumulFilters()

void operations_research::AppendDimensionCumulFilters ( const std::vector< RoutingDimension * > & dimensions,
const RoutingSearchParameters & parameters,
bool filter_objective_cost,
bool use_chain_cumul_filter,
std::vector< LocalSearchFilterManager::FilterEvent > * filters )

Definition at line 2779 of file routing_filters.cc.

◆ AppendLightWeightDimensionFilters()

void operations_research::AppendLightWeightDimensionFilters ( const PathState * path_state,
const std::vector< RoutingDimension * > & dimensions,
std::vector< LocalSearchFilterManager::FilterEvent > * filters )

Appends dimension-based filters to the given list of filters using a path state.

Definition at line 2706 of file routing_filters.cc.

◆ ApplyMipPresolveSteps()

glop::ProblemStatus operations_research::ApplyMipPresolveSteps ( const glop::GlopParameters & glop_params,
MPModelProto * model,
std::vector< std::unique_ptr< glop::Preprocessor > > * for_postsolve,
SolverLogger * logger )

Definition at line 38 of file sat_solver_utils.cc.

◆ ApplyVerifiedMPModelDelta()

void operations_research::ApplyVerifiedMPModelDelta ( const MPModelDeltaProto & delta,
MPModelProto * model )

Definition at line 981 of file model_validator.cc.

◆ AreAllBooleans()

bool operations_research::AreAllBooleans ( const std::vector< IntVar * > & vars)
inline

Definition at line 4308 of file constraint_solveri.h.

◆ AreAllBound()

bool operations_research::AreAllBound ( const std::vector< IntVar * > & vars)
inline

Definition at line 4299 of file constraint_solveri.h.

◆ AreAllBoundOrNull()

template<class T>
bool operations_research::AreAllBoundOrNull ( const std::vector< IntVar * > & vars,
const std::vector< T > & values )

Returns true if all the variables are assigned to a single value, or if their corresponding value is null.

Definition at line 4315 of file constraint_solveri.h.

◆ AreAllBoundTo()

bool operations_research::AreAllBoundTo ( const std::vector< IntVar * > & vars,
int64_t value )
inline

Returns true if all variables are assigned to 'value'.

Definition at line 4326 of file constraint_solveri.h.

◆ AreAllGreaterOrEqual()

template<class T>
bool operations_research::AreAllGreaterOrEqual ( const std::vector< T > & values,
const T & value )

Definition at line 4229 of file constraint_solveri.h.

◆ AreAllLessOrEqual()

template<class T>
bool operations_research::AreAllLessOrEqual ( const std::vector< T > & values,
const T & value )

Definition at line 4239 of file constraint_solveri.h.

◆ AreAllNegative()

template<class T>
bool operations_research::AreAllNegative ( const std::vector< T > & values)

Definition at line 4254 of file constraint_solveri.h.

◆ AreAllNull()

template<class T>
bool operations_research::AreAllNull ( const std::vector< T > & values)

Definition at line 4224 of file constraint_solveri.h.

◆ AreAllOnes()

template<class T>
bool operations_research::AreAllOnes ( const std::vector< T > & values)

Definition at line 4219 of file constraint_solveri.h.

◆ AreAllPositive()

template<class T>
bool operations_research::AreAllPositive ( const std::vector< T > & values)

Definition at line 4249 of file constraint_solveri.h.

◆ AreAllStrictlyNegative()

template<class T>
bool operations_research::AreAllStrictlyNegative ( const std::vector< T > & values)

Definition at line 4264 of file constraint_solveri.h.

◆ AreAllStrictlyPositive()

template<class T>
bool operations_research::AreAllStrictlyPositive ( const std::vector< T > & values)

Definition at line 4259 of file constraint_solveri.h.

◆ AreBoundsValid()

bool operations_research::AreBoundsValid ( Fractional lower_bound,
Fractional upper_bound )
inline

Definition at line 51 of file preprocessor.cc.

◆ AreWithinAbsoluteOrRelativeTolerances()

template<typename FloatType>
bool operations_research::AreWithinAbsoluteOrRelativeTolerances ( FloatType x,
FloatType y,
FloatType relative_tolerance,
FloatType absolute_tolerance )

Definition at line 131 of file fp_utils.h.

◆ AreWithinAbsoluteTolerance()

template<typename FloatType>
bool operations_research::AreWithinAbsoluteTolerance ( FloatType x,
FloatType y,
FloatType absolute_tolerance )

Definition at line 152 of file fp_utils.h.

◆ AssertOptimalWithBestSolution()

void operations_research::AssertOptimalWithBestSolution ( const GScipResult & actual_result,
const double expected_objective_value,
const GScipSolution & expected_solution,
const double tolerance )

Definition at line 118 of file gscip_testing.cc.

◆ AssertOptimalWithPartialBestSolution()

void operations_research::AssertOptimalWithPartialBestSolution ( const GScipResult & actual_result,
const double expected_objective_value,
const GScipSolution & expected_solution,
const double tolerance )

Definition at line 128 of file gscip_testing.cc.

◆ assign()

Select next search node to expand Select next item_i to operations_research::assign ( using primary propagator)
new

◆ AtMinOrMaxInt64()

bool operations_research::AtMinOrMaxInt64 ( int64_t x)
inline

Definition at line 53 of file saturated_arithmetic.h.

◆ atoi32()

int32_t operations_research::atoi32 ( absl::string_view word)
inline

Definition at line 56 of file strtoint.h.

◆ atoi64()

int64_t operations_research::atoi64 ( absl::string_view word)
inline

Definition at line 57 of file strtoint.h.

◆ AutomaticFirstSolutionStrategy()

operations_research::FirstSolutionStrategy::Value operations_research::AutomaticFirstSolutionStrategy ( bool has_pickup_deliveries,
bool has_node_precedences,
bool has_single_vehicle_node )

Returns the best value for the automatic first solution strategy, based on the given model parameters.

Definition at line 374 of file routing_search.cc.

◆ BasisStatusString()

std::string operations_research::BasisStatusString ( const int stat)

Definition at line 50 of file glpk_formatters.cc.

◆ begin()

ClosedInterval::Iterator operations_research::begin ( ClosedInterval interval)
inline

Definition at line 733 of file sorted_interval_list.h.

◆ Benchmarks()

void operations_research::Benchmarks ( )

Definition at line 536 of file set_cover_solve.cc.

◆ BenchmarksTable()

std::vector< BenchmarksTableRow > operations_research::BenchmarksTable ( )

Definition at line 495 of file set_cover_solve.cc.

◆ BinarySearch()

template<class Point, bool check_bounds = DEBUG_MODE>
Point operations_research::BinarySearch ( Point x_true,
Point x_false,
std::function< bool(Point)> f )

Definition at line 219 of file binary_search.h.

◆ BinarySearchMidpoint()

template<class Point>
Point operations_research::BinarySearchMidpoint ( Point x,
Point y )

Definition at line 188 of file binary_search.h.

◆ BipartiteMinimumVertexCover()

std::vector< bool > operations_research::BipartiteMinimumVertexCover ( const std::vector< std::vector< int > > & left_to_right_arcs,
int num_right )

Definition at line 23 of file minimum_vertex_cover.cc.

◆ BitCount32()

uint32_t operations_research::BitCount32 ( uint32_t n)
inline

Definition at line 56 of file bitset.h.

◆ BitCount64()

uint64_t operations_research::BitCount64 ( uint64_t n)
inline

Definition at line 45 of file bitset.h.

◆ BitCountRange32()

uint32_t operations_research::BitCountRange32 ( const uint32_t * bitset,
uint32_t start,
uint32_t end )

◆ BitCountRange64()

uint64_t operations_research::BitCountRange64 ( const uint64_t * bitset,
uint64_t start,
uint64_t end )

◆ BitLength32()

uint32_t operations_research::BitLength32 ( uint32_t size)
inline

Definition at line 342 of file bitset.h.

◆ BitLength64()

uint64_t operations_research::BitLength64 ( uint64_t size)
inline

Definition at line 341 of file bitset.h.

◆ BitOffset32()

uint32_t operations_research::BitOffset32 ( uint32_t pos)
inline

Definition at line 338 of file bitset.h.

◆ BitOffset64()

uint64_t operations_research::BitOffset64 ( uint64_t pos)
inline

Definition at line 337 of file bitset.h.

◆ BitPos32()

uint32_t operations_research::BitPos32 ( uint32_t pos)
inline

Definition at line 334 of file bitset.h.

◆ BitPos64()

uint32_t operations_research::BitPos64 ( uint64_t pos)
inline

Definition at line 333 of file bitset.h.

◆ BitShift32()

uint32_t operations_research::BitShift32 ( uint32_t v)
inline

Definition at line 346 of file bitset.h.

◆ BitShift64()

uint64_t operations_research::BitShift64 ( uint64_t v)
inline

Definition at line 345 of file bitset.h.

◆ BuildDemonProfiler()

DemonProfiler * operations_research::BuildDemonProfiler ( Solver * solver)
extern

Definition at line 445 of file demon_profiler.cc.

◆ BuildDurationExpr()

IntExpr * operations_research::BuildDurationExpr ( IntervalVar * var)

Definition at line 171 of file sched_expr.cc.

◆ BuildEndExpr()

IntExpr * operations_research::BuildEndExpr ( IntervalVar * var)

Definition at line 181 of file sched_expr.cc.

◆ BuildEulerianPath()

template<typename Graph>
std::vector< typename Graph::NodeIndex > operations_research::BuildEulerianPath ( const Graph & graph,
bool assume_connectivity = true )

Definition at line 143 of file eulerian_path.h.

◆ BuildEulerianPathFromNode()

template<typename NodeIndex, typename Graph>
std::vector< NodeIndex > operations_research::BuildEulerianPathFromNode ( const Graph & graph,
NodeIndex root )

Definition at line 79 of file eulerian_path.h.

◆ BuildEulerianTour()

template<typename Graph>
std::vector< typename Graph::NodeIndex > operations_research::BuildEulerianTour ( const Graph & graph,
bool assume_connectivity = true )

Definition at line 133 of file eulerian_path.h.

◆ BuildEulerianTourFromNode()

template<typename NodeIndex, typename Graph>
std::vector< NodeIndex > operations_research::BuildEulerianTourFromNode ( const Graph & graph,
NodeIndex root,
bool assume_connectivity = true )

Definition at line 121 of file eulerian_path.h.

◆ BuildKruskalMinimumSpanningTree()

template<typename Graph, typename ArcComparator>
std::vector< typename Graph::ArcIndex > operations_research::BuildKruskalMinimumSpanningTree ( const Graph & graph,
const ArcComparator & arc_comparator )

Definition at line 87 of file minimum_spanning_tree.h.

◆ BuildKruskalMinimumSpanningTreeFromSortedArcs()

template<typename Graph>
std::vector< typename Graph::ArcIndex > operations_research::BuildKruskalMinimumSpanningTreeFromSortedArcs ( const Graph & graph,
absl::Span< const typename Graph::ArcIndex > sorted_arcs )

Definition at line 49 of file minimum_spanning_tree.h.

◆ BuildLocalSearchMonitorPrimary()

LocalSearchMonitor * operations_research::BuildLocalSearchMonitorPrimary ( Solver * s)
extern

Definition at line 3228 of file constraint_solver.cc.

◆ BuildLocalSearchProfiler()

LocalSearchProfiler * operations_research::BuildLocalSearchProfiler ( Solver * solver)
extern

Definition at line 3750 of file local_search.cc.

◆ BuildModelCache()

ModelCache * operations_research::BuildModelCache ( Solver * solver)
extern

Definition at line 846 of file model_cache.cc.

◆ BuildPrimMinimumSpanningTree()

template<typename Graph, typename ArcValue>
std::vector< typename Graph::ArcIndex > operations_research::BuildPrimMinimumSpanningTree ( const Graph & graph,
const ArcValue & arc_value )

Definition at line 113 of file minimum_spanning_tree.h.

◆ BuildPrintTrace()

PropagationMonitor * operations_research::BuildPrintTrace ( Solver * s)
extern

Definition at line 877 of file trace.cc.

◆ BuildSafeDurationExpr()

IntExpr * operations_research::BuildSafeDurationExpr ( IntervalVar * var,
int64_t unperformed_value )

Definition at line 196 of file sched_expr.cc.

◆ BuildSafeEndExpr()

IntExpr * operations_research::BuildSafeEndExpr ( IntervalVar * var,
int64_t unperformed_value )

Definition at line 201 of file sched_expr.cc.

◆ BuildSafeStartExpr()

IntExpr * operations_research::BuildSafeStartExpr ( IntervalVar * var,
int64_t unperformed_value )

Definition at line 191 of file sched_expr.cc.

◆ BuildStartExpr()

IntExpr * operations_research::BuildStartExpr ( IntervalVar * var)

Definition at line 161 of file sched_expr.cc.

◆ BuildTrace()

PropagationMonitor * operations_research::BuildTrace ( Solver * s)
extern

Definition at line 3152 of file constraint_solver.cc.

◆ CapAbs()

int64_t operations_research::CapAbs ( int64_t v)
inline

Definition at line 61 of file saturated_arithmetic.h.

◆ CapAdd()

int64_t operations_research::CapAdd ( int64_t x,
int64_t y )
inline

Definition at line 292 of file saturated_arithmetic.h.

◆ CapAddGeneric()

int64_t operations_research::CapAddGeneric ( int64_t x,
int64_t y )
inline

Definition at line 233 of file saturated_arithmetic.h.

◆ CapAddTo()

void operations_research::CapAddTo ( int64_t x,
int64_t * y )
inline

Definition at line 315 of file saturated_arithmetic.h.

◆ CapOpp()

int64_t operations_research::CapOpp ( int64_t v)
inline

Definition at line 59 of file saturated_arithmetic.h.

◆ CapOrFloatAdd()

template<typename T>
T operations_research::CapOrFloatAdd ( T x,
T y )

Definition at line 347 of file saturated_arithmetic.h.

◆ CapProd()

int64_t operations_research::CapProd ( int64_t x,
int64_t y )
inline

Definition at line 332 of file saturated_arithmetic.h.

◆ CapProdGeneric()

int64_t operations_research::CapProdGeneric ( int64_t x,
int64_t y )
inline

Definition at line 258 of file saturated_arithmetic.h.

◆ CapSub()

int64_t operations_research::CapSub ( int64_t x,
int64_t y )
inline

Definition at line 317 of file saturated_arithmetic.h.

◆ CapSubFrom()

void operations_research::CapSubFrom ( int64_t amount,
int64_t * target )
inline

Definition at line 328 of file saturated_arithmetic.h.

◆ CapSubGeneric()

int64_t operations_research::CapSubGeneric ( int64_t x,
int64_t y )
inline

Definition at line 238 of file saturated_arithmetic.h.

◆ CapWithSignOf()

int64_t operations_research::CapWithSignOf ( int64_t x)
inline

Definition at line 143 of file saturated_arithmetic.h.

◆ CeilRatio()

int64_t operations_research::CeilRatio ( int64_t value,
int64_t positive_coeff )

Definition at line 106 of file sorted_interval_list.cc.

◆ CheckNodeIsValid()

template<class GraphType>
void operations_research::CheckNodeIsValid ( typename GraphType::NodeIndex node,
const GraphType & graph )

Definition at line 282 of file dag_shortest_path.h.

◆ ChooseMode()

BaseAssignVariables::Mode operations_research::ChooseMode ( Solver::IntValueStrategy val_str)

Definition at line 2132 of file search.cc.

◆ CleanVariableOnFail()

void operations_research::CleanVariableOnFail ( IntVar * var)
extern

Definition at line 6385 of file expressions.cc.

◆ ClearBit32()

void operations_research::ClearBit32 ( uint32_t *const bitset,
uint32_t pos )
inline

Definition at line 368 of file bitset.h.

◆ ClearBit64()

void operations_research::ClearBit64 ( uint64_t *const bitset,
uint64_t pos )
inline

Definition at line 365 of file bitset.h.

◆ ClearMostCoveredElements() [1/2]

std::vector< SubsetIndex > operations_research::ClearMostCoveredElements ( absl::Span< const SubsetIndex > focus,
BaseInt max_num_subsets,
SetCoverInvariant * inv )

Definition at line 873 of file set_cover_heuristics.cc.

◆ ClearMostCoveredElements() [2/2]

std::vector< SubsetIndex > operations_research::ClearMostCoveredElements ( BaseInt max_num_subsets,
SetCoverInvariant * inv )

Definition at line 867 of file set_cover_heuristics.cc.

◆ ClearRandomSubsets() [1/2]

std::vector< SubsetIndex > operations_research::ClearRandomSubsets ( absl::Span< const SubsetIndex > focus,
BaseInt num_subsets_to_choose,
SetCoverInvariant * inv )

Definition at line 833 of file set_cover_heuristics.cc.

◆ ClearRandomSubsets() [2/2]

std::vector< SubsetIndex > operations_research::ClearRandomSubsets ( BaseInt num_subsets,
SetCoverInvariant * inv )

Definition at line 828 of file set_cover_heuristics.cc.

◆ CompareKnapsackItemWithEfficiencyInDecreasingEfficiencyOrder()

bool operations_research::CompareKnapsackItemWithEfficiencyInDecreasingEfficiencyOrder ( const KnapsackItemWithEfficiency & item1,
const KnapsackItemWithEfficiency & item2 )

Definition at line 733 of file knapsack_solver.cc.

◆ ComputeAllToAllShortestPathsWithMultipleThreads()

template<class GraphType>
void operations_research::ComputeAllToAllShortestPathsWithMultipleThreads ( const GraphType & graph,
const std::vector< PathDistance > & arc_lengths,
int num_threads,
GenericPathContainer< GraphType > *const path_container )

Definition at line 272 of file shortest_paths.h.

◆ ComputeBestVehicleToResourceAssignment()

int64_t operations_research::ComputeBestVehicleToResourceAssignment ( absl::Span< const int > vehicles,
const util_intops::StrongVector< RoutingModel::ResourceClassIndex, std::vector< int > > & resource_indices_per_class,
const util_intops::StrongVector< RoutingModel::ResourceClassIndex, absl::flat_hash_set< int > > & ignored_resources_per_class,
std::function< const std::vector< int64_t > *(int)> vehicle_to_resource_class_assignment_costs,
std::vector< int > * resource_indices )

Definition at line 3207 of file routing_lp_scheduling.cc.

◆ ComputeDagConnectivity()

std::vector< Bitset64< int64_t > > operations_research::ComputeDagConnectivity ( absl::Span< const std::pair< int, int > > arcs,
bool * error_was_cyclic,
std::vector< int > * error_cycle_out )

Definition at line 60 of file dag_connectivity.cc.

◆ ComputeDagConnectivityOrDie()

std::vector< Bitset64< int64_t > > operations_research::ComputeDagConnectivityOrDie ( absl::Span< const std::pair< int, int > > arcs)

Definition at line 111 of file dag_connectivity.cc.

◆ ComputeDeciles()

template<typename T>
std::vector< T > operations_research::ComputeDeciles ( std::vector< T > values)

Definition at line 660 of file set_cover_model.cc.

◆ ComputeFormVarLowerBound()

double operations_research::ComputeFormVarLowerBound ( glp_prob *const problem,
const int num_cstrs,
const int k )
inline

Definition at line 118 of file glpk_computational_form.h.

◆ ComputeFormVarPrimalValue()

double operations_research::ComputeFormVarPrimalValue ( glp_prob *const problem,
const int num_cstrs,
const int k )
inline

Definition at line 108 of file glpk_computational_form.h.

◆ ComputeFormVarReducedCost()

double operations_research::ComputeFormVarReducedCost ( glp_prob *const problem,
const int num_cstrs,
const int k )
inline

Definition at line 98 of file glpk_computational_form.h.

◆ ComputeFormVarStatus()

int operations_research::ComputeFormVarStatus ( glp_prob *const problem,
const int num_cstrs,
const int k )
inline

Definition at line 88 of file glpk_computational_form.h.

◆ ComputeFormVarUpperBound()

double operations_research::ComputeFormVarUpperBound ( glp_prob *const problem,
const int num_cstrs,
const int k )
inline

Definition at line 128 of file glpk_computational_form.h.

◆ ComputeGcdOfRoundedDoubles()

int64_t operations_research::ComputeGcdOfRoundedDoubles ( absl::Span< const double > x,
double scaling_factor )

Definition at line 207 of file fp_utils.cc.

◆ ComputeManyToAllShortestPathsWithMultipleThreads()

template<class GraphType>
void operations_research::ComputeManyToAllShortestPathsWithMultipleThreads ( const GraphType & graph,
const std::vector< PathDistance > & arc_lengths,
const std::vector< typename GraphType::NodeIndex > & sources,
int num_threads,
GenericPathContainer< GraphType > *const path_container )

Definition at line 260 of file shortest_paths.h.

◆ ComputeManyToManyShortestPathsWithMultipleThreads()

template<class GraphType>
void operations_research::ComputeManyToManyShortestPathsWithMultipleThreads ( const GraphType & graph,
const std::vector< PathDistance > & arc_lengths,
const std::vector< typename GraphType::NodeIndex > & sources,
const std::vector< typename GraphType::NodeIndex > & destinations,
int num_threads,
GenericPathContainer< GraphType > *const paths )

Definition at line 744 of file shortest_paths.h.

◆ ComputeMinimumWeightMatching()

template<typename CostType, typename WeightFunctionType, typename GraphType>
absl::StatusOr< std::vector< std::pair< typename GraphType::NodeIndex, typename GraphType::NodeIndex > > > operations_research::ComputeMinimumWeightMatching ( const GraphType & graph,
const WeightFunctionType & weight )

Definition at line 124 of file christofides.h.

◆ ComputeMinimumWeightMatchingWithMIP()

template<typename WeightFunctionType, typename GraphType>
absl::StatusOr< std::vector< std::pair< typename GraphType::NodeIndex, typename GraphType::NodeIndex > > > operations_research::ComputeMinimumWeightMatchingWithMIP ( const GraphType & graph,
const WeightFunctionType & weight )

Definition at line 166 of file christofides.h.

◆ ComputeOneToAllShortestPaths()

template<class GraphType>
void operations_research::ComputeOneToAllShortestPaths ( const GraphType & graph,
const std::vector< PathDistance > & arc_lengths,
typename GraphType::NodeIndex source,
GenericPathContainer< GraphType > *const path_container )

Definition at line 208 of file shortest_paths.h.

◆ ComputeOneToManyShortestPaths()

template<class GraphType>
void operations_research::ComputeOneToManyShortestPaths ( const GraphType & graph,
const std::vector< PathDistance > & arc_lengths,
typename GraphType::NodeIndex source,
const std::vector< typename GraphType::NodeIndex > & destinations,
GenericPathContainer< GraphType > *const path_container )

Definition at line 220 of file shortest_paths.h.

◆ ComputeOneToOneShortestPath()

template<class GraphType>
std::vector< typename GraphType::NodeIndex > operations_research::ComputeOneToOneShortestPath ( const GraphType & graph,
const std::vector< PathDistance > & arc_lengths,
typename GraphType::NodeIndex source,
typename GraphType::NodeIndex destination )

Definition at line 239 of file shortest_paths.h.

◆ ComputeScalingErrors()

void operations_research::ComputeScalingErrors ( absl::Span< const double > input,
absl::Span< const double > lb,
absl::Span< const double > ub,
double scaling_factor,
double * max_relative_coeff_error,
double * max_scaled_sum_error )

Definition at line 175 of file fp_utils.cc.

◆ ComputeStats()

template<typename T>
SetCoverModel::Stats operations_research::ComputeStats ( std::vector< T > samples)

Definition at line 635 of file set_cover_model.cc.

◆ ComputeVehicleEndChainStarts()

std::vector< int64_t > operations_research::ComputeVehicleEndChainStarts ( const RoutingModel & model)

Computes and returns the first node in the end chain of each vehicle in the model, based on the current bound NextVar values.

Definition at line 386 of file routing_search.cc.

◆ ComputeVehicleToResourceClassAssignmentCosts()

bool operations_research::ComputeVehicleToResourceClassAssignmentCosts ( int v,
double solve_duration_ratio,
const RoutingModel::ResourceGroup & resource_group,
const util_intops::StrongVector< RoutingModel::ResourceClassIndex, absl::flat_hash_set< int > > & ignored_resources_per_class,
const std::function< int64_t(int64_t)> & next_accessor,
const std::function< int64_t(int64_t, int64_t)> & transit_accessor,
bool optimize_vehicle_costs,
LocalDimensionCumulOptimizer * lp_optimizer,
LocalDimensionCumulOptimizer * mp_optimizer,
std::vector< int64_t > * assignment_costs,
std::vector< std::vector< int64_t > > * cumul_values,
std::vector< std::vector< int64_t > > * break_values )

Definition at line 3058 of file routing_lp_scheduling.cc.

◆ ConstrainedShortestPathsOnDag()

PathWithLength operations_research::ConstrainedShortestPathsOnDag ( const int num_nodes,
absl::Span< const ArcWithLengthAndResources > arcs_with_length_and_resources,
int source,
int destination,
const std::vector< double > & max_resources )

Definition at line 40 of file dag_constrained_shortest_path.cc.

◆ ConstraintHandlerResultPriority()

int operations_research::ConstraintHandlerResultPriority ( const GScipCallbackResult result,
const ConstraintHandlerCallbackType callback_type )

Definition at line 251 of file gscip_constraint_handler.cc.

◆ ConstraintSolverParameters_TrailCompression_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::ConstraintSolverParameters_TrailCompression_descriptor ( )

Definition at line 205 of file solver_parameters.pb.cc.

◆ ConstraintSolverParameters_TrailCompression_IsValid()

bool operations_research::ConstraintSolverParameters_TrailCompression_IsValid ( int value)
inline

Definition at line 87 of file solver_parameters.pb.h.

◆ ConstraintSolverParameters_TrailCompression_Name() [1/2]

template<>
const ::std::string & operations_research::ConstraintSolverParameters_TrailCompression_Name ( ConstraintSolverParameters_TrailCompression value)
inline

Definition at line 100 of file solver_parameters.pb.h.

◆ ConstraintSolverParameters_TrailCompression_Name() [2/2]

template<typename T>
const ::std::string & operations_research::ConstraintSolverParameters_TrailCompression_Name ( T value)

Definition at line 93 of file solver_parameters.pb.h.

◆ ConstraintSolverParameters_TrailCompression_Parse()

bool operations_research::ConstraintSolverParameters_TrailCompression_Parse ( ::absl::string_view name,
ConstraintSolverParameters_TrailCompression *PROTOBUF_NONNULL value )
inline

Definition at line 104 of file solver_parameters.pb.h.

◆ ConstraintToString()

std::string operations_research::ConstraintToString ( const sat::ConstraintProto & constraint,
const sat::CpModelProto & model_,
bool show_enforcement = true )

Definition at line 3446 of file routing_lp_scheduling.cc.

◆ ContinueAtLocalOptimum()

bool operations_research::ContinueAtLocalOptimum ( Search * search)

Definition at line 1376 of file constraint_solver.cc.

◆ ConvertDimacsToFlowModel()

bool operations_research::ConvertDimacsToFlowModel ( absl::string_view file,
FlowModelProto * flow_model )

Definition at line 111 of file solve_flow_model.cc.

◆ ConvertFlowModelToDimacs()

void operations_research::ConvertFlowModelToDimacs ( const FlowModelProto & flow_model,
std::string * dimacs )

Definition at line 66 of file solve_flow_model.cc.

◆ ConvertGScipCallbackResult()

SCIP_RESULT operations_research::ConvertGScipCallbackResult ( const GScipCallbackResult result)

Definition at line 21 of file gscip_callback_result.cc.

◆ ConvertStatusOrMPSolutionResponse()

MPSolutionResponse operations_research::ConvertStatusOrMPSolutionResponse ( bool log_error,
absl::StatusOr< MPSolutionResponse > response )
inline

Definition at line 37 of file proto_utils.h.

◆ ConvexMinimum() [1/2]

template<class Point, class Value>
std::pair< Point, Value > operations_research::ConvexMinimum ( absl::Span< const Point > sorted_points,
std::function< Value(Point)> f )

Definition at line 324 of file binary_search.h.

◆ ConvexMinimum() [2/2]

template<class Point, class Value>
std::pair< Point, Value > operations_research::ConvexMinimum ( bool is_to_the_right,
std::pair< Point, Value > current_min,
absl::Span< const Point > sorted_points,
std::function< Value(Point)> f )

Definition at line 333 of file binary_search.h.

◆ CoolingScheduleStrategy_Value_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::CoolingScheduleStrategy_Value_descriptor ( )

Definition at line 701 of file routing_ils.pb.cc.

◆ CoolingScheduleStrategy_Value_IsValid()

bool operations_research::CoolingScheduleStrategy_Value_IsValid ( int value)
inline

Definition at line 239 of file routing_ils.pb.h.

◆ CoolingScheduleStrategy_Value_Name() [1/2]

template<>
const ::std::string & operations_research::CoolingScheduleStrategy_Value_Name ( CoolingScheduleStrategy_Value value)
inline

Definition at line 252 of file routing_ils.pb.h.

◆ CoolingScheduleStrategy_Value_Name() [2/2]

template<typename T>
const ::std::string & operations_research::CoolingScheduleStrategy_Value_Name ( T value)

Definition at line 245 of file routing_ils.pb.h.

◆ CoolingScheduleStrategy_Value_Parse()

bool operations_research::CoolingScheduleStrategy_Value_Parse ( ::absl::string_view name,
CoolingScheduleStrategy_Value *PROTOBUF_NONNULL value )
inline

Definition at line 256 of file routing_ils.pb.h.

◆ CountTriangles()

std::vector< int > operations_research::CountTriangles ( const ::util::StaticGraph< int, int > & graph,
int max_degree )

Definition at line 57 of file find_graph_symmetries.cc.

◆ CourseSchedulingResultStatus_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::CourseSchedulingResultStatus_descriptor ( )

Definition at line 448 of file course_scheduling.pb.cc.

◆ CourseSchedulingResultStatus_IsValid()

bool operations_research::CourseSchedulingResultStatus_IsValid ( int value)
inline

Definition at line 120 of file course_scheduling.pb.h.

◆ CourseSchedulingResultStatus_Name() [1/2]

template<>
const ::std::string & operations_research::CourseSchedulingResultStatus_Name ( CourseSchedulingResultStatus value)
inline

Definition at line 133 of file course_scheduling.pb.h.

◆ CourseSchedulingResultStatus_Name() [2/2]

template<typename T>
const ::std::string & operations_research::CourseSchedulingResultStatus_Name ( T value)

Definition at line 126 of file course_scheduling.pb.h.

◆ CourseSchedulingResultStatus_Parse()

bool operations_research::CourseSchedulingResultStatus_Parse ( ::absl::string_view name,
CourseSchedulingResultStatus *PROTOBUF_NONNULL value )
inline

Definition at line 137 of file course_scheduling.pb.h.

◆ CoverArcsByCliques()

void operations_research::CoverArcsByCliques ( std::function< bool(int, int)> graph,
int node_count,
std::function< bool(const std::vector< int > &)> callback )

Definition at line 244 of file cliques.cc.

◆ CpRandomSeed()

int64_t operations_research::CpRandomSeed ( )
inline

Definition at line 175 of file constraint_solver.h.

◆ CropMultiLineString()

std::string operations_research::CropMultiLineString ( const std::string & s,
int max_line_length,
int max_num_lines )

Definition at line 25 of file string_util.cc.

◆ DefaultGScipConstraintOptions()

const GScipConstraintOptions & operations_research::DefaultGScipConstraintOptions ( )

Definition at line 299 of file gscip.cc.

◆ DefaultGScipVariableOptions()

const GScipVariableOptions & operations_research::DefaultGScipVariableOptions ( )

Definition at line 294 of file gscip.cc.

◆ DefaultPhaseStatString()

std::string operations_research::DefaultPhaseStatString ( DecisionBuilder * db)

Definition at line 1121 of file default_search.cc.

◆ DefaultRoutingModelParameters()

RoutingModelParameters operations_research::DefaultRoutingModelParameters ( )

Definition at line 49 of file routing_parameters.cc.

◆ DefaultRoutingSearchParameters()

◆ DefaultSecondaryRoutingSearchParameters()

RoutingSearchParameters operations_research::DefaultSecondaryRoutingSearchParameters ( )

Definition at line 269 of file routing_parameters.cc.

◆ DEFINE_STRONG_INDEX_TYPE() [1/8]

operations_research::DEFINE_STRONG_INDEX_TYPE ( LeafIndex )

◆ DEFINE_STRONG_INDEX_TYPE() [2/8]

operations_research::DEFINE_STRONG_INDEX_TYPE ( RoutingCostClassIndex )

◆ DEFINE_STRONG_INDEX_TYPE() [3/8]

operations_research::DEFINE_STRONG_INDEX_TYPE ( RoutingDimensionIndex )

◆ DEFINE_STRONG_INDEX_TYPE() [4/8]

operations_research::DEFINE_STRONG_INDEX_TYPE ( RoutingDisjunctionIndex )

◆ DEFINE_STRONG_INDEX_TYPE() [5/8]

operations_research::DEFINE_STRONG_INDEX_TYPE ( RoutingNodeIndex )

Defining common types used in the routing library outside the main RoutingModel class has several purposes: 1) It allows some small libraries to avoid a dependency on routing.{h,cc}, eg. routing_neighborhoods.h. 2) It allows an easier wrapping via SWIG, which can have issues with intra-class types. Users that depend on routing.{h,cc} should just use the RoutingModel:: equivalent, eg. RoutingModel::NodeIndex.

◆ DEFINE_STRONG_INDEX_TYPE() [6/8]

operations_research::DEFINE_STRONG_INDEX_TYPE ( RoutingResourceClassIndex )

◆ DEFINE_STRONG_INDEX_TYPE() [7/8]

operations_research::DEFINE_STRONG_INDEX_TYPE ( RoutingVehicleClassIndex )

◆ DEFINE_STRONG_INDEX_TYPE() [8/8]

operations_research::DEFINE_STRONG_INDEX_TYPE ( TreeNodeIndex )

◆ DEFINE_STRONG_INT_TYPE() [1/7]

operations_research::DEFINE_STRONG_INT_TYPE ( CapacityTermIndex ,
BaseInt  )

◆ DEFINE_STRONG_INT_TYPE() [2/7]

operations_research::DEFINE_STRONG_INT_TYPE ( ColumnEntryIndex ,
BaseInt  )

◆ DEFINE_STRONG_INT_TYPE() [3/7]

operations_research::DEFINE_STRONG_INT_TYPE ( ElementIndex ,
BaseInt  )

◆ DEFINE_STRONG_INT_TYPE() [4/7]

operations_research::DEFINE_STRONG_INT_TYPE ( FullElementIndex ,
BaseInt  )

◆ DEFINE_STRONG_INT_TYPE() [5/7]

operations_research::DEFINE_STRONG_INT_TYPE ( FullSubsetIndex ,
BaseInt  )

◆ DEFINE_STRONG_INT_TYPE() [6/7]

operations_research::DEFINE_STRONG_INT_TYPE ( RowEntryIndex ,
BaseInt  )

◆ DEFINE_STRONG_INT_TYPE() [7/7]

operations_research::DEFINE_STRONG_INT_TYPE ( SubsetIndex ,
BaseInt  )

◆ DefragmentRanges()

template<typename T>
void operations_research::DefragmentRanges ( std::vector< T > & mutable_input,
CommittableArray< IndexRange > & ranges,
std::vector< T > & temp_container )

Definition at line 158 of file routing_filter_committables.h.

◆ DeleteDemonProfiler()

void operations_research::DeleteDemonProfiler ( DemonProfiler * monitor)
extern

Definition at line 453 of file demon_profiler.cc.

◆ DeleteLocalSearchProfiler()

void operations_research::DeleteLocalSearchProfiler ( LocalSearchProfiler * monitor)
extern

Definition at line 3757 of file local_search.cc.

◆ DemonProfilerAddFakeRun()

void operations_research::DemonProfilerAddFakeRun ( DemonProfiler *const monitor,
Demon *const demon,
int64_t start_time,
int64_t end_time,
bool is_fail )

Definition at line 470 of file demon_profiler.cc.

◆ DemonProfilerBeginInitialPropagation()

void operations_research::DemonProfilerBeginInitialPropagation ( DemonProfiler *const monitor,
Constraint *const constraint )

Definition at line 488 of file demon_profiler.cc.

◆ DemonProfilerEndInitialPropagation()

void operations_research::DemonProfilerEndInitialPropagation ( DemonProfiler *const monitor,
Constraint *const constraint )

Definition at line 493 of file demon_profiler.cc.

◆ DemonProfilerExportInformation()

void operations_research::DemonProfilerExportInformation ( DemonProfiler *const monitor,
const Constraint *const constraint,
int64_t *const fails,
int64_t *const initial_propagation_runtime,
int64_t *const demon_invocations,
int64_t *const total_demon_runtime,
int *const demon_count )

Definition at line 476 of file demon_profiler.cc.

◆ DisableAllCutsExceptUserDefined()

void operations_research::DisableAllCutsExceptUserDefined ( GScipParameters * parameters)

Definition at line 147 of file gscip_parameters.cc.

◆ DisableAllLocalSearchOperators()

void operations_research::DisableAllLocalSearchOperators ( RoutingSearchParameters::LocalSearchNeighborhoodOperators * operators)

Definition at line 47 of file routing_parameters_utils.cc.

◆ DisplayPlan()

void operations_research::DisplayPlan ( const RoutingIndexManager & manager,
const RoutingModel & routing,
const operations_research::Assignment & plan,
bool use_same_vehicle_costs,
int64_t max_nodes_per_group,
int64_t same_vehicle_cost,
absl::Span< const std::string > dimension_names )

Definition at line 165 of file cvrptw_lib.cc.

◆ DomainToString()

std::string operations_research::DomainToString ( const ::google::protobuf::RepeatedField< int64_t > * domain)

Definition at line 3398 of file routing_lp_scheduling.cc.

◆ DropAllEvents()

SCIP_RETCODE operations_research::DropAllEvents ( GScipEventHandler & handler)

Definition at line 133 of file gscip_event_handler.cc.

◆ EmptyOrGurobiLicenseWarning()

testing::Matcher< std::string > operations_research::EmptyOrGurobiLicenseWarning ( )

Definition at line 23 of file gurobi_stdout_matchers.cc.

◆ EmptyOrGurobiLicenseWarningIfGurobi()

testing::Matcher< std::string > operations_research::EmptyOrGurobiLicenseWarningIfGurobi ( const bool is_gurobi)

Definition at line 30 of file gurobi_stdout_matchers.cc.

◆ ENABLE_EXPLICIT_STRONG_TYPE_CAST() [1/4]

operations_research::ENABLE_EXPLICIT_STRONG_TYPE_CAST ( ElementIndex ,
FullElementIndex  )

◆ ENABLE_EXPLICIT_STRONG_TYPE_CAST() [2/4]

operations_research::ENABLE_EXPLICIT_STRONG_TYPE_CAST ( FullElementIndex ,
ElementIndex  )

◆ ENABLE_EXPLICIT_STRONG_TYPE_CAST() [3/4]

operations_research::ENABLE_EXPLICIT_STRONG_TYPE_CAST ( FullSubsetIndex ,
SubsetIndex  )

◆ ENABLE_EXPLICIT_STRONG_TYPE_CAST() [4/4]

operations_research::ENABLE_EXPLICIT_STRONG_TYPE_CAST ( SubsetIndex ,
FullSubsetIndex  )

◆ EncodeParametersAsString()

template<typename P>
std::string operations_research::EncodeParametersAsString ( const P & parameters)

Definition at line 71 of file proto_utils.h.

◆ end()

ClosedInterval::Iterator operations_research::end ( ClosedInterval interval)
inline

Definition at line 736 of file sorted_interval_list.h.

◆ ExchangeAndMakeActive()

LocalSearchOperator * operations_research::ExchangeAndMakeActive ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class )

Definition at line 900 of file local_search.cc.

◆ ExchangePathStartEndsAndMakeActive()

LocalSearchOperator * operations_research::ExchangePathStartEndsAndMakeActive ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class )

Definition at line 947 of file local_search.cc.

◆ ExploreAndCountAllProtoPathsInInstance()

void operations_research::ExploreAndCountAllProtoPathsInInstance ( const google::protobuf::Message & message,
absl::flat_hash_map< std::string, int > * proto_path_counts )

◆ ExportModelAsLpFormat()

absl::StatusOr< std::string > operations_research::ExportModelAsLpFormat ( const MPModelProto & model,
const MPModelExportOptions & options = MPModelExportOptions() )

Outputs the current model (variables, constraints, objective) as a string encoded in the so-called "CPLEX LP file format" as generated by SCIP. The LP file format is easily readable by a human.

Returns false if some error has occurred during execution. The validity of names is automatically checked. If a variable name or a constraint name is invalid or non-existent, a new valid name is automatically generated.

If 'obfuscated' is true, the variable and constraint names of proto_ are not used. Variable and constraint names of the form "V12345" and "C12345" are used instead.

For more information about the different LP file formats: http://lpsolve.sourceforge.net/5.5/lp-format.htm The following give a reasonable idea of the CPLEX LP file format: http://lpsolve.sourceforge.net/5.5/CPLEX-format.htm https://www.ibm.com/docs/en/icos/12.8.0.0?topic=cplex-lp-file-format-algebraic-representation http://www.gurobi.com/documentation/5.1/reference-manual/node871

Definition at line 224 of file model_exporter.cc.

◆ ExportModelAsMpsFormat()

absl::StatusOr< std::string > operations_research::ExportModelAsMpsFormat ( const MPModelProto & model,
const MPModelExportOptions & options = MPModelExportOptions() )

Outputs the current model (variables, constraints, objective) as a string encoded in MPS file format, using the "free" MPS format.

Returns false if some error has occurred during execution. Models with maximization objectives trigger an error, because MPS can encode only minimization problems.

The validity of names is automatically checked. If a variable name or a constraint name is invalid or non-existent, a new valid name is automatically generated.

Name validity and obfuscation works exactly as in ExportModelAsLpFormat().

For more information about the MPS format: http://en.wikipedia.org/wiki/MPS_(format) A close-to-original description coming from OSL: http://tinyurl.com/mps-format-by-osl A recent description from CPLEX: http://tinyurl.com/mps-format-by-cplex CPLEX extensions: http://tinyurl.com/mps-extensions-by-cplex Gurobi's description: http://www.gurobi.com/documentation/5.1/reference-manual/node869

Definition at line 241 of file model_exporter.cc.

◆ ExtractValidMPModelOrPopulateResponseStatus()

std::optional< LazyMutableCopy< MPModelProto > > operations_research::ExtractValidMPModelOrPopulateResponseStatus ( const MPModelRequest & request,
MPSolutionResponse * response )

If the model is valid and non-empty, returns it (possibly after extracting the model_delta). If invalid or empty, updates response and returns null.

Definition at line 685 of file model_validator.cc.

◆ fast_ilogb()

int operations_research::fast_ilogb ( double value)
inline

Definition at line 256 of file fp_utils.h.

◆ fast_scalbn()

double operations_research::fast_scalbn ( double value,
int exponent )
inline

Definition at line 257 of file fp_utils.h.

◆ fasthash64()

uint64_t operations_research::fasthash64 ( const void * buf,
size_t len,
uint64_t seed )

Definition at line 36 of file hash.cc.

◆ FillDimensionValuesFromRoutingDimension()

bool operations_research::FillDimensionValuesFromRoutingDimension ( int path,
int64_t capacity,
int64_t span_upper_bound,
absl::Span< const DimensionValues::Interval > cumul_of_node,
absl::Span< const DimensionValues::Interval > slack_of_node,
absl::AnyInvocable< int64_t(int64_t, int64_t) const > evaluator,
DimensionValues & dimension_values )

Definition at line 1474 of file routing_filters.cc.

◆ FillPathEvaluation()

void operations_research::FillPathEvaluation ( absl::Span< const int64_t > path,
const RoutingModel::TransitCallback2 & evaluator,
std::vector< int64_t > * values )

Definition at line 6893 of file routing.cc.

◆ FillPrePostVisitValues()

void operations_research::FillPrePostVisitValues ( int path,
const DimensionValues & dimension_values,
std::optional< absl::AnyInvocable< int64_t(int64_t, int64_t) const > > pre_travel_evaluator,
std::optional< absl::AnyInvocable< int64_t(int64_t, int64_t) const > > post_travel_evaluator,
PrePostVisitValues & visit_values )

Definition at line 1554 of file routing_filters.cc.

◆ FillValues()

void operations_research::FillValues ( const std::vector< IntVar * > & vars,
std::vector< int64_t > *const values )
inline

Definition at line 4355 of file constraint_solveri.h.

◆ FindCliques()

void operations_research::FindCliques ( std::function< bool(int, int)> graph,
int node_count,
std::function< bool(const std::vector< int > &)> callback )

Definition at line 230 of file cliques.cc.

◆ FindErrorInMPModelDeltaProto()

std::string operations_research::FindErrorInMPModelDeltaProto ( const MPModelDeltaProto & delta,
const MPModelProto & model )

Like FindErrorInMPModelProto, but for a MPModelDeltaProto applied to a given baseline model (assumed valid, eg. FindErrorInMPModelProto(model)=""). Works in O(|model_delta|) + O(num_vars in model), but the latter term has a very small constant factor.

Definition at line 840 of file model_validator.cc.

◆ FindErrorInMPModelForScip()

std::string operations_research::FindErrorInMPModelForScip ( const MPModelProto & model,
SCIP * scip )

Definition at line 595 of file scip_proto_solver.cc.

◆ FindErrorInMPModelProto()

std::string operations_research::FindErrorInMPModelProto ( const MPModelProto & model,
double abs_value_threshold = 0.0,
bool accept_trivially_infeasible_bounds = false )

Returns an empty string iff the model is valid and not trivially infeasible. Otherwise, returns a description of the first error or trivial infeasibility variable or constraint bound encountered.

abs_value_threshold is the (exclusive) limit for the abs value of constraint coefficients, objective coefficients, etc. If unspecified, or 0, it defaults to FLAGS_model_validator_infinity.

NOTE(user): the code of this method (and the client code too!) is considerably simplified by this string-based, simple API. If clients require it, we could add a formal error status enum.

Definition at line 556 of file model_validator.cc.

◆ FindErrorInRoutingSearchParameters()

std::string operations_research::FindErrorInRoutingSearchParameters ( const RoutingSearchParameters & search_parameters)

Returns an empty std::string if the routing search parameters are valid, and a non-empty, human readable error description if they're not.

Definition at line 627 of file routing_parameters.cc.

◆ FindErrorsInRoutingSearchParameters()

std::vector< std::string > operations_research::FindErrorsInRoutingSearchParameters ( const RoutingSearchParameters & search_parameters)

Returns a list of std::string describing the errors in the routing search parameters. Returns an empty vector if the parameters are valid.

Definition at line 634 of file routing_parameters.cc.

◆ FindFeasibilityErrorInSolutionHint()

std::string operations_research::FindFeasibilityErrorInSolutionHint ( const MPModelProto & model,
double tolerance )

Returns an empty string if the solution hint given in the model is a feasible solution. Otherwise, returns a description of the first reason for infeasibility.

This function can be useful for debugging/checking that the given solution hint is feasible when it is expected to be the case. The feasibility is checked up to the given tolerance using the ::operations_research::IsLowerWithinTolerance() function.

Definition at line 779 of file model_validator.cc.

◆ FindMostExpensiveArcsOnRoute()

bool operations_research::FindMostExpensiveArcsOnRoute ( int num_arcs,
int64_t start,
const std::function< int64_t(int64_t)> & next_accessor,
const std::function< bool(int64_t)> & is_end,
const std::function< int64_t(int64_t, int64_t, int64_t)> & arc_cost_for_route_start,
std::vector< std::pair< int64_t, int > > * most_expensive_arc_starts_and_ranks,
std::pair< int, int > * first_expensive_arc_indices )

Definition at line 123 of file routing_utils.cc.

◆ FirstSolutionStrategy_Value_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::FirstSolutionStrategy_Value_descriptor ( )

Definition at line 153 of file routing_enums.pb.cc.

◆ FirstSolutionStrategy_Value_IsValid()

bool operations_research::FirstSolutionStrategy_Value_IsValid ( int value)
inline

Definition at line 122 of file routing_enums.pb.h.

◆ FirstSolutionStrategy_Value_Name() [1/2]

template<>
const ::std::string & operations_research::FirstSolutionStrategy_Value_Name ( FirstSolutionStrategy_Value value)
inline

Definition at line 135 of file routing_enums.pb.h.

◆ FirstSolutionStrategy_Value_Name() [2/2]

template<typename T>
const ::std::string & operations_research::FirstSolutionStrategy_Value_Name ( T value)

Definition at line 128 of file routing_enums.pb.h.

◆ FirstSolutionStrategy_Value_Parse()

bool operations_research::FirstSolutionStrategy_Value_Parse ( ::absl::string_view name,
FirstSolutionStrategy_Value *PROTOBUF_NONNULL value )
inline

Definition at line 139 of file routing_enums.pb.h.

◆ FixFlagsAndEnvironmentForSwig()

void operations_research::FixFlagsAndEnvironmentForSwig ( )

Definition at line 28 of file logging.cc.

◆ FloorRatio()

int64_t operations_research::FloorRatio ( int64_t value,
int64_t positive_coeff )

Definition at line 113 of file sorted_interval_list.cc.

◆ FlowModelProto_ProblemType_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::FlowModelProto_ProblemType_descriptor ( )

Definition at line 191 of file flow_problem.pb.cc.

◆ FlowModelProto_ProblemType_IsValid()

bool operations_research::FlowModelProto_ProblemType_IsValid ( int value)
inline

Definition at line 92 of file flow_problem.pb.h.

◆ FlowModelProto_ProblemType_Name() [1/2]

template<>
const ::std::string & operations_research::FlowModelProto_ProblemType_Name ( FlowModelProto_ProblemType value)
inline

Definition at line 105 of file flow_problem.pb.h.

◆ FlowModelProto_ProblemType_Name() [2/2]

template<typename T>
const ::std::string & operations_research::FlowModelProto_ProblemType_Name ( T value)

Definition at line 98 of file flow_problem.pb.h.

◆ FlowModelProto_ProblemType_Parse()

bool operations_research::FlowModelProto_ProblemType_Parse ( ::absl::string_view name,
FlowModelProto_ProblemType *PROTOBUF_NONNULL value )
inline

Definition at line 109 of file flow_problem.pb.h.

◆ FormatCounter()

std::string operations_research::FormatCounter ( int64_t num)

Definition at line 30 of file logging.cc.

◆ FullProtocolMessageAsString()

std::string operations_research::FullProtocolMessageAsString ( const google::protobuf::Message & message,
int indent_level )

Definition at line 63 of file proto_tools.cc.

◆ GetBestScalingOfDoublesToInt64() [1/2]

double operations_research::GetBestScalingOfDoublesToInt64 ( absl::Span< const double > input,
absl::Span< const double > lb,
absl::Span< const double > ub,
int64_t max_absolute_sum )

Definition at line 184 of file fp_utils.cc.

◆ GetBestScalingOfDoublesToInt64() [2/2]

void operations_research::GetBestScalingOfDoublesToInt64 ( absl::Span< const double > input,
int64_t max_absolute_sum,
double * scaling_factor,
double * max_relative_coeff_error )

Definition at line 195 of file fp_utils.cc.

◆ GetGraphNodes()

template<class GraphType>
void operations_research::GetGraphNodes ( const GraphType & graph,
std::vector< typename GraphType::NodeIndex > * nodes )

Definition at line 180 of file shortest_paths.h.

◆ GetGraphNodesFromGraph()

template<class GraphType>
void operations_research::GetGraphNodesFromGraph ( const GraphType & graph,
std::vector< typename GraphType::NodeIndex > * nodes )

Definition at line 192 of file shortest_paths.h.

◆ GetGurobiEnv()

absl::StatusOr< GRBenv * > operations_research::GetGurobiEnv ( )

Definition at line 43 of file gurobi_util.cc.

◆ getitcnt()

int operations_research::getitcnt ( const XPRSprob & mLp)

Definition at line 172 of file xpress_interface.cc.

◆ GetLocalCheapestInsertionSortingProperties()

std::vector< LocalCheapestInsertionParameters::InsertionSortingProperty > operations_research::GetLocalCheapestInsertionSortingProperties ( absl::Span< const int > lci_insertion_sorting_properties)

Definition at line 24 of file routing_parameters_utils.cc.

◆ getMapDoubleControls()

std::map< std::string, int > & operations_research::getMapDoubleControls ( )
static

Definition at line 509 of file xpress_interface.cc.

◆ getMapInt64Controls()

std::map< std::string, int > & operations_research::getMapInt64Controls ( )
static

Definition at line 831 of file xpress_interface.cc.

◆ getMapIntControls()

std::map< std::string, int > & operations_research::getMapIntControls ( )
static

Definition at line 594 of file xpress_interface.cc.

◆ getMapStringControls()

std::map< std::string, int > & operations_research::getMapStringControls ( )
static

Definition at line 494 of file xpress_interface.cc.

◆ GetMPModelOrPopulateResponse()

std::optional< LazyMutableCopy< MPModelProto > > operations_research::GetMPModelOrPopulateResponse ( LazyMutableCopy< MPModelRequest > & request,
MPSolutionResponse * response )

Same as ExtractValidMPModelOrPopulateResponseStatus() but if we already have ownership of the request, do not do any copy even when needed. Note that the MPModelProto in the request will be cleared in this case.

Definition at line 691 of file model_validator.cc.

◆ getnodecnt()

int operations_research::getnodecnt ( const XPRSprob & mLp)

Definition at line 178 of file xpress_interface.cc.

◆ getnumcols()

int operations_research::getnumcols ( const XPRSprob & mLp)

Definition at line 160 of file xpress_interface.cc.

◆ getnumrows()

int operations_research::getnumrows ( const XPRSprob & mLp)

Definition at line 166 of file xpress_interface.cc.

◆ GetParameterCaseForRecreateHeuristic()

RecreateParameters::ParametersCase operations_research::GetParameterCaseForRecreateHeuristic ( FirstSolutionStrategy::Value recreate_heuristic)

Definition at line 24 of file routing_ils_parameters_utils.cc.

◆ GetProcessMemoryUsage()

int64_t operations_research::GetProcessMemoryUsage ( )

Definition at line 91 of file sysinfo.cc.

◆ GetRecreateParametersName()

std::string operations_research::GetRecreateParametersName ( RecreateParameters::ParametersCase parameters_case)

Definition at line 51 of file routing_ils_parameters_utils.cc.

◆ GetSeed()

int32_t operations_research::GetSeed ( bool deterministic)

Definition at line 40 of file cvrptw_lib.cc.

◆ GetSimulatedAnnealingTemperatures()

std::pair< double, double > operations_research::GetSimulatedAnnealingTemperatures ( const RoutingModel & model,
const SimulatedAnnealingAcceptanceStrategy & sa_params,
std::mt19937 * rnd )

Definition at line 1279 of file routing_ils.cc.

◆ getSolverVersion()

std::string operations_research::getSolverVersion ( XPRSprob const & prob)

Definition at line 46 of file xpress_interface.cc.

◆ GetSupportedRecreateParametersCases()

std::vector< RecreateParameters::ParametersCase > operations_research::GetSupportedRecreateParametersCases ( )

Definition at line 45 of file routing_ils_parameters_utils.cc.

◆ GlopSolveProto()

MPSolutionResponse operations_research::GlopSolveProto ( LazyMutableCopy< MPModelRequest > request,
std::atomic< bool > * interrupt_solve,
std::function< void(const std::string &)> logging_callback )

Definition at line 107 of file glop_proto_solver.cc.

◆ GlopSolverVersion()

std::string operations_research::GlopSolverVersion ( )

Definition at line 234 of file glop_proto_solver.cc.

◆ GlopToMPSolverConstraintStatus()

MPSolver::BasisStatus operations_research::GlopToMPSolverConstraintStatus ( glop::ConstraintStatus s)

Definition at line 95 of file glop_utils.cc.

◆ GlopToMPSolverResultStatus()

MPSolver::ResultStatus operations_research::GlopToMPSolverResultStatus ( glop::ProblemStatus s)

Definition at line 22 of file glop_utils.cc.

◆ GlopToMPSolverVariableStatus()

MPSolver::BasisStatus operations_research::GlopToMPSolverVariableStatus ( glop::VariableStatus s)

Definition at line 61 of file glop_utils.cc.

◆ GLPKGatherInformationCallback()

void operations_research::GLPKGatherInformationCallback ( glp_tree * tree,
void * info )

Definition at line 57 of file glpk_interface.cc.

◆ GraphIsSymmetric()

template<class Graph>
bool util::GraphIsSymmetric ( const Graph & graph)

Definition at line 228 of file util.h.

◆ GScipAddQuadraticObjectiveTerm()

absl::Status operations_research::GScipAddQuadraticObjectiveTerm ( GScip * gscip,
std::vector< SCIP_Var * > quadratic_variables1,
std::vector< SCIP_Var * > quadratic_variables2,
std::vector< double > quadratic_coefficients,
absl::string_view name )

Definition at line 150 of file gscip_ext.cc.

◆ GScipCatchCtrlC()

bool operations_research::GScipCatchCtrlC ( const GScipParameters & parameters)

Definition at line 136 of file gscip_parameters.cc.

◆ GScipCatchCtrlCSet()

bool operations_research::GScipCatchCtrlCSet ( const GScipParameters & parameters)

Definition at line 143 of file gscip_parameters.cc.

◆ GScipCreateAbs()

absl::Status operations_research::GScipCreateAbs ( GScip * gscip,
SCIP_Var * x,
SCIP_Var * abs_x,
absl::string_view name )

Definition at line 76 of file gscip_ext.cc.

◆ GScipCreateIndicatorRange()

absl::Status operations_research::GScipCreateIndicatorRange ( GScip * gscip,
const GScipIndicatorRangeConstraint & indicator_range,
absl::string_view name,
const GScipConstraintOptions & options )

Definition at line 180 of file gscip_ext.cc.

◆ GScipCreateMaximum()

absl::Status operations_research::GScipCreateMaximum ( GScip * gscip,
const GScipLinearExpr & resultant,
absl::Span< const GScipLinearExpr > terms,
absl::string_view name )

Definition at line 83 of file gscip_ext.cc.

◆ GScipCreateMinimum()

absl::Status operations_research::GScipCreateMinimum ( GScip * gscip,
const GScipLinearExpr & resultant,
absl::Span< const GScipLinearExpr > terms,
absl::string_view name )

Definition at line 139 of file gscip_ext.cc.

◆ GScipDifference()

GScipLinearExpr operations_research::GScipDifference ( GScipLinearExpr left,
const GScipLinearExpr & right )

Definition at line 44 of file gscip_ext.cc.

◆ GScipLe()

GScipLinearRange operations_research::GScipLe ( const GScipLinearExpr left,
const GScipLinearExpr & right )

Definition at line 63 of file gscip_ext.cc.

◆ GScipLogLevel()

int operations_research::GScipLogLevel ( const GScipParameters & parameters)

Definition at line 88 of file gscip_parameters.cc.

◆ GScipLogLevelSet()

bool operations_research::GScipLogLevelSet ( const GScipParameters & parameters)

Definition at line 93 of file gscip_parameters.cc.

◆ GScipMaxNumThreads()

int operations_research::GScipMaxNumThreads ( const GScipParameters & parameters)

Definition at line 70 of file gscip_parameters.cc.

◆ GScipMaxNumThreadsSet()

bool operations_research::GScipMaxNumThreadsSet ( const GScipParameters & parameters)

Definition at line 77 of file gscip_parameters.cc.

◆ GScipNegate()

GScipLinearExpr operations_research::GScipNegate ( GScipLinearExpr expr)

Definition at line 53 of file gscip_ext.cc.

◆ GScipOutput_Status_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::GScipOutput_Status_descriptor ( )

Definition at line 489 of file gscip.pb.cc.

◆ GScipOutput_Status_IsValid()

bool operations_research::GScipOutput_Status_IsValid ( int value)
inline

Definition at line 230 of file gscip.pb.h.

◆ GScipOutput_Status_Name() [1/2]

template<>
const ::std::string & operations_research::GScipOutput_Status_Name ( GScipOutput_Status value)
inline

Definition at line 243 of file gscip.pb.h.

◆ GScipOutput_Status_Name() [2/2]

template<typename T>
const ::std::string & operations_research::GScipOutput_Status_Name ( T value)

Definition at line 236 of file gscip.pb.h.

◆ GScipOutput_Status_Parse()

bool operations_research::GScipOutput_Status_Parse ( ::absl::string_view name,
GScipOutput_Status *PROTOBUF_NONNULL value )
inline

Definition at line 247 of file gscip.pb.h.

◆ GScipOutputEnabled()

bool operations_research::GScipOutputEnabled ( const GScipParameters & parameters)

Definition at line 104 of file gscip_parameters.cc.

◆ GScipOutputEnabledSet()

bool operations_research::GScipOutputEnabledSet ( const GScipParameters & parameters)

Definition at line 109 of file gscip_parameters.cc.

◆ GScipParameters_Emphasis_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::GScipParameters_Emphasis_descriptor ( )

Definition at line 477 of file gscip.pb.cc.

◆ GScipParameters_Emphasis_IsValid()

bool operations_research::GScipParameters_Emphasis_IsValid ( int value)
inline

Definition at line 141 of file gscip.pb.h.

◆ GScipParameters_Emphasis_Name() [1/2]

template<>
const ::std::string & operations_research::GScipParameters_Emphasis_Name ( GScipParameters_Emphasis value)
inline

Definition at line 154 of file gscip.pb.h.

◆ GScipParameters_Emphasis_Name() [2/2]

template<typename T>
const ::std::string & operations_research::GScipParameters_Emphasis_Name ( T value)

Definition at line 147 of file gscip.pb.h.

◆ GScipParameters_Emphasis_Parse()

bool operations_research::GScipParameters_Emphasis_Parse ( ::absl::string_view name,
GScipParameters_Emphasis *PROTOBUF_NONNULL value )
inline

Definition at line 158 of file gscip.pb.h.

◆ GScipParameters_MetaParamValue_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::GScipParameters_MetaParamValue_descriptor ( )

Definition at line 483 of file gscip.pb.cc.

◆ GScipParameters_MetaParamValue_IsValid()

bool operations_research::GScipParameters_MetaParamValue_IsValid ( int value)
inline

Definition at line 179 of file gscip.pb.h.

◆ GScipParameters_MetaParamValue_Name() [1/2]

template<>
const ::std::string & operations_research::GScipParameters_MetaParamValue_Name ( GScipParameters_MetaParamValue value)
inline

Definition at line 192 of file gscip.pb.h.

◆ GScipParameters_MetaParamValue_Name() [2/2]

template<typename T>
const ::std::string & operations_research::GScipParameters_MetaParamValue_Name ( T value)

Definition at line 185 of file gscip.pb.h.

◆ GScipParameters_MetaParamValue_Parse()

bool operations_research::GScipParameters_MetaParamValue_Parse ( ::absl::string_view name,
GScipParameters_MetaParamValue *PROTOBUF_NONNULL value )
inline

Definition at line 196 of file gscip.pb.h.

◆ GScipRandomSeed()

int operations_research::GScipRandomSeed ( const GScipParameters & parameters)

Definition at line 119 of file gscip_parameters.cc.

◆ GScipRandomSeedSet()

bool operations_research::GScipRandomSeedSet ( const GScipParameters & parameters)

Definition at line 126 of file gscip_parameters.cc.

◆ GScipSetCatchCtrlC()

void operations_research::GScipSetCatchCtrlC ( const bool catch_ctrl_c,
GScipParameters *const parameters )

Definition at line 130 of file gscip_parameters.cc.

◆ GScipSetLogLevel()

void operations_research::GScipSetLogLevel ( GScipParameters * parameters,
int log_level )

Definition at line 81 of file gscip_parameters.cc.

◆ GScipSetMaxNumThreads()

void operations_research::GScipSetMaxNumThreads ( int num_threads,
GScipParameters * parameters )

Definition at line 64 of file gscip_parameters.cc.

◆ GScipSetOutputEnabled()

void operations_research::GScipSetOutputEnabled ( GScipParameters * parameters,
bool output_enabled )

Definition at line 97 of file gscip_parameters.cc.

◆ GScipSetRandomSeed()

void operations_research::GScipSetRandomSeed ( GScipParameters * parameters,
int random_seed )

Definition at line 113 of file gscip_parameters.cc.

◆ GScipSetTimeLimit()

void operations_research::GScipSetTimeLimit ( absl::Duration time_limit,
GScipParameters * parameters )

Definition at line 36 of file gscip_parameters.cc.

◆ GScipSolutionAlmostEquals()

testing::Matcher< GScipSolution > operations_research::GScipSolutionAlmostEquals ( const GScipSolution & rhs,
double tolerance )

Definition at line 113 of file gscip_testing.cc.

◆ GScipSolutionEquals()

testing::Matcher< GScipSolution > operations_research::GScipSolutionEquals ( const GScipSolution & rhs)

Definition at line 110 of file gscip_testing.cc.

◆ GScipTimeLimit()

absl::Duration operations_research::GScipTimeLimit ( const GScipParameters & parameters)

Definition at line 45 of file gscip_parameters.cc.

◆ GScipTimeLimitSet()

bool operations_research::GScipTimeLimitSet ( const GScipParameters & parameters)

Definition at line 60 of file gscip_parameters.cc.

◆ GurobiDynamicLibraryPotentialPaths()

std::vector< std::string > operations_research::GurobiDynamicLibraryPotentialPaths ( )

Definition at line 337 of file gurobi_environment.cc.

◆ GurobiIsCorrectlyInstalled()

bool operations_research::GurobiIsCorrectlyInstalled ( )

Definition at line 31 of file gurobi_util.cc.

◆ GurobiParamInfoForLogging()

std::string operations_research::GurobiParamInfoForLogging ( GRBenv * grb,
bool one_liner_output )

Definition at line 58 of file gurobi_util.cc.

◆ GurobiSolveProto()

absl::StatusOr< MPSolutionResponse > operations_research::GurobiSolveProto ( LazyMutableCopy< MPModelRequest > request,
GRBenv * gurobi_env )

Definition at line 275 of file gurobi_proto_solver.cc.

◆ Hash1() [1/7]

uint64_t operations_research::Hash1 ( const std::vector< int64_t > & ptrs)
inline

Definition at line 277 of file constraint_solveri.h.

◆ Hash1() [2/7]

template<class T>
uint64_t operations_research::Hash1 ( const std::vector< T * > & ptrs)

Definition at line 267 of file constraint_solveri.h.

◆ Hash1() [3/7]

uint64_t operations_research::Hash1 ( int value)
inline

Definition at line 255 of file constraint_solveri.h.

◆ Hash1() [4/7]

uint64_t operations_research::Hash1 ( int64_t value)
inline

Definition at line 251 of file constraint_solveri.h.

◆ Hash1() [5/7]

uint64_t operations_research::Hash1 ( uint32_t value)
inline

Definition at line 240 of file constraint_solveri.h.

◆ Hash1() [6/7]

uint64_t operations_research::Hash1 ( uint64_t value)
inline

Hash functions.

value = (value << 21) - value - 1;

value * 265

value * 21

Definition at line 229 of file constraint_solveri.h.

◆ Hash1() [7/7]

uint64_t operations_research::Hash1 ( void *const ptr)
inline

Definition at line 257 of file constraint_solveri.h.

◆ HighsSolveProto()

absl::StatusOr< MPSolutionResponse > operations_research::HighsSolveProto ( LazyMutableCopy< MPModelRequest > request,
HighsSolveInfo * solve_info )

Definition at line 48 of file highs_proto_solver.cc.

◆ IncrementalSort() [1/2]

template<class Iterator, class Compare = std::less<value_type_t<Iterator>>>
void operations_research::IncrementalSort ( int max_comparisons,
Iterator begin,
Iterator end,
Compare comp = Compare{},
bool is_stable = false )

Definition at line 46 of file sort.h.

◆ IncrementalSort() [2/2]

template<class Iterator, class Compare = std::less<value_type_t<Iterator>>>
void operations_research::IncrementalSort ( Iterator begin,
Iterator end,
Compare comp = Compare{},
bool is_stable = false )

Definition at line 129 of file sort.h.

◆ IndexRange()

template<class Index>
operations_research::IndexRange ( Index a,
Index b )->IndexRange< Index >

◆ initXpressEnv()

bool operations_research::initXpressEnv ( bool verbose,
int xpress_oem_license_key )

init XPRESS environment.

Definition at line 336 of file xpress_environment.cc.

◆ InputContainsNan()

bool operations_research::InputContainsNan ( absl::Span< const std::vector< double > > input)

Definition at line 643 of file hungarian.cc.

◆ InsertionSort()

template<class Iterator, class Compare = std::less<value_type_t<Iterator>>>
void operations_research::InsertionSort ( Iterator begin,
Iterator end,
Compare comp = Compare{} )

Definition at line 95 of file sort.h.

◆ InstallDemonProfiler()

void operations_research::InstallDemonProfiler ( DemonProfiler * monitor)
extern

Definition at line 443 of file demon_profiler.cc.

◆ InstallLocalSearchProfiler()

void operations_research::InstallLocalSearchProfiler ( LocalSearchProfiler * monitor)
extern

Definition at line 3746 of file local_search.cc.

◆ Int64ToStr()

std::string operations_research::Int64ToStr ( int64_t number)

Definition at line 3392 of file routing_lp_scheduling.cc.

◆ InternalSaveBooleanVarValue()

void operations_research::InternalSaveBooleanVarValue ( Solver *const solver,
IntVar *const var )

Definition at line 963 of file constraint_solver.cc.

◆ Interpolate()

template<typename FloatType>
FloatType operations_research::Interpolate ( FloatType x,
FloatType y,
FloatType alpha )
inline

Definition at line 252 of file fp_utils.h.

◆ interruptXPRESS()

void operations_research::interruptXPRESS ( XPRSprob & xprsProb,
CUSTOM_INTERRUPT_REASON reason )

Definition at line 203 of file xpress_interface.cc.

◆ IntervalDown32()

uint32_t operations_research::IntervalDown32 ( uint32_t s)
inline

Definition at line 319 of file bitset.h.

◆ IntervalDown64()

uint64_t operations_research::IntervalDown64 ( uint64_t s)
inline

Definition at line 314 of file bitset.h.

◆ IntervalsAreSortedAndNonAdjacent()

bool operations_research::IntervalsAreSortedAndNonAdjacent ( absl::Span< const ClosedInterval > intervals)

Returns true iff we have:

  • The intervals appear in increasing order.
  • for all i: intervals[i].start <= intervals[i].end (should always be true, by construction, but bad intervals can in practice escape detection in opt mode).
  • for all i but the last: intervals[i].end + 1 < intervals[i+1].start

Definition at line 41 of file sorted_interval_list.cc.

◆ IntervalUp32()

uint32_t operations_research::IntervalUp32 ( uint32_t s)
inline

Definition at line 308 of file bitset.h.

◆ IntervalUp64()

uint64_t operations_research::IntervalUp64 ( uint64_t s)
inline

Definition at line 303 of file bitset.h.

◆ IsAligned()

template<size_t alignment_bytes, typename Value>
bool operations_research::IsAligned ( Value * ptr)
inline

Definition at line 64 of file aligned_memory.h.

◆ IsArrayBoolean()

template<class T>
bool operations_research::IsArrayBoolean ( const std::vector< T > & values)

Definition at line 4209 of file constraint_solveri.h.

◆ IsArrayConstant()

template<class T>
bool operations_research::IsArrayConstant ( const std::vector< T > & values,
const T & value )

Definition at line 4199 of file constraint_solveri.h.

◆ IsArrayInRange()

template<class T>
bool operations_research::IsArrayInRange ( const std::vector< IntVar * > & vars,
T range_min,
T range_max )

Definition at line 4289 of file constraint_solveri.h.

◆ IsBitSet32()

bool operations_research::IsBitSet32 ( const uint32_t *const bitset,
uint32_t pos )
inline

Definition at line 352 of file bitset.h.

◆ IsBitSet64()

bool operations_research::IsBitSet64 ( const uint64_t *const bitset,
uint64_t pos )
inline

Definition at line 349 of file bitset.h.

◆ IsEmptyRange32()

bool operations_research::IsEmptyRange32 ( const uint32_t * bitset,
uint32_t start,
uint32_t end )

◆ IsEmptyRange64()

bool operations_research::IsEmptyRange64 ( const uint64_t * bitset,
uint64_t start,
uint64_t end )

◆ IsEulerianGraph()

template<typename Graph>
bool operations_research::IsEulerianGraph ( const Graph & graph,
bool assume_connectivity = true )

Definition at line 46 of file eulerian_path.h.

◆ IsIncreasing()

template<class T>
bool operations_research::IsIncreasing ( const std::vector< T > & values)

Definition at line 4279 of file constraint_solveri.h.

◆ IsIncreasingContiguous()

template<class T>
bool operations_research::IsIncreasingContiguous ( const std::vector< T > & values)

Definition at line 4269 of file constraint_solveri.h.

◆ IsIntegerWithinTolerance()

template<typename FloatType>
bool operations_research::IsIntegerWithinTolerance ( FloatType x,
FloatType tolerance )
inline

Definition at line 173 of file fp_utils.h.

◆ IsPositiveOrNegativeInfinity()

template<typename FloatType>
bool operations_research::IsPositiveOrNegativeInfinity ( FloatType x)
inline

Definition at line 118 of file fp_utils.h.

◆ IsSemiEulerianGraph()

template<typename NodeIndex, typename Graph>
bool operations_research::IsSemiEulerianGraph ( const Graph & graph,
std::vector< NodeIndex > * odd_nodes,
bool assume_connectivity = true )

Definition at line 60 of file eulerian_path.h.

◆ IsSmallerWithinTolerance()

template<typename FloatType>
bool operations_research::IsSmallerWithinTolerance ( FloatType x,
FloatType y,
FloatType tolerance )

Definition at line 164 of file fp_utils.h.

◆ IterableContainer()

template<typename T>
operations_research::IterableContainer ( const T & data_source) ->IterableContainer< T >

◆ JoinDebugString()

template<class T>
std::string operations_research::JoinDebugString ( const std::vector< T > & v,
absl::string_view separator )

Definition at line 40 of file string_array.h.

◆ JoinDebugStringPtr()

template<class T>
std::string operations_research::JoinDebugStringPtr ( const std::vector< T > & v,
absl::string_view separator )

Definition at line 47 of file string_array.h.

◆ JoinNameFieldPtr()

template<class T>
std::string operations_research::JoinNameFieldPtr ( const std::vector< T > & v,
absl::string_view separator )

Definition at line 60 of file string_array.h.

◆ JoinNamePtr()

template<class T>
std::string operations_research::JoinNamePtr ( const std::vector< T > & v,
absl::string_view separator )

Definition at line 54 of file string_array.h.

◆ kNotFound()

SubsetIndex operations_research::kNotFound ( - 1)
constexpr

◆ KShortestPathsOnDag()

std::vector< PathWithLength > operations_research::KShortestPathsOnDag ( const int num_nodes,
absl::Span< const ArcWithLength > arcs_with_length,
const int source,
const int destination,
const int path_count )

Definition at line 105 of file dag_shortest_path.cc.

◆ LeastSignificantBitPosition32() [1/2]

int operations_research::LeastSignificantBitPosition32 ( const uint32_t * bitset,
uint32_t start,
uint32_t end )

◆ LeastSignificantBitPosition32() [2/2]

int operations_research::LeastSignificantBitPosition32 ( uint32_t n)
inline

Definition at line 185 of file bitset.h.

◆ LeastSignificantBitPosition32DeBruijn()

int operations_research::LeastSignificantBitPosition32DeBruijn ( uint32_t n)
inline

Definition at line 147 of file bitset.h.

◆ LeastSignificantBitPosition32Default()

int operations_research::LeastSignificantBitPosition32Default ( uint32_t n)
inline

Definition at line 156 of file bitset.h.

◆ LeastSignificantBitPosition64() [1/2]

int64_t operations_research::LeastSignificantBitPosition64 ( const uint64_t * bitset,
uint64_t start,
uint64_t end )

◆ LeastSignificantBitPosition64() [2/2]

int operations_research::LeastSignificantBitPosition64 ( uint64_t n)
inline

Definition at line 130 of file bitset.h.

◆ LeastSignificantBitPosition64DeBruijn()

int operations_research::LeastSignificantBitPosition64DeBruijn ( uint64_t n)
inline

Definition at line 84 of file bitset.h.

◆ LeastSignificantBitPosition64Default()

int operations_research::LeastSignificantBitPosition64Default ( uint64_t n)
inline

Definition at line 96 of file bitset.h.

◆ LeastSignificantBitWord32()

uint32_t operations_research::LeastSignificantBitWord32 ( uint32_t n)
inline

Definition at line 67 of file bitset.h.

◆ LeastSignificantBitWord64()

uint64_t operations_research::LeastSignificantBitWord64 ( uint64_t n)
inline

Definition at line 66 of file bitset.h.

◆ LegacyScipSetSolverSpecificParameters()

absl::Status operations_research::LegacyScipSetSolverSpecificParameters ( absl::string_view parameters,
SCIP * scip )

Definition at line 35 of file scip_params.cc.

◆ LinearConstraintIsViolated()

bool operations_research::LinearConstraintIsViolated ( const ScipConstraintHandlerContext & context,
const LinearRange & constraint )

Definition at line 99 of file scip_callback.cc.

◆ LinkVarExpr()

void operations_research::LinkVarExpr ( Solver * s,
IntExpr * expr,
IntVar * var )

Definition at line 7452 of file expressions.cc.

◆ LoadGurobiDynamicLibrary()

absl::Status operations_research::LoadGurobiDynamicLibrary ( std::vector< absl::string_view > potential_paths)

Definition at line 416 of file gurobi_environment.cc.

◆ LoadGurobiFunctions()

void operations_research::LoadGurobiFunctions ( DynamicLibrary * gurobi_dynamic_library)

Definition at line 222 of file gurobi_environment.cc.

◆ LoadXpressDynamicLibrary()

absl::Status operations_research::LoadXpressDynamicLibrary ( std::string & xpresspath)

Definition at line 280 of file xpress_environment.cc.

◆ LoadXpressFunctions()

void operations_research::LoadXpressFunctions ( DynamicLibrary * xpress_dynamic_library)

Definition at line 134 of file xpress_environment.cc.

◆ LocalBfs()

void operations_research::LocalBfs ( const ::util::StaticGraph< int, int > & graph,
int source,
int stop_after_num_nodes,
std::vector< int > * visited,
std::vector< int > * num_within_radius,
std::vector< bool > * tmp_mask )

Definition at line 78 of file find_graph_symmetries.cc.

◆ LocalCheapestInsertionParameters_InsertionSortingProperty_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::LocalCheapestInsertionParameters_InsertionSortingProperty_descriptor ( )

Definition at line 226 of file routing_heuristic_parameters.pb.cc.

◆ LocalCheapestInsertionParameters_InsertionSortingProperty_IsValid()

bool operations_research::LocalCheapestInsertionParameters_InsertionSortingProperty_IsValid ( int value)
inline

Definition at line 145 of file routing_heuristic_parameters.pb.h.

◆ LocalCheapestInsertionParameters_InsertionSortingProperty_Name() [1/2]

template<>
const ::std::string & operations_research::LocalCheapestInsertionParameters_InsertionSortingProperty_Name ( LocalCheapestInsertionParameters_InsertionSortingProperty value)
inline

Definition at line 158 of file routing_heuristic_parameters.pb.h.

◆ LocalCheapestInsertionParameters_InsertionSortingProperty_Name() [2/2]

template<typename T>
const ::std::string & operations_research::LocalCheapestInsertionParameters_InsertionSortingProperty_Name ( T value)

Definition at line 151 of file routing_heuristic_parameters.pb.h.

◆ LocalCheapestInsertionParameters_InsertionSortingProperty_Parse()

bool operations_research::LocalCheapestInsertionParameters_InsertionSortingProperty_Parse ( ::absl::string_view name,
LocalCheapestInsertionParameters_InsertionSortingProperty *PROTOBUF_NONNULL value )
inline

Definition at line 162 of file routing_heuristic_parameters.pb.h.

◆ LocalCheapestInsertionParameters_PairInsertionStrategy_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::LocalCheapestInsertionParameters_PairInsertionStrategy_descriptor ( )

Definition at line 220 of file routing_heuristic_parameters.pb.cc.

◆ LocalCheapestInsertionParameters_PairInsertionStrategy_IsValid()

bool operations_research::LocalCheapestInsertionParameters_PairInsertionStrategy_IsValid ( int value)
inline

Definition at line 102 of file routing_heuristic_parameters.pb.h.

◆ LocalCheapestInsertionParameters_PairInsertionStrategy_Name() [1/2]

template<>
const ::std::string & operations_research::LocalCheapestInsertionParameters_PairInsertionStrategy_Name ( LocalCheapestInsertionParameters_PairInsertionStrategy value)
inline

Definition at line 115 of file routing_heuristic_parameters.pb.h.

◆ LocalCheapestInsertionParameters_PairInsertionStrategy_Name() [2/2]

template<typename T>
const ::std::string & operations_research::LocalCheapestInsertionParameters_PairInsertionStrategy_Name ( T value)

Definition at line 108 of file routing_heuristic_parameters.pb.h.

◆ LocalCheapestInsertionParameters_PairInsertionStrategy_Parse()

bool operations_research::LocalCheapestInsertionParameters_PairInsertionStrategy_Parse ( ::absl::string_view name,
LocalCheapestInsertionParameters_PairInsertionStrategy *PROTOBUF_NONNULL value )
inline

Definition at line 119 of file routing_heuristic_parameters.pb.h.

◆ LocalSearchMetaheuristic_Value_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::LocalSearchMetaheuristic_Value_descriptor ( )

Definition at line 159 of file routing_enums.pb.cc.

◆ LocalSearchMetaheuristic_Value_IsValid()

bool operations_research::LocalSearchMetaheuristic_Value_IsValid ( int value)
inline

Definition at line 163 of file routing_enums.pb.h.

◆ LocalSearchMetaheuristic_Value_Name() [1/2]

template<>
const ::std::string & operations_research::LocalSearchMetaheuristic_Value_Name ( LocalSearchMetaheuristic_Value value)
inline

Definition at line 176 of file routing_enums.pb.h.

◆ LocalSearchMetaheuristic_Value_Name() [2/2]

template<typename T>
const ::std::string & operations_research::LocalSearchMetaheuristic_Value_Name ( T value)

Definition at line 169 of file routing_enums.pb.h.

◆ LocalSearchMetaheuristic_Value_Parse()

bool operations_research::LocalSearchMetaheuristic_Value_Parse ( ::absl::string_view name,
LocalSearchMetaheuristic_Value *PROTOBUF_NONNULL value )
inline

Definition at line 180 of file routing_enums.pb.h.

◆ log_full_license_error()

void operations_research::log_full_license_error ( int code,
const std::string & xpress_lib_dir )

Definition at line 416 of file xpress_environment.cc.

◆ log_message_about_XPRSinit_argument()

void operations_research::log_message_about_XPRSinit_argument ( )

Definition at line 427 of file xpress_environment.cc.

◆ LogCostAndTiming() [1/2]

void operations_research::LogCostAndTiming ( const absl::string_view problem_name,
absl::string_view alg_name,
const SetCoverInvariant & inv,
int64_t run_time )

Definition at line 141 of file set_cover_solve.cc.

◆ LogCostAndTiming() [2/2]

void operations_research::LogCostAndTiming ( const SetCoverSolutionGenerator & generator)

Definition at line 149 of file set_cover_solve.cc.

◆ LogStats()

void operations_research::LogStats ( const SetCoverModel & model)

Definition at line 117 of file set_cover_solve.cc.

◆ Main()

void operations_research::Main ( )

Definition at line 38 of file course_scheduling_run.cc.

◆ MakeActive()

LocalSearchOperator * operations_research::MakeActive ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
std::function< const std::vector< int > &(int, int)> get_incoming_neighbors = nullptr,
std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors = nullptr )

--— MakeActive --—

MakeActive inserts an inactive node into a path. Possible neighbors for the path 1 -> 2 -> 3 -> 4 with 5 inactive (where 1 and 4 are first and last nodes of the path) are: 1 -> 5 -> 2 -> 3 -> 4 1 -> 2 -> 5 -> 3 -> 4 1 -> 2 -> 3 -> 5 -> 4

Definition at line 818 of file local_search.cc.

◆ MakeActiveAndRelocate()

LocalSearchOperator * operations_research::MakeActiveAndRelocate ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class )

--— MakeActiveAndRelocate --—

MakeActiveAndRelocate makes a node active next to a node being relocated. Possible neighbor for paths 0 -> 4, 1 -> 2 -> 5 and 3 inactive is: 0 -> 3 -> 2 -> 4, 1 -> 5.

Definition at line 990 of file local_search.cc.

◆ MakeActiveNodeGroupFilter()

IntVarLocalSearchFilter * operations_research::MakeActiveNodeGroupFilter ( const RoutingModel & routing_model)

Returns a filter ensuring that all nodes in a same activity group have the same activity.

Definition at line 542 of file routing_filters.cc.

◆ MakeAllUnperformed()

DecisionBuilder * operations_research::MakeAllUnperformed ( RoutingModel * model)

Definition at line 5512 of file routing_search.cc.

◆ MakeBareIntToIntFunction()

RangeIntToIntFunction * operations_research::MakeBareIntToIntFunction ( std::function< int64_t(int64_t)> f)

Definition at line 225 of file range_query_function.cc.

◆ MakeBinCapacities()

std::unique_ptr< BinCapacities > operations_research::MakeBinCapacities ( const std::vector< RoutingDimension * > & dimensions,
const PathsMetadata & paths_metadata )

Definition at line 5564 of file routing.cc.

◆ MakeCachedIntToIntFunction()

RangeIntToIntFunction * operations_research::MakeCachedIntToIntFunction ( const std::function< int64_t(int64_t)> & f,
int64_t domain_start,
int64_t domain_end )

Definition at line 230 of file range_query_function.cc.

◆ MakeCachedRangeMinMaxIndexFunction()

RangeMinMaxIndexFunction * operations_research::MakeCachedRangeMinMaxIndexFunction ( const std::function< int64_t(int64_t)> & f,
int64_t domain_start,
int64_t domain_end )

Definition at line 236 of file range_query_function.cc.

◆ MakeChainInactive()

LocalSearchOperator * operations_research::MakeChainInactive ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class )

--— MakeChainInactive --—

Operator which makes a "chain" of path nodes inactive. Possible neighbors for the path 1 -> 2 -> 3 -> 4 (where 1 and 4 are first and last nodes of the path) are: 1 -> 3 -> 4 with 2 inactive 1 -> 2 -> 4 with 3 inactive 1 -> 4 with 2 and 3 inactive

Definition at line 1122 of file local_search.cc.

◆ MakeConstraintDemon0()

template<class T>
Demon * operations_research::MakeConstraintDemon0 ( Solver *const s,
T *const ct,
void(T::* method )(),
const std::string & name )

Definition at line 533 of file constraint_solveri.h.

◆ MakeConstraintDemon1()

template<class T, class P>
Demon * operations_research::MakeConstraintDemon1 ( Solver *const s,
T *const ct,
void(T::* method )(P),
const std::string & name,
P param1 )

Definition at line 574 of file constraint_solveri.h.

◆ MakeConstraintDemon2()

template<class T, class P, class Q>
Demon * operations_research::MakeConstraintDemon2 ( Solver *const s,
T *const ct,
void(T::* method )(P, Q),
const std::string & name,
P param1,
Q param2 )

Definition at line 612 of file constraint_solveri.h.

◆ MakeConstraintDemon3()

template<class T, class P, class Q, class R>
Demon * operations_research::MakeConstraintDemon3 ( Solver *const s,
T *const ct,
void(T::* method )(P, Q, R),
const std::string & name,
P param1,
Q param2,
R param3 )

Definition at line 655 of file constraint_solveri.h.

◆ MakeCPFeasibilityFilter()

IntVarLocalSearchFilter * operations_research::MakeCPFeasibilityFilter ( RoutingModel * routing_model)

Returns a filter checking the current solution using CP propagation.

Definition at line 3917 of file routing_filters.cc.

◆ MakeCross()

LocalSearchOperator * operations_research::MakeCross ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
std::function< const std::vector< int > &(int, int)> get_incoming_neighbors = nullptr,
std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors = nullptr )

--— Cross --—

Cross echanges the starting chains of 2 paths, including exchanging the whole paths. First and last nodes are not moved. Possible neighbors for the paths 1 -> 2 -> 3 -> 4 -> 5 and 6 -> 7 -> 8 (where (1, 5) and (6, 8) are first and last nodes of the paths and can therefore not be moved): 1 -> 7 -> 3 -> 4 -> 5 6 -> 2 -> 8 1 -> 7 -> 4 -> 5 6 -> 2 -> 3 -> 8 1 -> 7 -> 5 6 -> 2 -> 3 -> 4 -> 8

Definition at line 717 of file local_search.cc.

◆ MakeCumulBoundsPropagatorFilter()

IntVarLocalSearchFilter * operations_research::MakeCumulBoundsPropagatorFilter ( const RoutingDimension & dimension)

Returns a filter handling dimension cumul bounds.

Definition at line 3226 of file routing_filters.cc.

◆ MakeDelayedConstraintDemon0()

template<class T>
Demon * operations_research::MakeDelayedConstraintDemon0 ( Solver *const s,
T *const ct,
void(T::* method )(),
const std::string & name )

Definition at line 695 of file constraint_solveri.h.

◆ MakeDelayedConstraintDemon1()

template<class T, class P>
Demon * operations_research::MakeDelayedConstraintDemon1 ( Solver *const s,
T *const ct,
void(T::* method )(P),
const std::string & name,
P param1 )

Definition at line 731 of file constraint_solveri.h.

◆ MakeDelayedConstraintDemon2()

template<class T, class P, class Q>
Demon * operations_research::MakeDelayedConstraintDemon2 ( Solver *const s,
T *const ct,
void(T::* method )(P, Q),
const std::string & name,
P param1,
Q param2 )

Definition at line 775 of file constraint_solveri.h.

◆ MakeDifferentFromValues()

Constraint * operations_research::MakeDifferentFromValues ( Solver * solver,
IntVar * var,
std::vector< int64_t > values )

Definition at line 66 of file routing_constraints.cc.

◆ MakeDimensionFilter()

LocalSearchFilter * operations_research::MakeDimensionFilter ( Solver * solver,
std::unique_ptr< DimensionChecker > checker,
absl::string_view dimension_name )

Definition at line 4655 of file routing_filters.cc.

◆ MakeExchange()

LocalSearchOperator * operations_research::MakeExchange ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
std::function< const std::vector< int > &(int, int)> get_incoming_neighbors = nullptr,
std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors = nullptr )

--— Exchange --—

Exchanges the positions of two nodes. Possible neighbors for the path 1 -> 2 -> 3 -> 4 -> 5 (where (1, 5) are first and last nodes of the path and can therefore not be moved): 1 -> 3 -> 2 -> 4 -> 5 1 -> 4 -> 3 -> 2 -> 5 1 -> 2 -> 4 -> 3 -> 5

Definition at line 601 of file local_search.cc.

◆ MakeExchangeSubtrip() [1/2]

LocalSearchOperator * operations_research::MakeExchangeSubtrip ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
absl::Span< const PickupDeliveryPair > pairs )

Definition at line 1841 of file routing_neighborhoods.cc.

◆ MakeExchangeSubtrip() [2/2]

LocalSearchOperator * operations_research::MakeExchangeSubtrip ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
std::function< const std::vector< int > &(int, int)> get_incoming_neighbors,
std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors,
absl::Span< const PickupDeliveryPair > pairs )

Definition at line 1822 of file routing_neighborhoods.cc.

◆ MakeExtendedSwapActive()

LocalSearchOperator * operations_research::MakeExtendedSwapActive ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class )

--— ExtendedSwapActive --—

ExtendedSwapActive makes an inactive node active and an active one inactive. It is similar to SwapActiveOperator excepts that it tries to insert the inactive node in all possible positions instead of just the position of the node made inactive. Possible neighbors for the path 1 -> 2 -> 3 -> 4 with 5 inactive (where 1 and 4 are first and last nodes of the path) are: 1 -> 5 -> 3 -> 4 & 2 inactive 1 -> 3 -> 5 -> 4 & 2 inactive 1 -> 5 -> 2 -> 4 & 3 inactive 1 -> 2 -> 5 -> 4 & 3 inactive

Definition at line 1296 of file local_search.cc.

◆ MakeGlobalLPCumulFilter()

IntVarLocalSearchFilter * operations_research::MakeGlobalLPCumulFilter ( GlobalDimensionCumulOptimizer * lp_optimizer,
GlobalDimensionCumulOptimizer * mp_optimizer,
bool filter_objective_cost )

Returns a filter checking global linear constraints and costs.

Definition at line 3383 of file routing_filters.cc.

◆ MakeGlobalVehicleBreaksConstraint()

Constraint * operations_research::MakeGlobalVehicleBreaksConstraint ( Solver * solver,
const RoutingDimension * dimension )

Definition at line 1031 of file routing_constraints.cc.

◆ MakeGroupPairAndRelocate() [1/2]

LocalSearchOperator * operations_research::MakeGroupPairAndRelocate ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
const std::vector< PickupDeliveryPair > & pairs )

Definition at line 679 of file routing_neighborhoods.cc.

◆ MakeGroupPairAndRelocate() [2/2]

LocalSearchOperator * operations_research::MakeGroupPairAndRelocate ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
std::function< const std::vector< int > &(int, int)> get_incoming_neighbors,
std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors,
const std::vector< PickupDeliveryPair > & pairs )

Definition at line 659 of file routing_neighborhoods.cc.

◆ MakeHamiltonianPathSolver()

template<typename CostType, typename CostFunction>
HamiltonianPathSolver< CostType, CostFunction > operations_research::MakeHamiltonianPathSolver ( int num_nodes,
CostFunction cost )

Definition at line 604 of file hamiltonian_path.h.

◆ MakeInactive()

LocalSearchOperator * operations_research::MakeInactive ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class )

--— MakeInactive --—

MakeInactive makes path nodes inactive. Possible neighbors for the path 1 -> 2 -> 3 -> 4 (where 1 and 4 are first and last nodes of the path) are: 1 -> 3 -> 4 & 2 inactive 1 -> 2 -> 4 & 3 inactive

Definition at line 1022 of file local_search.cc.

◆ MakeIndexPairSwapActive()

LocalSearchOperator * operations_research::MakeIndexPairSwapActive ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
const std::vector< PickupDeliveryPair > & pairs )

Definition at line 1285 of file routing_neighborhoods.cc.

◆ MakeLightPairRelocate() [1/2]

LocalSearchOperator * operations_research::MakeLightPairRelocate ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
const std::vector< PickupDeliveryPair > & pairs,
std::function< bool(int64_t)> force_lifo )

Definition at line 807 of file routing_neighborhoods.cc.

◆ MakeLightPairRelocate() [2/2]

LocalSearchOperator * operations_research::MakeLightPairRelocate ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
std::function< const std::vector< int > &(int, int)> get_incoming_neighbors,
std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors,
const std::vector< PickupDeliveryPair > & pairs,
std::function< bool(int64_t)> force_lifo )

Definition at line 787 of file routing_neighborhoods.cc.

◆ MakeLightVehicleBreaksFilter()

LocalSearchFilter * operations_research::MakeLightVehicleBreaksFilter ( Solver * solver,
std::unique_ptr< LightVehicleBreaksChecker > checker,
absl::string_view dimension_name )

Definition at line 4784 of file routing_filters.cc.

◆ MakeLinKernighan()

LocalSearchOperator * operations_research::MakeLinKernighan ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
const Solver::IndexEvaluator3 & evaluator,
bool topt )

--— Lin-Kernighan --—

Definition at line 1791 of file local_search.cc.

◆ MakeMaxActiveVehiclesFilter()

IntVarLocalSearchFilter * operations_research::MakeMaxActiveVehiclesFilter ( const RoutingModel & routing_model)

Returns a filter ensuring that max active vehicles constraints are enforced.

Definition at line 224 of file routing_filters.cc.

◆ MakeNeighborAcceptanceCriterion()

std::unique_ptr< NeighborAcceptanceCriterion > operations_research::MakeNeighborAcceptanceCriterion ( const RoutingModel & model,
const AcceptanceStrategy & acceptance_strategy,
const NeighborAcceptanceCriterion::SearchState & final_search_state,
std::mt19937 * rnd )

Definition at line 1253 of file routing_ils.cc.

◆ MakeNodeDisjunctionFilter()

IntVarLocalSearchFilter * operations_research::MakeNodeDisjunctionFilter ( const RoutingModel & routing_model,
bool filter_cost )

Returns a filter ensuring that node disjunction constraints are enforced.

Definition at line 705 of file routing_filters.cc.

◆ MakeNumActiveVehiclesCapacityConstraint()

Constraint * operations_research::MakeNumActiveVehiclesCapacityConstraint ( Solver * solver,
std::vector< IntVar * > transit_vars,
std::vector< IntVar * > active_vars,
std::vector< IntVar * > vehicle_active_vars,
std::vector< int64_t > vehicle_capacities,
int max_active_vehicles,
bool enforce_active_vehicles = false )

Makes inactive the vehicles which cannot cover the demand resulting from the transit variables of the active nodes given the maximum number of vehicles which can be active.

Definition at line 1138 of file routing_constraints.cc.

◆ MakeOrderedActivityGroupFilter()

IntVarLocalSearchFilter * operations_research::MakeOrderedActivityGroupFilter ( const RoutingModel & routing_model)

Returns a filter ensuring that for each ordered activity group, if nodes[i] is active then nodes[i-1] is active.

Definition at line 548 of file routing_filters.cc.

◆ MakePairActive()

LocalSearchOperator * operations_research::MakePairActive ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
const std::vector< PickupDeliveryPair > & pairs )

Definition at line 474 of file routing_neighborhoods.cc.

◆ MakePairExchange() [1/2]

LocalSearchOperator * operations_research::MakePairExchange ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
const std::vector< PickupDeliveryPair > & pairs )

Definition at line 939 of file routing_neighborhoods.cc.

◆ MakePairExchange() [2/2]

LocalSearchOperator * operations_research::MakePairExchange ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
std::function< const std::vector< int > &(int, int)> get_incoming_neighbors,
std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors,
const std::vector< PickupDeliveryPair > & pairs )

Definition at line 920 of file routing_neighborhoods.cc.

◆ MakePairExchangeRelocate()

LocalSearchOperator * operations_research::MakePairExchangeRelocate ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
const std::vector< PickupDeliveryPair > & pairs )

Definition at line 1099 of file routing_neighborhoods.cc.

◆ MakePairInactive()

LocalSearchOperator * operations_research::MakePairInactive ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
const std::vector< PickupDeliveryPair > & pairs )

Definition at line 511 of file routing_neighborhoods.cc.

◆ MakePairNodeSwapActive()

template<bool swap_first>
LocalSearchOperator * operations_research::MakePairNodeSwapActive ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
const std::vector< PickupDeliveryPair > & pairs )

Definition at line 791 of file routing_neighborhoods.h.

◆ MakePairRelocate()

LocalSearchOperator * operations_research::MakePairRelocate ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
const std::vector< PickupDeliveryPair > & pairs )

Definition at line 607 of file routing_neighborhoods.cc.

◆ MakePathCumulFilter()

IntVarLocalSearchFilter * operations_research::MakePathCumulFilter ( const RoutingDimension & dimension,
bool propagate_own_objective_value,
bool filter_objective_cost,
bool may_use_optimizers )

Returns a filter handling dimension costs and constraints.

Definition at line 2646 of file routing_filters.cc.

◆ MakePathEnergyCostFilter()

LocalSearchFilter * operations_research::MakePathEnergyCostFilter ( Solver * solver,
std::unique_ptr< PathEnergyCostChecker > checker,
absl::string_view dimension_name )

Definition at line 5237 of file routing_filters.cc.

◆ MakePathLns()

LocalSearchOperator * operations_research::MakePathLns ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
int number_of_chunks,
int chunk_size,
bool unactive_fragments )

--— Path-based Large Neighborhood Search --—

Breaks "number_of_chunks" chains of "chunk_size" arcs, and deactivate all inactive nodes if "unactive_fragments" is true. As a special case, if chunk_size=0, then we break full paths.

Definition at line 1877 of file local_search.cc.

◆ MakePathSpansAndTotalSlacks()

Constraint * operations_research::MakePathSpansAndTotalSlacks ( const RoutingDimension * dimension,
std::vector< IntVar * > spans,
std::vector< IntVar * > total_slacks )

For every vehicle of the routing model:

  • if total_slacks[vehicle] is not nullptr, constrains it to be the sum of slacks on that vehicle, that is, dimension->CumulVar(end) - dimension->CumulVar(start) - sum_{node in path of vehicle} dimension->FixedTransitVar(node).
  • if spans[vehicle] is not nullptr, constrains it to be dimension->CumulVar(end) - dimension->CumulVar(start) This does stronger propagation than a decomposition, and takes breaks into account.

Definition at line 638 of file routing_constraints.cc.

◆ MakePathStateFilter()

LocalSearchFilter * operations_research::MakePathStateFilter ( Solver * solver,
std::unique_ptr< PathState > path_state,
const std::vector< IntVar * > & nexts )

Definition at line 4342 of file routing_filters.cc.

◆ MakePerturbationDecisionBuilder()

DecisionBuilder * operations_research::MakePerturbationDecisionBuilder ( const RoutingSearchParameters & parameters,
RoutingModel * model,
std::mt19937 * rnd,
const Assignment * assignment,
std::function< bool()> stop_search,
LocalSearchFilterManager * filter_manager )

Definition at line 1236 of file routing_ils.cc.

◆ MakePickupDeliveryFilter()

LocalSearchFilter * operations_research::MakePickupDeliveryFilter ( const RoutingModel & routing_model,
const PathState * path_state,
absl::Span< const PickupDeliveryPair > pairs,
const std::vector< RoutingModel::PickupAndDeliveryPolicy > & vehicle_policies )

Returns a filter enforcing pickup and delivery constraints for the given pair of nodes and given policies.

Definition at line 3095 of file routing_filters.cc.

◆ MakeRelocate()

LocalSearchOperator * operations_research::MakeRelocate ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
std::function< const std::vector< int > &(int, int)> get_incoming_neighbors = nullptr,
std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors = nullptr,
int64_t chain_length = 1LL,
bool single_path = false,
const std::string & name = "Relocate" )

--— Relocate --—

Moves a sub-chain of a path to another position; the specified chain length is the fixed length of the chains being moved. When this length is 1 the operator simply moves a node to another position. Possible neighbors for the path 1 -> 2 -> 3 -> 4 -> 5, for a chain length of 2 (where (1, 5) are first and last nodes of the path and can therefore not be moved): 1 -> 4 -> 2 -> 3 -> 5 1 -> 3 -> 4 -> 2 -> 5 Using Relocate with chain lengths of 1, 2 and 3 together is equivalent to the OrOpt operator on a path. The OrOpt operator is a limited version of 3Opt (breaks 3 arcs on a path).

Definition at line 538 of file local_search.cc.

◆ MakeRelocateExpensiveChain()

LocalSearchOperator * operations_research::MakeRelocateExpensiveChain ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
int num_arcs_to_consider,
std::function< int64_t(int64_t, int64_t, int64_t)> arc_cost_for_path_start )

Definition at line 1417 of file routing_neighborhoods.cc.

◆ MakeRelocateNeighbors() [1/2]

LocalSearchOperator * operations_research::MakeRelocateNeighbors ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
RoutingTransitCallback2 arc_evaluator )

Definition at line 158 of file routing_neighborhoods.cc.

◆ MakeRelocateNeighbors() [2/2]

LocalSearchOperator * operations_research::MakeRelocateNeighbors ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
std::function< const std::vector< int > &(int, int)> get_incoming_neighbors,
std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors,
RoutingTransitCallback2 arc_evaluator )

Definition at line 139 of file routing_neighborhoods.cc.

◆ MakeRelocateSubtrip() [1/2]

LocalSearchOperator * operations_research::MakeRelocateSubtrip ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
absl::Span< const PickupDeliveryPair > pairs )

Definition at line 1611 of file routing_neighborhoods.cc.

◆ MakeRelocateSubtrip() [2/2]

LocalSearchOperator * operations_research::MakeRelocateSubtrip ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
std::function< const std::vector< int > &(int, int)> get_incoming_neighbors,
std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors,
absl::Span< const PickupDeliveryPair > pairs )

Definition at line 1592 of file routing_neighborhoods.cc.

◆ MakeResourceAssignmentFilter()

LocalSearchFilter * operations_research::MakeResourceAssignmentFilter ( LocalDimensionCumulOptimizer * optimizer,
LocalDimensionCumulOptimizer * mp_optimizer,
bool propagate_own_objective_value,
bool filter_objective_cost )

Returns a filter checking the feasibility and cost of the resource assignment.

Definition at line 3810 of file routing_filters.cc.

◆ MakeResourceConstraint()

Constraint * operations_research::MakeResourceConstraint ( const RoutingModel::ResourceGroup * resource_group,
const std::vector< IntVar * > * vehicle_resource_vars,
RoutingModel * model )

Definition at line 275 of file routing_constraints.cc.

◆ MakeRestoreDimensionValuesForUnchangedRoutes()

DecisionBuilder * operations_research::MakeRestoreDimensionValuesForUnchangedRoutes ( RoutingModel * model)

A decision builder that monitors solutions, and tries to fix dimension variables whose route did not change in the candidate solution. Dimension variables are Cumul, Slack and break variables of all dimensions. The user must make sure that those variables will be always be fixed at solution, typically by composing another DecisionBuilder after this one. If this DecisionBuilder returns a non-nullptr value at some node of the search tree, it will always return nullptr in the subtree of that node. Moreover, the decision will be a simultaneous assignment of the dimension variables of unchanged routes on the left branch, and an empty decision on the right branch.

Definition at line 889 of file routing_decision_builders.cc.

◆ MakeRouteConstraint()

Constraint * operations_research::MakeRouteConstraint ( RoutingModel * model,
std::vector< IntVar * > route_cost_vars,
std::function< std::optional< int64_t >(const std::vector< int64_t > &)> route_evaluator )

Definition at line 796 of file routing_constraints.cc.

◆ MakeRouteConstraintFilter()

IntVarLocalSearchFilter * operations_research::MakeRouteConstraintFilter ( const RoutingModel & routing_model)

Returns a filter tracking route constraints.

Definition at line 158 of file routing_filters.cc.

◆ MakeRuinAndRecreateDecisionBuilder()

DecisionBuilder * operations_research::MakeRuinAndRecreateDecisionBuilder ( const RoutingSearchParameters & parameters,
RoutingModel * model,
std::mt19937 * rnd,
const Assignment * assignment,
std::function< bool()> stop_search,
LocalSearchFilterManager * filter_manager )

Definition at line 1220 of file routing_ils.cc.

◆ MakeSameVehicleCostFilter()

IntVarLocalSearchFilter * operations_research::MakeSameVehicleCostFilter ( const RoutingModel & routing_model)

Returns a filter computing same vehicle costs.

Definition at line 1198 of file routing_filters.cc.

◆ MakeSetCumulsFromGlobalDimensionCosts()

DecisionBuilder * operations_research::MakeSetCumulsFromGlobalDimensionCosts ( Solver * solver,
GlobalDimensionCumulOptimizer * global_optimizer,
GlobalDimensionCumulOptimizer * global_mp_optimizer,
bool optimize_and_pack,
std::vector< RoutingModel::RouteDimensionTravelInfo > dimension_travel_info_per_route )

Variant based on global optimizers, handling all routes together.

Definition at line 719 of file routing_decision_builders.cc.

◆ MakeSetCumulsFromLocalDimensionCosts()

DecisionBuilder * operations_research::MakeSetCumulsFromLocalDimensionCosts ( Solver * solver,
LocalDimensionCumulOptimizer * lp_optimizer,
LocalDimensionCumulOptimizer * mp_optimizer,
bool optimize_and_pack = false,
std::vector< RoutingModel::RouteDimensionTravelInfo > dimension_travel_info_per_route = {} )

Functions returning decision builders which try to instantiate dimension cumul variables using scheduling optimizers. Variant based on local optimizers, for which each route is handled separately.

Definition at line 544 of file routing_decision_builders.cc.

◆ MakeSetValuesFromTargets()

DecisionBuilder * operations_research::MakeSetValuesFromTargets ( Solver * solver,
std::vector< IntVar * > variables,
std::vector< int64_t > targets )

A decision builder which tries to assign values to variables as close as possible to target values first.

Definition at line 103 of file routing_decision_builders.cc.

◆ MakeSwapActive()

LocalSearchOperator * operations_research::MakeSwapActive ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class )

--— SwapActive --—

SwapActive replaces an active node by an inactive one. Possible neighbors for the path 1 -> 2 -> 3 -> 4 with 5 inactive (where 1 and 4 are first and last nodes of the path) are: 1 -> 5 -> 3 -> 4 & 2 inactive 1 -> 2 -> 5 -> 4 & 3 inactive

Definition at line 1155 of file local_search.cc.

◆ MakeSwapActiveChain()

LocalSearchOperator * operations_research::MakeSwapActiveChain ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
int max_chain_size )

--— SwapActiveChain --—

Definition at line 1256 of file local_search.cc.

◆ MakeSwapActiveToShortestPath()

LocalSearchOperator * operations_research::MakeSwapActiveToShortestPath ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
std::vector< std::vector< int64_t > > alternative_sets,
RoutingTransitCallback2 arc_evaluator )

Definition at line 367 of file routing_neighborhoods.cc.

◆ MakeSweepDecisionBuilder()

DecisionBuilder * operations_research::MakeSweepDecisionBuilder ( RoutingModel * model,
bool check_assignment )

Definition at line 5478 of file routing_search.cc.

◆ MakeTSPLns()

LocalSearchOperator * operations_research::MakeTSPLns ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
Solver::IndexEvaluator3 evaluator,
int tsp_size )

TSP-base lns. Randomly merge consecutive nodes until n "meta"-nodes remain and solve the corresponding TSP. This can be seen as a large neighborhood search operator although decisions are taken with the operator. This is an "unlimited" neighborhood which must be stopped by search limits. To force diversification, the operator iteratively forces each node to serve as base of a meta-node.

Definition at line 1529 of file local_search.cc.

◆ MakeTSPOpt()

LocalSearchOperator * operations_research::MakeTSPOpt ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
Solver::IndexEvaluator3 evaluator,
int chain_length )

--— TSP-based operators --—

Sliding TSP operator Uses an exact dynamic programming algorithm to solve the TSP corresponding to path sub-chains. For a subchain 1 -> 2 -> 3 -> 4 -> 5 -> 6, solves the TSP on nodes A, 2, 3, 4, 5, where A is a merger of nodes 1 and 6 such that cost(A,i) = cost(1,i) and cost(i,A) = cost(i,6).

Definition at line 1375 of file local_search.cc.

◆ MakeTwoOpt()

LocalSearchOperator * operations_research::MakeTwoOpt ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
std::function< const std::vector< int > &(int, int)> get_incoming_neighbors = nullptr,
std::function< const std::vector< int > &(int, int)> get_outgoing_neighbors = nullptr )

--— 2Opt --—

Reverses a sub-chain of a path. It is called 2Opt because it breaks 2 arcs on the path; resulting paths are called 2-optimal. Possible neighbors for the path 1 -> 2 -> 3 -> 4 -> 5 (where (1, 5) are first and last nodes of the path and can therefore not be moved): 1 -> 3 -> 2 -> 4 -> 5 1 -> 4 -> 3 -> 2 -> 5 1 -> 2 -> 4 -> 3 -> 5

Definition at line 445 of file local_search.cc.

◆ MakeTwoOptWithShortestPath()

LocalSearchOperator * operations_research::MakeTwoOptWithShortestPath ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class,
std::vector< std::vector< int64_t > > alternative_sets,
RoutingTransitCallback2 arc_evaluator )

Definition at line 316 of file routing_neighborhoods.cc.

◆ MakeTypeRegulationsFilter()

IntVarLocalSearchFilter * operations_research::MakeTypeRegulationsFilter ( const RoutingModel & routing_model)

Returns a filter ensuring type regulation constraints are enforced.

Definition at line 1350 of file routing_filters.cc.

◆ MakeVehicleAmortizedCostFilter()

IntVarLocalSearchFilter * operations_research::MakeVehicleAmortizedCostFilter ( const RoutingModel & routing_model)

Returns a filter computing vehicle amortized costs.

Definition at line 1068 of file routing_filters.cc.

◆ MakeVehicleVarFilter()

LocalSearchFilter * operations_research::MakeVehicleVarFilter ( const RoutingModel & routing_model,
const PathState * path_state )

Returns a filter checking that vehicle variable domains are respected.

Definition at line 3165 of file routing_filters.cc.

◆ MaximizeLinearAssignment()

void operations_research::MaximizeLinearAssignment ( absl::Span< const std::vector< double > > cost,
absl::flat_hash_map< int, int > * direct_assignment,
absl::flat_hash_map< int, int > * reverse_assignment )

Definition at line 673 of file hungarian.cc.

◆ MaxVarArray()

int64_t operations_research::MaxVarArray ( const std::vector< IntVar * > & vars)
inline

The std::max<int64_t> is needed for compilation on MSVC.

Definition at line 4335 of file constraint_solveri.h.

◆ MemoryUsage()

std::string operations_research::MemoryUsage ( )

Definition at line 32 of file stats.cc.

◆ MergeConstraintHandlerResults()

GScipCallbackResult operations_research::MergeConstraintHandlerResults ( const GScipCallbackResult result1,
const GScipCallbackResult result2,
const ConstraintHandlerCallbackType callback_type )

Definition at line 296 of file gscip_constraint_handler.cc.

◆ MergeMPConstraintProtoExceptTerms()

void operations_research::MergeMPConstraintProtoExceptTerms ( const MPConstraintProto & from,
MPConstraintProto * to )

Definition at line 938 of file model_validator.cc.

◆ MinimizeLinearAssignment()

void operations_research::MinimizeLinearAssignment ( absl::Span< const std::vector< double > > cost,
absl::flat_hash_map< int, int > * direct_assignment,
absl::flat_hash_map< int, int > * reverse_assignment )

Definition at line 655 of file hungarian.cc.

◆ MinVarArray()

int64_t operations_research::MinVarArray ( const std::vector< IntVar * > & vars)
inline

The std::min<int64_t> is needed for compilation on MSVC.

Definition at line 4345 of file constraint_solveri.h.

◆ mix()

void operations_research::mix ( uint64_t & a,
uint64_t & b,
uint64_t & c )
inlinestatic

Definition at line 29 of file hash.h.

◆ ModelProtoFromLpFormat()

absl::StatusOr< MPModelProto > operations_research::ModelProtoFromLpFormat ( absl::string_view model)

Definition at line 472 of file lp_parser.cc.

◆ MostSignificantBitPosition32() [1/2]

int operations_research::MostSignificantBitPosition32 ( const uint32_t * bitset,
uint32_t start,
uint32_t end )

◆ MostSignificantBitPosition32() [2/2]

int operations_research::MostSignificantBitPosition32 ( uint32_t n)
inline

Definition at line 276 of file bitset.h.

◆ MostSignificantBitPosition32Default()

int operations_research::MostSignificantBitPosition32Default ( uint32_t n)
inline

Definition at line 252 of file bitset.h.

◆ MostSignificantBitPosition64() [1/2]

int64_t operations_research::MostSignificantBitPosition64 ( const uint64_t * bitset,
uint64_t start,
uint64_t end )

◆ MostSignificantBitPosition64() [2/2]

int operations_research::MostSignificantBitPosition64 ( uint64_t n)
inline

Definition at line 234 of file bitset.h.

◆ MostSignificantBitPosition64Default()

int operations_research::MostSignificantBitPosition64Default ( uint64_t n)
inline

Definition at line 206 of file bitset.h.

◆ MPModelProto_Annotation_TargetType_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::MPModelProto_Annotation_TargetType_descriptor ( )

Definition at line 1151 of file linear_solver.pb.cc.

◆ MPModelProto_Annotation_TargetType_IsValid()

bool operations_research::MPModelProto_Annotation_TargetType_IsValid ( int value)
inline

Definition at line 225 of file linear_solver.pb.h.

◆ MPModelProto_Annotation_TargetType_Name() [1/2]

template<>
const ::std::string & operations_research::MPModelProto_Annotation_TargetType_Name ( MPModelProto_Annotation_TargetType value)
inline

Definition at line 238 of file linear_solver.pb.h.

◆ MPModelProto_Annotation_TargetType_Name() [2/2]

template<typename T>
const ::std::string & operations_research::MPModelProto_Annotation_TargetType_Name ( T value)

Definition at line 231 of file linear_solver.pb.h.

◆ MPModelProto_Annotation_TargetType_Parse()

bool operations_research::MPModelProto_Annotation_TargetType_Parse ( ::absl::string_view name,
MPModelProto_Annotation_TargetType *PROTOBUF_NONNULL value )
inline

Definition at line 242 of file linear_solver.pb.h.

◆ MPModelRequest_SolverType_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::MPModelRequest_SolverType_descriptor ( )

Definition at line 1163 of file linear_solver.pb.cc.

◆ MPModelRequest_SolverType_IsValid()

bool operations_research::MPModelRequest_SolverType_IsValid ( int value)
inline

Definition at line 307 of file linear_solver.pb.h.

◆ MPModelRequest_SolverType_Name()

template<typename T>
const ::std::string & operations_research::MPModelRequest_SolverType_Name ( T value)

Definition at line 313 of file linear_solver.pb.h.

◆ MPModelRequest_SolverType_Parse()

bool operations_research::MPModelRequest_SolverType_Parse ( ::absl::string_view name,
MPModelRequest_SolverType *PROTOBUF_NONNULL value )
inline

Definition at line 319 of file linear_solver.pb.h.

◆ MPModelRequestLoggingInfo()

std::string operations_research::MPModelRequestLoggingInfo ( const MPModelRequest & request)

Definition at line 50 of file solve_mp_model.cc.

◆ MPSolverCommonParameters_LPAlgorithmValues_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::MPSolverCommonParameters_LPAlgorithmValues_descriptor ( )

Definition at line 1157 of file linear_solver.pb.cc.

◆ MPSolverCommonParameters_LPAlgorithmValues_IsValid()

bool operations_research::MPSolverCommonParameters_LPAlgorithmValues_IsValid ( int value)
inline

Definition at line 259 of file linear_solver.pb.h.

◆ MPSolverCommonParameters_LPAlgorithmValues_Name() [1/2]

template<>
const ::std::string & operations_research::MPSolverCommonParameters_LPAlgorithmValues_Name ( MPSolverCommonParameters_LPAlgorithmValues value)
inline

Definition at line 272 of file linear_solver.pb.h.

◆ MPSolverCommonParameters_LPAlgorithmValues_Name() [2/2]

template<typename T>
const ::std::string & operations_research::MPSolverCommonParameters_LPAlgorithmValues_Name ( T value)

Definition at line 265 of file linear_solver.pb.h.

◆ MPSolverCommonParameters_LPAlgorithmValues_Parse()

bool operations_research::MPSolverCommonParameters_LPAlgorithmValues_Parse ( ::absl::string_view name,
MPSolverCommonParameters_LPAlgorithmValues *PROTOBUF_NONNULL value )
inline

Definition at line 276 of file linear_solver.pb.h.

◆ MPSolverResponseStatus_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::MPSolverResponseStatus_descriptor ( )

Definition at line 1169 of file linear_solver.pb.cc.

◆ MPSolverResponseStatus_IsValid()

bool operations_research::MPSolverResponseStatus_IsValid ( int value)
inline

Definition at line 346 of file linear_solver.pb.h.

◆ MPSolverResponseStatus_Name()

template<typename T>
const ::std::string & operations_research::MPSolverResponseStatus_Name ( T value)

Definition at line 352 of file linear_solver.pb.h.

◆ MPSolverResponseStatus_Parse()

bool operations_research::MPSolverResponseStatus_Parse ( ::absl::string_view name,
MPSolverResponseStatus *PROTOBUF_NONNULL value )
inline

Definition at line 358 of file linear_solver.pb.h.

◆ MPSolverResponseStatusIsRpcError()

bool operations_research::MPSolverResponseStatusIsRpcError ( MPSolverResponseStatus status)

Definition at line 1787 of file linear_solver.cc.

◆ MPSolverToGlopConstraintStatus()

glop::ConstraintStatus operations_research::MPSolverToGlopConstraintStatus ( MPSolver::BasisStatus s)

Definition at line 112 of file glop_utils.cc.

◆ MPSolverToGlopVariableStatus()

glop::VariableStatus operations_research::MPSolverToGlopVariableStatus ( MPSolver::BasisStatus s)

Definition at line 78 of file glop_utils.cc.

◆ MPSolverToXpressBasisStatus()

int operations_research::MPSolverToXpressBasisStatus ( MPSolver::BasisStatus mpsolver_basis_status)
static

Definition at line 1264 of file xpress_interface.cc.

◆ MPSosConstraint_Type_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::MPSosConstraint_Type_descriptor ( )

Definition at line 1145 of file linear_solver.pb.cc.

◆ MPSosConstraint_Type_IsValid()

bool operations_research::MPSosConstraint_Type_IsValid ( int value)
inline

Definition at line 192 of file linear_solver.pb.h.

◆ MPSosConstraint_Type_Name() [1/2]

template<>
const ::std::string & operations_research::MPSosConstraint_Type_Name ( MPSosConstraint_Type value)
inline

Definition at line 205 of file linear_solver.pb.h.

◆ MPSosConstraint_Type_Name() [2/2]

template<typename T>
const ::std::string & operations_research::MPSosConstraint_Type_Name ( T value)

Definition at line 198 of file linear_solver.pb.h.

◆ MPSosConstraint_Type_Parse()

bool operations_research::MPSosConstraint_Type_Parse ( ::absl::string_view name,
MPSosConstraint_Type *PROTOBUF_NONNULL value )
inline

Definition at line 209 of file linear_solver.pb.h.

◆ MultiDijkstra()

template<class DistanceType, class Graph, class ArcLengthFunctor, class SettledNodeCallbackType>
std::vector< absl::flat_hash_map< int, DistanceAndParentArc< DistanceType > > > operations_research::MultiDijkstra ( const Graph & graph,
ArcLengthFunctor arc_length_functor,
const std::vector< std::vector< int > > & source_sets,
SettledNodeCallbackType settled_node_callback )

Definition at line 126 of file multi_dijkstra.h.

◆ NChooseK()

absl::StatusOr< int64_t > operations_research::NChooseK ( int64_t n,
int64_t k )

Definition at line 142 of file n_choose_k.cc.

◆ NodePathImpliedBy()

template<typename GraphType>
std::vector< typename GraphType::NodeIndex > operations_research::NodePathImpliedBy ( absl::Span< const typename GraphType::ArcIndex > arc_path,
const GraphType & graph )

Definition at line 268 of file dag_shortest_path.h.

◆ NumBitsForZeroTo()

template<typename T>
int operations_research::NumBitsForZeroTo ( T max_value)

Definition at line 253 of file radix_sort.h.

◆ One()

int64_t operations_research::One ( )
inline

This method returns 1.

Definition at line 3439 of file constraint_solver.h.

◆ OneBit32()

uint32_t operations_research::OneBit32 ( int pos)
inline

Definition at line 42 of file bitset.h.

◆ OneBit64()

uint64_t operations_research::OneBit64 ( int pos)
inline

Definition at line 41 of file bitset.h.

◆ OneRange32()

uint32_t operations_research::OneRange32 ( uint32_t s,
uint32_t e )
inline

Definition at line 295 of file bitset.h.

◆ OneRange64()

uint64_t operations_research::OneRange64 ( uint64_t s,
uint64_t e )
inline

Definition at line 288 of file bitset.h.

◆ operator*() [1/2]

LinearExpr operations_research::operator* ( double lhs,
LinearExpr rhs )

Definition at line 168 of file linear_expr.cc.

◆ operator*() [2/2]

LinearExpr operations_research::operator* ( LinearExpr lhs,
double rhs )

Definition at line 160 of file linear_expr.cc.

◆ operator+()

LinearExpr operations_research::operator+ ( LinearExpr lhs,
const LinearExpr & rhs )

Definition at line 152 of file linear_expr.cc.

◆ operator-()

LinearExpr operations_research::operator- ( LinearExpr lhs,
const LinearExpr & rhs )

Definition at line 156 of file linear_expr.cc.

◆ operator/()

LinearExpr operations_research::operator/ ( LinearExpr lhs,
double rhs )

Definition at line 164 of file linear_expr.cc.

◆ operator<<() [1/13]

std::ostream & operations_research::operator<< ( std::ostream & os,
MPSolver::OptimizationProblemType optimization_problem_type )
inline

Definition at line 1001 of file linear_solver.h.

◆ operator<<() [2/13]

std::ostream & operations_research::operator<< ( std::ostream & os,
MPSolver::ResultStatus status )
inline

Definition at line 1007 of file linear_solver.h.

◆ operator<<() [3/13]

template<typename StrongIndexName>
std::ostream & operations_research::operator<< ( std::ostream & os,
StrongIndex< StrongIndexName > arg )

Definition at line 251 of file strong_integers.h.

◆ operator<<() [4/13]

template<typename StrongIntegerName>
std::ostream & operations_research::operator<< ( std::ostream & os,
StrongInt64< StrongIntegerName > arg )

Definition at line 262 of file strong_integers.h.

◆ operator<<() [5/13]

std::ostream & operations_research::operator<< ( std::ostream & out,
const Assignment & assignment )

Definition at line 1021 of file assignment.cc.

◆ operator<<() [6/13]

std::ostream & operations_research::operator<< ( std::ostream & out,
const BaseObject *const o )

Definition at line 2488 of file constraint_solver.cc.

◆ operator<<() [7/13]

std::ostream & operations_research::operator<< ( std::ostream & out,
const ClosedInterval & interval )

Definition at line 120 of file sorted_interval_list.cc.

◆ operator<<() [8/13]

std::ostream & operations_research::operator<< ( std::ostream & out,
const Domain & domain )

Definition at line 129 of file sorted_interval_list.cc.

◆ operator<<() [9/13]

std::ostream & operations_research::operator<< ( std::ostream & out,
const RoundTripDoubleFormat & format )

Definition at line 110 of file fp_roundtrip_conv.cc.

◆ operator<<() [10/13]

std::ostream & operations_research::operator<< ( std::ostream & out,
const Solver *const s )

Definition at line 2483 of file constraint_solver.cc.

◆ operator<<() [11/13]

std::ostream & operations_research::operator<< ( std::ostream & out,
const std::vector< ClosedInterval > & intervals )

Definition at line 124 of file sorted_interval_list.cc.

◆ operator<<() [12/13]

template<class DistanceType>
std::ostream & operations_research::operator<< ( std::ostream & out,
DistanceAndParentArc< DistanceType > distance_and_parent_arc )

Definition at line 116 of file multi_dijkstra.h.

◆ operator<<() [13/13]

std::ostream & operations_research::operator<< ( std::ostream & stream,
const LinearExpr & linear_expr )

Definition at line 147 of file linear_expr.cc.

◆ operator<=()

LinearRange operations_research::operator<= ( const LinearExpr & lhs,
const LinearExpr & rhs )

Definition at line 183 of file linear_expr.cc.

◆ operator==()

LinearRange operations_research::operator== ( const LinearExpr & lhs,
const LinearExpr & rhs )

Definition at line 186 of file linear_expr.cc.

◆ operator>=()

LinearRange operations_research::operator>= ( const LinearExpr & lhs,
const LinearExpr & rhs )

Definition at line 189 of file linear_expr.cc.

◆ optimizermsg()

void XPRS_CC operations_research::optimizermsg ( XPRSprob prob,
void * data,
const char * sMsg,
int nLen,
int nMsgLvl )

Definition at line 2174 of file xpress_interface.cc.

◆ OptionalBoolean_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::OptionalBoolean_descriptor ( )

Definition at line 63 of file optional_boolean.pb.cc.

◆ OptionalBoolean_IsValid()

bool operations_research::OptionalBoolean_IsValid ( int value)
inline

Definition at line 81 of file optional_boolean.pb.h.

◆ OptionalBoolean_Name() [1/2]

template<>
const ::std::string & operations_research::OptionalBoolean_Name ( OptionalBoolean value)
inline

Definition at line 94 of file optional_boolean.pb.h.

◆ OptionalBoolean_Name() [2/2]

template<typename T>
const ::std::string & operations_research::OptionalBoolean_Name ( T value)

Definition at line 87 of file optional_boolean.pb.h.

◆ OptionalBoolean_Parse()

bool operations_research::OptionalBoolean_Parse ( ::absl::string_view name,
OptionalBoolean *PROTOBUF_NONNULL value )
inline

Definition at line 98 of file optional_boolean.pb.h.

◆ OrToolsMajorVersion()

int operations_research::OrToolsMajorVersion ( )

Definition at line 22 of file version.cc.

◆ OrToolsMinorVersion()

int operations_research::OrToolsMinorVersion ( )

Definition at line 24 of file version.cc.

◆ OrToolsPatchVersion()

int operations_research::OrToolsPatchVersion ( )

Definition at line 26 of file version.cc.

◆ OrToolsVersionString()

std::string operations_research::OrToolsVersionString ( )

Definition at line 28 of file version.cc.

◆ ParameterDebugString() [1/2]

template<class P>
std::string operations_research::ParameterDebugString ( P * param)

Support limited to pointers to classes which define DebugString().

Definition at line 545 of file constraint_solveri.h.

◆ ParameterDebugString() [2/2]

template<class P>
std::string operations_research::ParameterDebugString ( P param)

Definition at line 539 of file constraint_solveri.h.

◆ ParseAndSolve()

void operations_research::ParseAndSolve ( const std::string & filename,
absl::string_view solver,
const std::string & params )

Definition at line 43 of file vector_bin_packing_main.cc.

◆ ParseFileFormat()

FileFormat operations_research::ParseFileFormat ( const std::string & format_name)

Definition at line 168 of file set_cover_solve.cc.

◆ ParseSolFile() [1/2]

absl::StatusOr< glop::DenseRow > operations_research::ParseSolFile ( absl::string_view file_name,
const glop::LinearProgram & model )

Definition at line 35 of file sol_reader.cc.

◆ ParseSolFile() [2/2]

absl::StatusOr< MPSolutionResponse > operations_research::ParseSolFile ( absl::string_view file_name,
const MPModelProto & model )

Definition at line 41 of file sol_reader.cc.

◆ ParseSolString() [1/2]

absl::StatusOr< glop::DenseRow > operations_research::ParseSolString ( const std::string & solution,
const glop::LinearProgram & model )

Definition at line 47 of file sol_reader.cc.

◆ ParseSolString() [2/2]

absl::StatusOr< MPSolutionResponse > operations_research::ParseSolString ( const std::string & solution,
const MPModelProto & model )

Definition at line 104 of file sol_reader.cc.

◆ ParseTextProtoForFlag()

bool operations_research::ParseTextProtoForFlag ( const absl::string_view text,
google::protobuf::Message *const message_out,
std::string *const error_out )

Definition at line 82 of file parse_proto.cc.

◆ PdlpSolveProto()

absl::StatusOr< MPSolutionResponse > operations_research::PdlpSolveProto ( LazyMutableCopy< MPModelRequest > request,
const bool relax_integer_variables,
const std::atomic< bool > * interrupt_solve )

Definition at line 36 of file pdlp_proto_solver.cc.

◆ PerturbationStrategy_Value_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::PerturbationStrategy_Value_descriptor ( )

Definition at line 695 of file routing_ils.pb.cc.

◆ PerturbationStrategy_Value_IsValid()

bool operations_research::PerturbationStrategy_Value_IsValid ( int value)
inline

Definition at line 202 of file routing_ils.pb.h.

◆ PerturbationStrategy_Value_Name() [1/2]

template<>
const ::std::string & operations_research::PerturbationStrategy_Value_Name ( PerturbationStrategy_Value value)
inline

Definition at line 215 of file routing_ils.pb.h.

◆ PerturbationStrategy_Value_Name() [2/2]

template<typename T>
const ::std::string & operations_research::PerturbationStrategy_Value_Name ( T value)

Definition at line 208 of file routing_ils.pb.h.

◆ PerturbationStrategy_Value_Parse()

bool operations_research::PerturbationStrategy_Value_Parse ( ::absl::string_view name,
PerturbationStrategy_Value *PROTOBUF_NONNULL value )
inline

Definition at line 219 of file routing_ils.pb.h.

◆ PiecewiseLinearFunctionToSlopeAndYIntercept()

std::vector< SlopeAndYIntercept > operations_research::PiecewiseLinearFunctionToSlopeAndYIntercept ( const FloatSlopePiecewiseLinearFunction & pwl_function,
int index_start,
int index_end )

Definition at line 1496 of file routing_lp_scheduling.cc.

◆ PortableDeleteFile()

absl::Status operations_research::PortableDeleteFile ( absl::string_view file_name)

Definition at line 55 of file file.cc.

◆ PortableFileGetContents()

absl::Status operations_research::PortableFileGetContents ( absl::string_view file_name,
std::string * output )

Definition at line 45 of file file.cc.

◆ PortableFileSetContents()

absl::Status operations_research::PortableFileSetContents ( absl::string_view file_name,
absl::string_view content )

Definition at line 35 of file file.cc.

◆ PosIntDivDown()

int64_t operations_research::PosIntDivDown ( int64_t e,
int64_t v )
inline

Definition at line 4369 of file constraint_solveri.h.

◆ PosIntDivUp()

int64_t operations_research::PosIntDivUp ( int64_t e,
int64_t v )
inline

Definition at line 4364 of file constraint_solveri.h.

◆ printError()

void operations_research::printError ( const XPRSprob & mLp,
int line )

Definition at line 139 of file xpress_interface.cc.

◆ printXpressBanner()

void operations_research::printXpressBanner ( bool error)

Definition at line 228 of file xpress_environment.cc.

◆ ProbablyRunningInsideUnitTest()

bool operations_research::ProbablyRunningInsideUnitTest ( )
inline

Definition at line 22 of file testing_utils.h.

◆ PropagateLightweightVehicleBreaks()

bool operations_research::PropagateLightweightVehicleBreaks ( int path,
DimensionValues & dimension_values,
absl::Span< const std::pair< int64_t, int64_t > > interbreaks )

Definition at line 1584 of file routing_filters.cc.

◆ PropagateTransitAndSpan()

bool operations_research::PropagateTransitAndSpan ( int path,
DimensionValues & dimension_values )

Definition at line 21 of file routing_filter_committables.cc.

◆ ProtobufDebugString()

template<class P>
std::string operations_research::ProtobufDebugString ( const P & message)

Definition at line 31 of file proto_utils.h.

◆ ProtobufParseTextProtoForFlag()

template<typename ProtoType>
bool operations_research::ProtobufParseTextProtoForFlag ( absl::string_view text,
ProtoType * message_out,
std::string * error_out )

Definition at line 103 of file proto_utils.h.

◆ ProtobufShortDebugString()

template<class P>
std::string operations_research::ProtobufShortDebugString ( const P & message)

Definition at line 46 of file proto_utils.h.

◆ ProtobufTextFormatMergeFromString()

template<typename ProtoType>
bool operations_research::ProtobufTextFormatMergeFromString ( absl::string_view proto_text_string,
ProtoType * proto )

Definition at line 79 of file proto_utils.h.

◆ ProtobufTextFormatPrintToStringForFlag() [1/2]

std::string operations_research::ProtobufTextFormatPrintToStringForFlag ( const google::protobuf::Message & proto)

Definition at line 26 of file proto_utils.cc.

◆ ProtobufTextFormatPrintToStringForFlag() [2/2]

std::string operations_research::ProtobufTextFormatPrintToStringForFlag ( const google::protobuf::MessageLite & proto)

Definition at line 39 of file proto_utils.cc.

◆ ProtoEnumToString()

template<typename ProtoEnumType>
std::string operations_research::ProtoEnumToString ( ProtoEnumType enum_value)

Definition at line 63 of file proto_utils.h.

◆ RadixSort()

template<typename T>
void operations_research::RadixSort ( absl::Span< T > values,
int num_bits = sizeof(T) * 8 )

Definition at line 270 of file radix_sort.h.

◆ RadixSortTpl()

template<typename T, int radix_width, int num_passes>
void operations_research::RadixSortTpl ( absl::Span< T > values)

Definition at line 101 of file radix_sort.h.

◆ RangeConvexMinimum() [1/2]

template<class Point, class Value>
std::pair< Point, Value > operations_research::RangeConvexMinimum ( Point begin,
Point end,
absl::FunctionRef< Value(Point)> f )

Definition at line 247 of file binary_search.h.

◆ RangeConvexMinimum() [2/2]

template<class Point, class Value>
std::pair< Point, Value > operations_research::RangeConvexMinimum ( std::pair< Point, Value > current_min,
Point begin,
Point end,
absl::FunctionRef< Value(Point)> f )

Definition at line 280 of file binary_search.h.

◆ RationalApproximation()

Fraction operations_research::RationalApproximation ( const double x,
const double precision )

Definition at line 27 of file rational_approximation.cc.

◆ ReadAllRecordsOrDie() [1/2]

template<typename Proto>
std::vector< Proto > operations_research::ReadAllRecordsOrDie ( absl::string_view filename)

Definition at line 117 of file file_util.h.

◆ ReadAllRecordsOrDie() [2/2]

template<typename Proto>
std::vector< Proto > operations_research::ReadAllRecordsOrDie ( File * file)

Definition at line 121 of file file_util.h.

◆ ReadFileToProto() [1/2]

template<typename Proto>
absl::StatusOr< Proto > operations_research::ReadFileToProto ( absl::string_view filename,
bool allow_partial = false )

Definition at line 51 of file file_util.h.

◆ ReadFileToProto() [2/2]

absl::Status operations_research::ReadFileToProto ( absl::string_view filename,
google::protobuf::Message * proto,
bool allow_partial )

Definition at line 54 of file file_util.cc.

◆ ReadFileToString()

absl::StatusOr< std::string > operations_research::ReadFileToString ( absl::string_view filename)

Definition at line 43 of file file_util.cc.

◆ ReadFimiDat()

SetCoverModel operations_research::ReadFimiDat ( absl::string_view filename)

Definition at line 182 of file set_cover_reader.cc.

◆ ReadModel()

SetCoverModel operations_research::ReadModel ( absl::string_view filename,
FileFormat format )

Definition at line 189 of file set_cover_solve.cc.

◆ ReadOneRecordOrDie()

template<typename Proto>
Proto operations_research::ReadOneRecordOrDie ( absl::string_view filename)

Definition at line 129 of file file_util.h.

◆ ReadOrlibRail()

SetCoverModel operations_research::ReadOrlibRail ( absl::string_view filename)

Definition at line 153 of file set_cover_reader.cc.

◆ ReadOrlibScp()

SetCoverModel operations_research::ReadOrlibScp ( absl::string_view filename)

Definition at line 122 of file set_cover_reader.cc.

◆ readParameter()

bool operations_research::readParameter ( XPRSprob const & prob,
std::string const & name,
std::string const & value )

Definition at line 61 of file xpress_interface.cc.

◆ ReadQapProblemOrDie()

QapProblem operations_research::ReadQapProblemOrDie ( absl::string_view filepath)

Definition at line 30 of file qap_reader.cc.

◆ ReadSetCoverProto()

SetCoverModel operations_research::ReadSetCoverProto ( absl::string_view filename,
bool binary )

Definition at line 242 of file set_cover_reader.cc.

◆ ReadSetCoverSolutionProto()

SubsetBoolVector operations_research::ReadSetCoverSolutionProto ( absl::string_view filename,
bool binary )

Definition at line 370 of file set_cover_reader.cc.

◆ ReadSetCoverSolutionText()

SubsetBoolVector operations_research::ReadSetCoverSolutionText ( absl::string_view filename)

Definition at line 353 of file set_cover_reader.cc.

◆ ReadSolution()

SubsetBoolVector operations_research::ReadSolution ( absl::string_view filename,
FileFormat format )

Definition at line 207 of file set_cover_solve.cc.

◆ RealDebugString()

template<class Container, class Element>
void operations_research::RealDebugString ( const Container & container,
std::string *const out )

Definition at line 613 of file assignment.cc.

◆ RealLoad()

template<class Var, class Element, class Proto, class Container>
void operations_research::RealLoad ( const AssignmentProto & assignment_proto,
Container *const container,
int(AssignmentProto::* GetSize )() const,
const Proto &(AssignmentProto::* GetElem )(int) const )

Definition at line 504 of file assignment.cc.

◆ RealSave()

template<class Var, class Element, class Proto, class Container>
void operations_research::RealSave ( AssignmentProto *const assignment_proto,
const Container & container,
Proto *(AssignmentProto::* Add )() )

Definition at line 577 of file assignment.cc.

◆ RegisterConstraintHandler() [1/2]

template<typename Constraint>
void operations_research::RegisterConstraintHandler ( ScipConstraintHandler< Constraint > * handler,
SCIP * scip )

◆ RegisterConstraintHandler() [2/2]

template<typename ConstraintData>
void operations_research::RegisterConstraintHandler ( ScipConstraintHandler< ConstraintData > * handler,
SCIP * scip )

Definition at line 251 of file scip_callback.h.

◆ RegisterDemon()

void operations_research::RegisterDemon ( Solver *const solver,
Demon *const demon,
DemonProfiler *const monitor )

Definition at line 465 of file demon_profiler.cc.

◆ RelocateAndMakeActive()

LocalSearchOperator * operations_research::RelocateAndMakeActive ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class )

-— RelocateAndMakeActive --—

RelocateAndMakeActive relocates a node and replaces it by an inactive node. The idea is to make room for inactive nodes. Possible neighbor for paths 0 -> 4, 1 -> 2 -> 5 and 3 inactive is: 0 -> 2 -> 4, 1 -> 3 -> 5.

Todo
(user): Naming is close to MakeActiveAndRelocate but this one is correct; rename MakeActiveAndRelocate if it is actually used.

Definition at line 860 of file local_search.cc.

◆ RelocateAndMakeInactive()

LocalSearchOperator * operations_research::RelocateAndMakeInactive ( Solver * solver,
const std::vector< IntVar * > & vars,
const std::vector< IntVar * > & secondary_vars,
std::function< int(int64_t)> start_empty_path_class )

--— RelocateAndMakeInactive --—

RelocateAndMakeInactive relocates a node to a new position and makes the node which was at that position inactive. Possible neighbors for paths 0 -> 2 -> 4, 1 -> 3 -> 5 are: 0 -> 3 -> 4, 1 -> 5 & 2 inactive 0 -> 4, 1 -> 2 -> 5 & 3 inactive

Definition at line 1066 of file local_search.cc.

◆ RestoreBoolValue()

void operations_research::RestoreBoolValue ( IntVar * var)
extern

Definition at line 6406 of file expressions.cc.

◆ ReturnCodeString()

std::string operations_research::ReturnCodeString ( const int rc)

Definition at line 67 of file glpk_formatters.cc.

◆ RootedTreeFromGraph() [1/2]

template<typename Graph>
absl::StatusOr< RootedTree< typename Graph::NodeIndex > > operations_research::RootedTreeFromGraph ( const typename Graph::NodeIndex root,
const Graph & graph,
std::vector< typename Graph::NodeIndex > *const topological_order,
std::vector< typename Graph::NodeIndex > *const depths )

Definition at line 746 of file rooted_tree.h.

◆ RootedTreeFromGraph() [2/2]

template<typename Graph>
absl::StatusOr< RootedTree< typename Graph::NodeType > > operations_research::RootedTreeFromGraph ( typename Graph::NodeType root,
const Graph & graph,
std::vector< typename Graph::NodeType > * topological_order = nullptr,
std::vector< typename Graph::NodeType > * depths = nullptr )

◆ RoutingSearchParameters_SchedulingSolver_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::RoutingSearchParameters_SchedulingSolver_descriptor ( )

Definition at line 653 of file routing_parameters.pb.cc.

◆ RoutingSearchParameters_SchedulingSolver_IsValid()

bool operations_research::RoutingSearchParameters_SchedulingSolver_IsValid ( int value)
inline

Definition at line 107 of file routing_parameters.pb.h.

◆ RoutingSearchParameters_SchedulingSolver_Name() [1/2]

template<>
const ::std::string & operations_research::RoutingSearchParameters_SchedulingSolver_Name ( RoutingSearchParameters_SchedulingSolver value)
inline

Definition at line 120 of file routing_parameters.pb.h.

◆ RoutingSearchParameters_SchedulingSolver_Name() [2/2]

template<typename T>
const ::std::string & operations_research::RoutingSearchParameters_SchedulingSolver_Name ( T value)

Definition at line 113 of file routing_parameters.pb.h.

◆ RoutingSearchParameters_SchedulingSolver_Parse()

bool operations_research::RoutingSearchParameters_SchedulingSolver_Parse ( ::absl::string_view name,
RoutingSearchParameters_SchedulingSolver *PROTOBUF_NONNULL value )
inline

Definition at line 124 of file routing_parameters.pb.h.

◆ RoutingSearchStatus_Value_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::RoutingSearchStatus_Value_descriptor ( )

Definition at line 165 of file routing_enums.pb.cc.

◆ RoutingSearchStatus_Value_IsValid()

bool operations_research::RoutingSearchStatus_Value_IsValid ( int value)
inline

Definition at line 205 of file routing_enums.pb.h.

◆ RoutingSearchStatus_Value_Name() [1/2]

template<>
const ::std::string & operations_research::RoutingSearchStatus_Value_Name ( RoutingSearchStatus_Value value)
inline

Definition at line 218 of file routing_enums.pb.h.

◆ RoutingSearchStatus_Value_Name() [2/2]

template<typename T>
const ::std::string & operations_research::RoutingSearchStatus_Value_Name ( T value)

Definition at line 211 of file routing_enums.pb.h.

◆ RoutingSearchStatus_Value_Parse()

bool operations_research::RoutingSearchStatus_Value_Parse ( ::absl::string_view name,
RoutingSearchStatus_Value *PROTOBUF_NONNULL value )
inline

Definition at line 222 of file routing_enums.pb.h.

◆ RuinCompositionStrategy_Value_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::RuinCompositionStrategy_Value_descriptor ( )

Definition at line 689 of file routing_ils.pb.cc.

◆ RuinCompositionStrategy_Value_IsValid()

bool operations_research::RuinCompositionStrategy_Value_IsValid ( int value)
inline

Definition at line 166 of file routing_ils.pb.h.

◆ RuinCompositionStrategy_Value_Name() [1/2]

template<>
const ::std::string & operations_research::RuinCompositionStrategy_Value_Name ( RuinCompositionStrategy_Value value)
inline

Definition at line 179 of file routing_ils.pb.h.

◆ RuinCompositionStrategy_Value_Name() [2/2]

template<typename T>
const ::std::string & operations_research::RuinCompositionStrategy_Value_Name ( T value)

Definition at line 172 of file routing_ils.pb.h.

◆ RuinCompositionStrategy_Value_Parse()

bool operations_research::RuinCompositionStrategy_Value_Parse ( ::absl::string_view name,
RuinCompositionStrategy_Value *PROTOBUF_NONNULL value )
inline

Definition at line 183 of file routing_ils.pb.h.

◆ Run()

void operations_research::Run ( )

Definition at line 680 of file set_cover_solve.cc.

◆ RunGreedy()

SetCoverInvariant operations_research::RunGreedy ( SetCoverModel * model)

Definition at line 271 of file set_cover_solve.cc.

◆ RunLazyElementDegree()

SetCoverInvariant operations_research::RunLazyElementDegree ( SetCoverModel * model)

Definition at line 262 of file set_cover_solve.cc.

◆ RunSeparation()

ScipSeparationResult operations_research::RunSeparation ( internal::ScipCallbackRunner * runner,
const ScipConstraintHandlerContext & context,
absl::Span< SCIP_CONS * > constraints,
bool is_integral )

Definition at line 116 of file scip_callback.cc.

◆ RunTimeInMicroseconds()

int64_t operations_research::RunTimeInMicroseconds ( const SetCoverSolutionGenerator & gen)

Definition at line 109 of file set_cover_solve.cc.

◆ RunTimeInNanoseconds()

int64_t operations_research::RunTimeInNanoseconds ( const SetCoverSolutionGenerator & gen)

Definition at line 113 of file set_cover_solve.cc.

◆ SafeAddInto()

template<typename IntegerType>
bool operations_research::SafeAddInto ( IntegerType a,
IntegerType * b )

Definition at line 133 of file saturated_arithmetic.h.

◆ SafeProtoConstDownCast()

template<class Proto>
absl::StatusOr< const Proto * > operations_research::SafeProtoConstDownCast ( const google::protobuf::Message * proto)

Definition at line 83 of file proto_tools.h.

◆ SafeProtoDownCast()

template<class Proto>
absl::StatusOr< Proto * > operations_research::SafeProtoDownCast ( google::protobuf::Message * proto)

Definition at line 70 of file proto_tools.h.

◆ SatSolveProto()

MPSolutionResponse operations_research::SatSolveProto ( LazyMutableCopy< MPModelRequest > request,
std::atomic< bool > * interrupt_solve,
std::function< void(const std::string &)> logging_callback,
std::function< void(const MPSolution &)> solution_callback,
std::function< void(const double)> best_bound_callback )

Definition at line 423 of file sat_proto_solver.cc.

◆ SatSolveProtoInternal()

MPSolutionResponse operations_research::SatSolveProtoInternal ( LazyMutableCopy< MPModelRequest > request,
sat::Model * sat_model,
sat::CpSolverResponse * cp_response,
std::function< void(const MPSolution &)> solution_callback )

Definition at line 160 of file sat_proto_solver.cc.

◆ SatSolverVersion()

std::string operations_research::SatSolverVersion ( )

Definition at line 501 of file sat_proto_solver.cc.

◆ ScipSolveProto()

absl::StatusOr< MPSolutionResponse > operations_research::ScipSolveProto ( LazyMutableCopy< MPModelRequest > request)

Definition at line 719 of file scip_proto_solver.cc.

◆ SetAssignmentFromAssignment()

void operations_research::SetAssignmentFromAssignment ( Assignment * target_assignment,
const std::vector< IntVar * > & target_vars,
const Assignment * source_assignment,
const std::vector< IntVar * > & source_vars )

NOLINT.

Given a "source_assignment", clears the "target_assignment" and adds all IntVars in "target_vars", with the values of the variables set according to the corresponding values of "source_vars" in "source_assignment". source_vars and target_vars must have the same number of elements. The source and target assignments can belong to different Solvers.

Definition at line 947 of file assignment.cc.

◆ SetBit32()

void operations_research::SetBit32 ( uint32_t *const bitset,
uint32_t pos )
inline

Definition at line 360 of file bitset.h.

◆ SetBit64()

void operations_research::SetBit64 ( uint64_t *const bitset,
uint64_t pos )
inline

Definition at line 357 of file bitset.h.

◆ SetCoverSolutionResponse_Status_descriptor()

OR_PROTO_DLLconst::google::protobuf::EnumDescriptor *PROTOBUF_NONNULL operations_research::SetCoverSolutionResponse_Status_descriptor ( )

Definition at line 217 of file set_cover.pb.cc.

◆ SetCoverSolutionResponse_Status_IsValid()

bool operations_research::SetCoverSolutionResponse_Status_IsValid ( int value)
inline

Definition at line 99 of file set_cover.pb.h.

◆ SetCoverSolutionResponse_Status_Name() [1/2]

template<>
const ::std::string & operations_research::SetCoverSolutionResponse_Status_Name ( SetCoverSolutionResponse_Status value)
inline

Definition at line 112 of file set_cover.pb.h.

◆ SetCoverSolutionResponse_Status_Name() [2/2]

template<typename T>
const ::std::string & operations_research::SetCoverSolutionResponse_Status_Name ( T value)

Definition at line 105 of file set_cover.pb.h.

◆ SetCoverSolutionResponse_Status_Parse()

bool operations_research::SetCoverSolutionResponse_Status_Parse ( ::absl::string_view name,
SetCoverSolutionResponse_Status *PROTOBUF_NONNULL value )
inline

Definition at line 116 of file set_cover.pb.h.

◆ SetIsEqual()

Constraint * operations_research::SetIsEqual ( IntVar *const var,
absl::Span< const int64_t > values,
const std::vector< IntVar * > & vars )

Definition at line 6391 of file expressions.cc.

◆ SetIsGreaterOrEqual()

Constraint * operations_research::SetIsGreaterOrEqual ( IntVar *const var,
absl::Span< const int64_t > values,
const std::vector< IntVar * > & vars )

Definition at line 6398 of file expressions.cc.

◆ setobjoffset()

int operations_research::setobjoffset ( const XPRSprob & mLp,
double value )

Definition at line 184 of file xpress_interface.cc.

◆ SetSolverSpecificParameters() [1/2]

absl::Status operations_research::SetSolverSpecificParameters ( absl::string_view parameters,
GRBenv * gurobi )

Definition at line 233 of file gurobi_proto_solver.cc.

◆ SetSolverSpecificParameters() [2/2]

absl::Status operations_research::SetSolverSpecificParameters ( const std::string & parameters,
Highs & highs )

Definition at line 307 of file highs_proto_solver.cc.

◆ SetupGlpkEnvAutomaticDeletion()

void operations_research::SetupGlpkEnvAutomaticDeletion ( )

Definition at line 35 of file glpk_env_deleter.cc.

◆ ShortestPathsOnDag()

PathWithLength operations_research::ShortestPathsOnDag ( const int num_nodes,
absl::Span< const ArcWithLength > arcs_with_length,
const int source,
const int destination )

Definition at line 83 of file dag_shortest_path.cc.

◆ SimpleOneToOneShortestPath()

template<typename NodeIndex, typename DistanceType>
std::pair< DistanceType, std::vector< NodeIndex > > operations_research::SimpleOneToOneShortestPath ( NodeIndex source,
NodeIndex destination,
absl::Span< const NodeIndex > tails,
absl::Span< const NodeIndex > heads,
absl::Span< const DistanceType > lengths,
DistanceType limit = std::numeric_limits<DistanceType>::max() )

Definition at line 672 of file bounded_dijkstra.h.

◆ SlopeAndYInterceptToConvexityRegions()

std::vector< bool > operations_research::SlopeAndYInterceptToConvexityRegions ( absl::Span< const SlopeAndYIntercept > slope_and_y_intercept)

Definition at line 1514 of file routing_lp_scheduling.cc.

◆ solution()

Select next search node to expand Select next item_i to add this new search node to the search Generate a new search node where item_i is not in the knapsack Check validity of this new partial operations_research::solution ( using propagators)

◆ SolutionsAlmostEqual()

bool operations_research::SolutionsAlmostEqual ( const GScipSolution & left,
const GScipSolution & right,
const double tolerance )

Definition at line 49 of file gscip_testing.cc.

◆ SolutionStatusString()

std::string operations_research::SolutionStatusString ( const int status)

Definition at line 31 of file glpk_formatters.cc.

◆ SolutionToString()

std::string operations_research::SolutionToString ( const GScipSolution & solution)

Definition at line 39 of file gscip_testing.cc.

◆ SolveFromAssignmentWithAlternativeSolvers()

const Assignment * operations_research::SolveFromAssignmentWithAlternativeSolvers ( const Assignment * assignment,
RoutingModel * primary_model,
const std::vector< RoutingModel * > & alternative_models,
const RoutingSearchParameters & parameters,
int max_non_improving_iterations )

Definition at line 148 of file routing_search.cc.

◆ SolveFromAssignmentWithAlternativeSolversAndParameters()

const Assignment * operations_research::SolveFromAssignmentWithAlternativeSolversAndParameters ( const Assignment * assignment,
RoutingModel * primary_model,
const RoutingSearchParameters & primary_parameters,
const std::vector< RoutingModel * > & alternative_models,
const std::vector< RoutingSearchParameters > & alternative_parameters,
int max_non_improving_iterations )

Definition at line 158 of file routing_search.cc.

◆ SolveMaxFlow()

template<typename GraphType>
void operations_research::SolveMaxFlow ( const FlowModelProto & flow_model,
double * loading_time,
double * solving_time,
std::function< void(GraphType *graph)> configure_graph_options = nullptr )

Definition at line 234 of file solve_flow_model.cc.

◆ SolveMinCostFlow()

void operations_research::SolveMinCostFlow ( const FlowModelProto & flow_model,
double * loading_time,
double * solving_time )

Definition at line 186 of file solve_flow_model.cc.

◆ SolveModelWithSat()

bool operations_research::SolveModelWithSat ( RoutingModel * model,
RoutingSearchStats * search_stats,
const RoutingSearchParameters & search_parameters,
const operations_research::Assignment * initial_solution,
operations_research::Assignment * solution )

Attempts to solve the model using the cp-sat solver. As of 5/2019, will solve the TSP corresponding to the model if it has a single vehicle. Therefore the resulting solution might not actually be feasible. Will return false if a solution could not be found.

Definition at line 1173 of file routing_sat.cc.

◆ SolveMPModel()

MPSolutionResponse operations_research::SolveMPModel ( LazyMutableCopy< MPModelRequest > request,
const SolveInterrupter *absl_nullable interrupter = nullptr )

Solves the model encoded by a MPModelRequest protocol buffer and returns the solution encoded as a MPSolutionResponse.

LazyMutableCopy<> accept both 'const MPModelRequest&' and 'MPModelRequest&&' prefer to call this with the std::move() version if you no longer need the request. It will allows to reclaim the request memory as soon as it is converted to one of the solver internal data representation.

If interrupter is non-null, one can call interrupter->Interrupt() to stop the solver earlier. Interruption is only supported if SolverTypeSupportsInterruption() returns true for the requested solver. Passing a non-null pointer with any other solver type immediately returns an MPSOLVER_INCOMPATIBLE_OPTIONS error.

Definition at line 30 of file solve_mp_model.cc.

◆ SolverTypeIsMip() [1/2]

bool operations_research::SolverTypeIsMip ( MPModelRequest::SolverType solver_type)

Definition at line 85 of file linear_solver.cc.

◆ SolverTypeIsMip() [2/2]

bool operations_research::SolverTypeIsMip ( MPSolver::OptimizationProblemType solver_type)
inline

Definition at line 994 of file linear_solver.h.

◆ SolverTypeSupportsInterruption()

bool operations_research::SolverTypeSupportsInterruption ( const MPModelRequest::SolverType solver)

Definition at line 46 of file solve_mp_model.cc.

◆ SolveWithAlternativeSolvers()

const Assignment * operations_research::SolveWithAlternativeSolvers ( RoutingModel * primary_model,
const std::vector< RoutingModel * > & alternative_models,
const RoutingSearchParameters & parameters,
int max_non_improving_iterations )

Definition at line 138 of file routing_search.cc.

◆ splitMyString()

template<class Container>
void operations_research::splitMyString ( const std::string & str,
Container & cont,
char delim = ' ' )

Definition at line 2103 of file xpress_interface.cc.

◆ stringToCharPtr()

bool operations_research::stringToCharPtr ( const std::string & var,
const char ** out )

Definition at line 2111 of file xpress_interface.cc.

◆ StringToProto()

absl::Status operations_research::StringToProto ( absl::string_view data,
google::protobuf::Message * proto,
bool allow_partial )

Definition at line 63 of file file_util.cc.

◆ STRONG_TYPE_ARITHMETIC_OP() [1/11]

operations_research::STRONG_TYPE_ARITHMETIC_OP ( StrongIndex ,
int ,
%  )

◆ STRONG_TYPE_ARITHMETIC_OP() [2/11]

operations_research::STRONG_TYPE_ARITHMETIC_OP ( StrongIndex ,
int ,
*  )

◆ STRONG_TYPE_ARITHMETIC_OP() [3/11]

operations_research::STRONG_TYPE_ARITHMETIC_OP ( StrongIndex ,
int ,
-  )

◆ STRONG_TYPE_ARITHMETIC_OP() [4/11]

operations_research::STRONG_TYPE_ARITHMETIC_OP ( StrongIndex ,
int ,
+  )

◆ STRONG_TYPE_ARITHMETIC_OP() [5/11]

operations_research::STRONG_TYPE_ARITHMETIC_OP ( StrongInt64 ,
int64_t ,
%  )

◆ STRONG_TYPE_ARITHMETIC_OP() [6/11]

operations_research::STRONG_TYPE_ARITHMETIC_OP ( StrongInt64 ,
int64_t ,
*  )

◆ STRONG_TYPE_ARITHMETIC_OP() [7/11]

operations_research::STRONG_TYPE_ARITHMETIC_OP ( StrongInt64 ,
int64_t ,
-  )

◆ STRONG_TYPE_ARITHMETIC_OP() [8/11]

operations_research::STRONG_TYPE_ARITHMETIC_OP ( StrongInt64 ,
int64_t  )

◆ STRONG_TYPE_ARITHMETIC_OP() [9/11]

operations_research::STRONG_TYPE_ARITHMETIC_OP ( StrongInt64 ,
int64_t ,
+  )

◆ STRONG_TYPE_ARITHMETIC_OP() [10/11]

operations_research::STRONG_TYPE_ARITHMETIC_OP ( StrongInt64 ,
int64_t ,
/  )

◆ STRONG_TYPE_ARITHMETIC_OP() [11/11]

operations_research::STRONG_TYPE_ARITHMETIC_OP ( StrongInt64 ,
int64_t ,
<<  )

◆ STRONG_TYPE_COMPARISON_OP() [1/8]

operations_research::STRONG_TYPE_COMPARISON_OP ( StrongIndex ,
int ,
!  )

◆ STRONG_TYPE_COMPARISON_OP() [2/8]

operations_research::STRONG_TYPE_COMPARISON_OP ( StrongIndex ,
int ,
>=  )

◆ STRONG_TYPE_COMPARISON_OP() [3/8]

operations_research::STRONG_TYPE_COMPARISON_OP ( StrongIndex ,
int ,
<=  )

◆ STRONG_TYPE_COMPARISON_OP() [4/8]

operations_research::STRONG_TYPE_COMPARISON_OP ( StrongIndex ,
int  )

◆ STRONG_TYPE_COMPARISON_OP() [5/8]

operations_research::STRONG_TYPE_COMPARISON_OP ( StrongInt64 ,
int64_t ,
!  )

◆ STRONG_TYPE_COMPARISON_OP() [6/8]

operations_research::STRONG_TYPE_COMPARISON_OP ( StrongInt64 ,
int64_t ,
>=  )

◆ STRONG_TYPE_COMPARISON_OP() [7/8]

operations_research::STRONG_TYPE_COMPARISON_OP ( StrongInt64 ,
int64_t ,
<=  )

◆ STRONG_TYPE_COMPARISON_OP() [8/8]

operations_research::STRONG_TYPE_COMPARISON_OP ( StrongInt64 ,
int64_t  )

◆ strtoint32()

int32_t operations_research::strtoint32 ( absl::string_view word)

Definition at line 26 of file strtoint.cc.

◆ strtoint64()

int64_t operations_research::strtoint64 ( absl::string_view word)

Definition at line 32 of file strtoint.cc.

◆ SubHadOverflow()

bool operations_research::SubHadOverflow ( int64_t x,
int64_t y,
int64_t diff )
inline

Definition at line 107 of file saturated_arithmetic.h.

◆ SubOverflows()

int64_t operations_research::SubOverflows ( int64_t x,
int64_t y )
inline

Definition at line 126 of file saturated_arithmetic.h.

◆ SumOfKMaxValueInDomain()

int64_t operations_research::SumOfKMaxValueInDomain ( const Domain & domain,
int k )

Definition at line 845 of file sorted_interval_list.cc.

◆ SumOfKMinValueInDomain()

int64_t operations_research::SumOfKMinValueInDomain ( const Domain & domain,
int k )

Definition at line 831 of file sorted_interval_list.cc.

◆ TestGScipParameters()

GScipParameters operations_research::TestGScipParameters ( )

Definition at line 33 of file gscip_testing.cc.

◆ ToInt64Vector()

std::vector< int64_t > operations_research::ToInt64Vector ( const std::vector< int > & input)

Definition at line 824 of file utilities.cc.

◆ TopologicalOrderIsValid() [1/2]

template<class GraphType>
absl::Status operations_research::TopologicalOrderIsValid ( const GraphType & graph,
absl::Span< const typename GraphType::NodeIndex > topological_order )

Definition at line 292 of file dag_shortest_path.h.

◆ TopologicalOrderIsValid() [2/2]

template<class GraphType, typename ArcLengths>
absl::Status operations_research::TopologicalOrderIsValid ( const GraphType & graph,
absl::Span< const typename GraphType::NodeIndex > topological_order )

◆ ToString() [1/2]

std::string operations_research::ToString ( MPCallbackEvent event)

Definition at line 23 of file linear_solver_callback.cc.

◆ ToString() [2/2]

absl::string_view operations_research::ToString ( MPSolver::OptimizationProblemType optimization_problem_type)

Definition at line 494 of file linear_solver.cc.

◆ TruncateAndQuoteGLPKName()

std::string operations_research::TruncateAndQuoteGLPKName ( const std::string_view original_name)

Definition at line 112 of file glpk_formatters.cc.

◆ TwoBitsFromPos64()

uint64_t operations_research::TwoBitsFromPos64 ( uint64_t pos)
inline

Definition at line 405 of file bitset.h.

◆ TwosComplementAddition()

int64_t operations_research::TwosComplementAddition ( int64_t x,
int64_t y )
inline

Definition at line 82 of file saturated_arithmetic.h.

◆ TwosComplementSubtraction()

int64_t operations_research::TwosComplementSubtraction ( int64_t x,
int64_t y )
inline

Definition at line 89 of file saturated_arithmetic.h.

◆ UnsafeLeastSignificantBitPosition32()

int32_t operations_research::UnsafeLeastSignificantBitPosition32 ( const uint32_t * bitset,
uint32_t start,
uint32_t end )

◆ UnsafeLeastSignificantBitPosition64()

int64_t operations_research::UnsafeLeastSignificantBitPosition64 ( const uint64_t * bitset,
uint64_t start,
uint64_t end )

◆ UnsafeMostSignificantBitPosition32()

int32_t operations_research::UnsafeMostSignificantBitPosition32 ( const uint32_t * bitset,
uint32_t start,
uint32_t end )

◆ UnsafeMostSignificantBitPosition64()

int64_t operations_research::UnsafeMostSignificantBitPosition64 ( const uint64_t * bitset,
uint64_t start,
uint64_t end )

◆ VariablesToString()

std::string operations_research::VariablesToString ( absl::flat_hash_map< std::string, std::pair< sat::IntegerVariableProto, int > > & variables,
absl::flat_hash_map< std::string, std::vector< int > > & variable_instances,
absl::flat_hash_map< std::string, absl::flat_hash_set< std::string > > & variable_childs,
const sat::CpSolverResponse & response_,
absl::string_view variable,
std::string prefix = "" )

Definition at line 3476 of file routing_lp_scheduling.cc.

◆ VariableToString()

std::string operations_research::VariableToString ( std::pair< sat::IntegerVariableProto, int > & variable_pair,
const sat::CpSolverResponse & response_ )

Definition at line 3429 of file routing_lp_scheduling.cc.

◆ VectorSum()

float operations_research::VectorSum ( absl::Span< const float > values)
inline

Definition at line 37 of file vector_sum.h.

◆ WriteModel()

void operations_research::WriteModel ( const SetCoverModel & model,
const std::string & filename,
FileFormat format )

Definition at line 221 of file set_cover_solve.cc.

◆ WriteModelToMpsFile()

absl::Status operations_research::WriteModelToMpsFile ( absl::string_view filename,
const MPModelProto & model,
const MPModelExportOptions & options = MPModelExportOptions() )

Write the current model (variables, constraints, objective) to a file in MPS file format, using the "free" MPS format.

See ExportModelAsMpsFormat().

Definition at line 254 of file model_exporter.cc.

◆ WriteOrlibRail()

void operations_research::WriteOrlibRail ( const SetCoverModel & model,
absl::string_view filename )

Definition at line 322 of file set_cover_reader.cc.

◆ WriteOrlibScp()

void operations_research::WriteOrlibScp ( const SetCoverModel & model,
absl::string_view filename )

Definition at line 297 of file set_cover_reader.cc.

◆ WriteProtoToFile()

absl::Status operations_research::WriteProtoToFile ( absl::string_view filename,
const google::protobuf::Message & proto,
ProtoWriteFormat proto_write_format,
bool gzipped,
bool append_extension_to_file_name )

Definition at line 143 of file file_util.cc.

◆ WriteRecordsOrDie()

template<typename Proto>
void operations_research::WriteRecordsOrDie ( absl::string_view filename,
const std::vector< Proto > & protos )

Definition at line 138 of file file_util.h.

◆ WriteSetCoverProto()

void operations_research::WriteSetCoverProto ( const SetCoverModel & model,
absl::string_view filename,
bool binary )

Definition at line 343 of file set_cover_reader.cc.

◆ WriteSetCoverSolutionProto()

void operations_research::WriteSetCoverSolutionProto ( const SetCoverModel & model,
const SubsetBoolVector & solution,
absl::string_view filename,
bool binary )

Definition at line 413 of file set_cover_reader.cc.

◆ WriteSetCoverSolutionText()

void operations_research::WriteSetCoverSolutionText ( const SetCoverModel & model,
const SubsetBoolVector & solution,
absl::string_view filename )

Definition at line 388 of file set_cover_reader.cc.

◆ WriteSolution()

void operations_research::WriteSolution ( const SetCoverModel & model,
const SubsetBoolVector & solution,
absl::string_view filename,
FileFormat format )

Definition at line 243 of file set_cover_solve.cc.

◆ XpressBasisStatusesFrom()

std::vector< int > operations_research::XpressBasisStatusesFrom ( const std::vector< MPSolver::BasisStatus > & statuses)

Definition at line 1718 of file xpress_interface.cc.

◆ XpressDynamicLibraryPotentialPaths()

std::vector< std::string > operations_research::XpressDynamicLibraryPotentialPaths ( )

Definition at line 239 of file xpress_environment.cc.

◆ XpressIntSolCallbackImpl()

void XPRS_CC operations_research::XpressIntSolCallbackImpl ( XPRSprob cbprob,
void * cbdata )

Definition at line 2223 of file xpress_interface.cc.

◆ XpressIsCorrectlyInstalled()

bool operations_research::XpressIsCorrectlyInstalled ( )

Definition at line 432 of file xpress_environment.cc.

◆ XpressToMPSolverBasisStatus()

MPSolver::BasisStatus operations_research::XpressToMPSolverBasisStatus ( int xpress_basis_status)
static

Definition at line 1247 of file xpress_interface.cc.

◆ YenKShortestPaths()

template<class GraphType>
KShortestPaths< GraphType > operations_research::YenKShortestPaths ( const GraphType & graph,
const std::vector< PathDistance > & arc_lengths,
typename GraphType::NodeIndex source,
typename GraphType::NodeIndex destination,
unsigned k )

Definition at line 290 of file k_shortest_paths.h.

◆ Zero()

int64_t operations_research::Zero ( )
inline

NOLINT.

This method returns 0. It is useful when 0 can be cast either as a pointer or as an integer value and thus lead to an ambiguous function call.

Definition at line 3436 of file constraint_solver.h.

Variable Documentation

◆ _AbsencesBasedAcceptanceStrategy_default_instance_

OR_PROTO_DLL AbsencesBasedAcceptanceStrategyDefaultTypeInternal operations_research::_AbsencesBasedAcceptanceStrategy_default_instance_

Definition at line 265 of file routing_ils.pb.cc.

◆ _AcceptanceStrategy_default_instance_

OR_PROTO_DLL AcceptanceStrategyDefaultTypeInternal operations_research::_AcceptanceStrategy_default_instance_

Definition at line 343 of file routing_ils.pb.cc.

◆ _AllNodesPerformedAcceptanceStrategy_default_instance_

OR_PROTO_DLL AllNodesPerformedAcceptanceStrategyDefaultTypeInternal operations_research::_AllNodesPerformedAcceptanceStrategy_default_instance_

Definition at line 240 of file routing_ils.pb.cc.

◆ _AssignmentProto_default_instance_

OR_PROTO_DLL AssignmentProtoDefaultTypeInternal operations_research::_AssignmentProto_default_instance_

Definition at line 185 of file assignment.pb.cc.

◆ _CapacityConstraintProto_CapacityTerm_default_instance_

OR_PROTO_DLL CapacityConstraintProto_CapacityTermDefaultTypeInternal operations_research::_CapacityConstraintProto_CapacityTerm_default_instance_

Definition at line 79 of file capacity.pb.cc.

◆ _CapacityConstraintProto_CapacityTerm_ElementWeightPair_default_instance_

OR_PROTO_DLL CapacityConstraintProto_CapacityTerm_ElementWeightPairDefaultTypeInternal operations_research::_CapacityConstraintProto_CapacityTerm_ElementWeightPair_default_instance_

Definition at line 53 of file capacity.pb.cc.

◆ _CapacityConstraintProto_default_instance_

OR_PROTO_DLL CapacityConstraintProtoDefaultTypeInternal operations_research::_CapacityConstraintProto_default_instance_

Definition at line 106 of file capacity.pb.cc.

◆ _ClassAssignment_default_instance_

OR_PROTO_DLL ClassAssignmentDefaultTypeInternal operations_research::_ClassAssignment_default_instance_

Definition at line 209 of file course_scheduling.pb.cc.

◆ _ConstraintRuns_default_instance_

OR_PROTO_DLL ConstraintRunsDefaultTypeInternal operations_research::_ConstraintRuns_default_instance_

Definition at line 92 of file demon_profiler.pb.cc.

◆ _ConstraintSolverParameters_default_instance_

OR_PROTO_DLL ConstraintSolverParametersDefaultTypeInternal operations_research::_ConstraintSolverParameters_default_instance_

Definition at line 80 of file solver_parameters.pb.cc.

◆ _ConstraintSolverStatistics_default_instance_

OR_PROTO_DLL ConstraintSolverStatisticsDefaultTypeInternal operations_research::_ConstraintSolverStatistics_default_instance_

Definition at line 178 of file search_stats.pb.cc.

◆ _CoolingScheduleStrategy_default_instance_

OR_PROTO_DLL CoolingScheduleStrategyDefaultTypeInternal operations_research::_CoolingScheduleStrategy_default_instance_

Definition at line 222 of file routing_ils.pb.cc.

◆ _Course_default_instance_

OR_PROTO_DLL CourseDefaultTypeInternal operations_research::_Course_default_instance_

Definition at line 179 of file course_scheduling.pb.cc.

◆ _CourseSchedulingModel_default_instance_

OR_PROTO_DLL CourseSchedulingModelDefaultTypeInternal operations_research::_CourseSchedulingModel_default_instance_

Definition at line 272 of file course_scheduling.pb.cc.

◆ _CourseSchedulingResult_default_instance_

OR_PROTO_DLL CourseSchedulingResultDefaultTypeInternal operations_research::_CourseSchedulingResult_default_instance_

Definition at line 239 of file course_scheduling.pb.cc.

◆ _DemonRuns_default_instance_

OR_PROTO_DLL DemonRunsDefaultTypeInternal operations_research::_DemonRuns_default_instance_

Definition at line 59 of file demon_profiler.pb.cc.

◆ _FirstSolutionStrategy_default_instance_

OR_PROTO_DLL FirstSolutionStrategyDefaultTypeInternal operations_research::_FirstSolutionStrategy_default_instance_

Definition at line 81 of file routing_enums.pb.cc.

◆ _FlowArcProto_default_instance_

OR_PROTO_DLL FlowArcProtoDefaultTypeInternal operations_research::_FlowArcProto_default_instance_

Definition at line 81 of file flow_problem.pb.cc.

◆ _FlowModelProto_default_instance_

OR_PROTO_DLL FlowModelProtoDefaultTypeInternal operations_research::_FlowModelProto_default_instance_

Definition at line 108 of file flow_problem.pb.cc.

◆ _FlowNodeProto_default_instance_

OR_PROTO_DLL FlowNodeProtoDefaultTypeInternal operations_research::_FlowNodeProto_default_instance_

Definition at line 53 of file flow_problem.pb.cc.

◆ _GlobalCheapestInsertionParameters_default_instance_

OR_PROTO_DLL GlobalCheapestInsertionParametersDefaultTypeInternal operations_research::_GlobalCheapestInsertionParameters_default_instance_

Definition at line 111 of file routing_heuristic_parameters.pb.cc.

◆ _GreedyDescentAcceptanceStrategy_default_instance_

OR_PROTO_DLL GreedyDescentAcceptanceStrategyDefaultTypeInternal operations_research::_GreedyDescentAcceptanceStrategy_default_instance_

Definition at line 204 of file routing_ils.pb.cc.

◆ _GScipOutput_default_instance_

OR_PROTO_DLL GScipOutputDefaultTypeInternal operations_research::_GScipOutput_default_instance_

Definition at line 246 of file gscip.pb.cc.

◆ _GScipParameters_BoolParamsEntry_DoNotUse_default_instance_

OR_PROTO_DLL GScipParameters_BoolParamsEntry_DoNotUseDefaultTypeInternal operations_research::_GScipParameters_BoolParamsEntry_DoNotUse_default_instance_

Definition at line 169 of file gscip.pb.cc.

◆ _GScipParameters_CharParamsEntry_DoNotUse_default_instance_

OR_PROTO_DLL GScipParameters_CharParamsEntry_DoNotUseDefaultTypeInternal operations_research::_GScipParameters_CharParamsEntry_DoNotUse_default_instance_

Definition at line 151 of file gscip.pb.cc.

◆ _GScipParameters_default_instance_

OR_PROTO_DLL GScipParametersDefaultTypeInternal operations_research::_GScipParameters_default_instance_

Definition at line 217 of file gscip.pb.cc.

◆ _GScipParameters_IntParamsEntry_DoNotUse_default_instance_

OR_PROTO_DLL GScipParameters_IntParamsEntry_DoNotUseDefaultTypeInternal operations_research::_GScipParameters_IntParamsEntry_DoNotUse_default_instance_

Definition at line 133 of file gscip.pb.cc.

◆ _GScipParameters_LongParamsEntry_DoNotUse_default_instance_

OR_PROTO_DLL GScipParameters_LongParamsEntry_DoNotUseDefaultTypeInternal operations_research::_GScipParameters_LongParamsEntry_DoNotUse_default_instance_

Definition at line 115 of file gscip.pb.cc.

◆ _GScipParameters_RealParamsEntry_DoNotUse_default_instance_

OR_PROTO_DLL GScipParameters_RealParamsEntry_DoNotUseDefaultTypeInternal operations_research::_GScipParameters_RealParamsEntry_DoNotUse_default_instance_

Definition at line 97 of file gscip.pb.cc.

◆ _GScipParameters_StringParamsEntry_DoNotUse_default_instance_

OR_PROTO_DLL GScipParameters_StringParamsEntry_DoNotUseDefaultTypeInternal operations_research::_GScipParameters_StringParamsEntry_DoNotUse_default_instance_

Definition at line 79 of file gscip.pb.cc.

◆ _GScipSolvingStats_default_instance_

OR_PROTO_DLL GScipSolvingStatsDefaultTypeInternal operations_research::_GScipSolvingStats_default_instance_

Definition at line 61 of file gscip.pb.cc.

◆ _Int128_default_instance_

OR_PROTO_DLL Int128DefaultTypeInternal operations_research::_Int128_default_instance_

Definition at line 53 of file int128.pb.cc.

◆ _IntervalVarAssignment_default_instance_

OR_PROTO_DLL IntervalVarAssignmentDefaultTypeInternal operations_research::_IntervalVarAssignment_default_instance_

Definition at line 125 of file assignment.pb.cc.

◆ _IntVarAssignment_default_instance_

OR_PROTO_DLL IntVarAssignmentDefaultTypeInternal operations_research::_IntVarAssignment_default_instance_

Definition at line 155 of file assignment.pb.cc.

◆ _IteratedLocalSearchParameters_default_instance_

OR_PROTO_DLL IteratedLocalSearchParametersDefaultTypeInternal operations_research::_IteratedLocalSearchParameters_default_instance_

Definition at line 428 of file routing_ils.pb.cc.

◆ _LocalCheapestInsertionParameters_default_instance_

OR_PROTO_DLL LocalCheapestInsertionParametersDefaultTypeInternal operations_research::_LocalCheapestInsertionParameters_default_instance_

Definition at line 82 of file routing_heuristic_parameters.pb.cc.

◆ _LocalSearchMetaheuristic_default_instance_

OR_PROTO_DLL LocalSearchMetaheuristicDefaultTypeInternal operations_research::_LocalSearchMetaheuristic_default_instance_

Definition at line 63 of file routing_enums.pb.cc.

◆ _LocalSearchStatistics_default_instance_

OR_PROTO_DLL LocalSearchStatisticsDefaultTypeInternal operations_research::_LocalSearchStatistics_default_instance_

Definition at line 208 of file search_stats.pb.cc.

◆ _LocalSearchStatistics_FirstSolutionStatistics_default_instance_

OR_PROTO_DLL LocalSearchStatistics_FirstSolutionStatisticsDefaultTypeInternal operations_research::_LocalSearchStatistics_FirstSolutionStatistics_default_instance_

Definition at line 149 of file search_stats.pb.cc.

◆ _LocalSearchStatistics_LocalSearchFilterStatistics_default_instance_

OR_PROTO_DLL LocalSearchStatistics_LocalSearchFilterStatisticsDefaultTypeInternal operations_research::_LocalSearchStatistics_LocalSearchFilterStatistics_default_instance_

Definition at line 121 of file search_stats.pb.cc.

◆ _LocalSearchStatistics_LocalSearchOperatorStatistics_default_instance_

OR_PROTO_DLL LocalSearchStatistics_LocalSearchOperatorStatisticsDefaultTypeInternal operations_research::_LocalSearchStatistics_LocalSearchOperatorStatistics_default_instance_

Definition at line 87 of file search_stats.pb.cc.

◆ _MoreNodesPerformedAcceptanceStrategy_default_instance_

OR_PROTO_DLL MoreNodesPerformedAcceptanceStrategyDefaultTypeInternal operations_research::_MoreNodesPerformedAcceptanceStrategy_default_instance_

Definition at line 186 of file routing_ils.pb.cc.

◆ _MPAbsConstraint_default_instance_

OR_PROTO_DLL MPAbsConstraintDefaultTypeInternal operations_research::_MPAbsConstraint_default_instance_

Definition at line 395 of file linear_solver.pb.cc.

◆ _MPArrayConstraint_default_instance_

OR_PROTO_DLL MPArrayConstraintDefaultTypeInternal operations_research::_MPArrayConstraint_default_instance_

Definition at line 369 of file linear_solver.pb.cc.

◆ _MPArrayWithConstantConstraint_default_instance_

OR_PROTO_DLL MPArrayWithConstantConstraintDefaultTypeInternal operations_research::_MPArrayWithConstantConstraint_default_instance_

Definition at line 343 of file linear_solver.pb.cc.

◆ _MPConstraintProto_default_instance_

OR_PROTO_DLL MPConstraintProtoDefaultTypeInternal operations_research::_MPConstraintProto_default_instance_

Definition at line 316 of file linear_solver.pb.cc.

◆ _MPGeneralConstraintProto_default_instance_

OR_PROTO_DLL MPGeneralConstraintProtoDefaultTypeInternal operations_research::_MPGeneralConstraintProto_default_instance_

Definition at line 584 of file linear_solver.pb.cc.

◆ _MPIndicatorConstraint_default_instance_

OR_PROTO_DLL MPIndicatorConstraintDefaultTypeInternal operations_research::_MPIndicatorConstraint_default_instance_

Definition at line 526 of file linear_solver.pb.cc.

◆ _MPModelDeltaProto_ConstraintOverridesEntry_DoNotUse_default_instance_

OR_PROTO_DLL MPModelDeltaProto_ConstraintOverridesEntry_DoNotUseDefaultTypeInternal operations_research::_MPModelDeltaProto_ConstraintOverridesEntry_DoNotUse_default_instance_

Definition at line 499 of file linear_solver.pb.cc.

◆ _MPModelDeltaProto_default_instance_

OR_PROTO_DLL MPModelDeltaProtoDefaultTypeInternal operations_research::_MPModelDeltaProto_default_instance_

Definition at line 555 of file linear_solver.pb.cc.

◆ _MPModelDeltaProto_VariableOverridesEntry_DoNotUse_default_instance_

OR_PROTO_DLL MPModelDeltaProto_VariableOverridesEntry_DoNotUseDefaultTypeInternal operations_research::_MPModelDeltaProto_VariableOverridesEntry_DoNotUse_default_instance_

Definition at line 481 of file linear_solver.pb.cc.

◆ _MPModelProto_Annotation_default_instance_

OR_PROTO_DLL MPModelProto_AnnotationDefaultTypeInternal operations_research::_MPModelProto_Annotation_default_instance_

Definition at line 283 of file linear_solver.pb.cc.

◆ _MPModelProto_default_instance_

OR_PROTO_DLL MPModelProtoDefaultTypeInternal operations_research::_MPModelProto_default_instance_

Definition at line 619 of file linear_solver.pb.cc.

◆ _MPModelRequest_default_instance_

OR_PROTO_DLL MPModelRequestDefaultTypeInternal operations_research::_MPModelRequest_default_instance_

Definition at line 653 of file linear_solver.pb.cc.

◆ _MPQuadraticConstraint_default_instance_

OR_PROTO_DLL MPQuadraticConstraintDefaultTypeInternal operations_research::_MPQuadraticConstraint_default_instance_

Definition at line 248 of file linear_solver.pb.cc.

◆ _MPQuadraticObjective_default_instance_

OR_PROTO_DLL MPQuadraticObjectiveDefaultTypeInternal operations_research::_MPQuadraticObjective_default_instance_

Definition at line 217 of file linear_solver.pb.cc.

◆ _MPSolution_default_instance_

OR_PROTO_DLL MPSolutionDefaultTypeInternal operations_research::_MPSolution_default_instance_

Definition at line 190 of file linear_solver.pb.cc.

◆ _MPSolutionResponse_default_instance_

OR_PROTO_DLL MPSolutionResponseDefaultTypeInternal operations_research::_MPSolutionResponse_default_instance_

Definition at line 463 of file linear_solver.pb.cc.

◆ _MPSolveInfo_default_instance_

OR_PROTO_DLL MPSolveInfoDefaultTypeInternal operations_research::_MPSolveInfo_default_instance_

Definition at line 164 of file linear_solver.pb.cc.

◆ _MPSolverCommonParameters_default_instance_

OR_PROTO_DLL MPSolverCommonParametersDefaultTypeInternal operations_research::_MPSolverCommonParameters_default_instance_

Definition at line 425 of file linear_solver.pb.cc.

◆ _MPSosConstraint_default_instance_

OR_PROTO_DLL MPSosConstraintDefaultTypeInternal operations_research::_MPSosConstraint_default_instance_

Definition at line 138 of file linear_solver.pb.cc.

◆ _MPVariableProto_default_instance_

OR_PROTO_DLL MPVariableProtoDefaultTypeInternal operations_research::_MPVariableProto_default_instance_

Definition at line 111 of file linear_solver.pb.cc.

◆ _OptionalDouble_default_instance_

OR_PROTO_DLL OptionalDoubleDefaultTypeInternal operations_research::_OptionalDouble_default_instance_

Definition at line 79 of file linear_solver.pb.cc.

◆ _PartialVariableAssignment_default_instance_

OR_PROTO_DLL PartialVariableAssignmentDefaultTypeInternal operations_research::_PartialVariableAssignment_default_instance_

Definition at line 54 of file linear_solver.pb.cc.

◆ _PerturbationStrategy_default_instance_

OR_PROTO_DLL PerturbationStrategyDefaultTypeInternal operations_research::_PerturbationStrategy_default_instance_

Definition at line 168 of file routing_ils.pb.cc.

◆ _RandomWalkRuinStrategy_default_instance_

OR_PROTO_DLL RandomWalkRuinStrategyDefaultTypeInternal operations_research::_RandomWalkRuinStrategy_default_instance_

Definition at line 150 of file routing_ils.pb.cc.

◆ _RecreateParameters_default_instance_

OR_PROTO_DLL RecreateParametersDefaultTypeInternal operations_research::_RecreateParameters_default_instance_

Definition at line 317 of file routing_ils.pb.cc.

◆ _RecreateStrategy_default_instance_

OR_PROTO_DLL RecreateStrategyDefaultTypeInternal operations_research::_RecreateStrategy_default_instance_

Definition at line 369 of file routing_ils.pb.cc.

◆ _RegularLimitParameters_default_instance_

OR_PROTO_DLL RegularLimitParametersDefaultTypeInternal operations_research::_RegularLimitParameters_default_instance_

Definition at line 57 of file search_limit.pb.cc.

◆ _Room_default_instance_

OR_PROTO_DLL RoomDefaultTypeInternal operations_research::_Room_default_instance_

Definition at line 142 of file course_scheduling.pb.cc.

◆ _RoutingModelParameters_default_instance_

OR_PROTO_DLL RoutingModelParametersDefaultTypeInternal operations_research::_RoutingModelParameters_default_instance_

Definition at line 144 of file routing_parameters.pb.cc.

◆ _RoutingSearchParameters_default_instance_

OR_PROTO_DLL RoutingSearchParametersDefaultTypeInternal operations_research::_RoutingSearchParameters_default_instance_

Definition at line 221 of file routing_parameters.pb.cc.

◆ _RoutingSearchParameters_ImprovementSearchLimitParameters_default_instance_

OR_PROTO_DLL RoutingSearchParameters_ImprovementSearchLimitParametersDefaultTypeInternal operations_research::_RoutingSearchParameters_ImprovementSearchLimitParameters_default_instance_

Definition at line 117 of file routing_parameters.pb.cc.

◆ _RoutingSearchParameters_LocalSearchNeighborhoodOperators_default_instance_

OR_PROTO_DLL RoutingSearchParameters_LocalSearchNeighborhoodOperatorsDefaultTypeInternal operations_research::_RoutingSearchParameters_LocalSearchNeighborhoodOperators_default_instance_

Definition at line 91 of file routing_parameters.pb.cc.

◆ _RoutingSearchStatus_default_instance_

OR_PROTO_DLL RoutingSearchStatusDefaultTypeInternal operations_research::_RoutingSearchStatus_default_instance_

Definition at line 45 of file routing_enums.pb.cc.

◆ _RuinCompositionStrategy_default_instance_

OR_PROTO_DLL RuinCompositionStrategyDefaultTypeInternal operations_research::_RuinCompositionStrategy_default_instance_

Definition at line 125 of file routing_ils.pb.cc.

◆ _RuinRecreateParameters_default_instance_

OR_PROTO_DLL RuinRecreateParametersDefaultTypeInternal operations_research::_RuinRecreateParameters_default_instance_

Definition at line 399 of file routing_ils.pb.cc.

◆ _RuinStrategy_default_instance_

OR_PROTO_DLL RuinStrategyDefaultTypeInternal operations_research::_RuinStrategy_default_instance_

Definition at line 291 of file routing_ils.pb.cc.

◆ _SavingsParameters_default_instance_

OR_PROTO_DLL SavingsParametersDefaultTypeInternal operations_research::_SavingsParameters_default_instance_

Definition at line 55 of file routing_heuristic_parameters.pb.cc.

◆ _SearchStatistics_default_instance_

OR_PROTO_DLL SearchStatisticsDefaultTypeInternal operations_research::_SearchStatistics_default_instance_

Definition at line 235 of file search_stats.pb.cc.

◆ _SequenceVarAssignment_default_instance_

OR_PROTO_DLL SequenceVarAssignmentDefaultTypeInternal operations_research::_SequenceVarAssignment_default_instance_

Definition at line 89 of file assignment.pb.cc.

◆ _SetCoverProto_default_instance_

OR_PROTO_DLL SetCoverProtoDefaultTypeInternal operations_research::_SetCoverProto_default_instance_

Definition at line 115 of file set_cover.pb.cc.

◆ _SetCoverProto_Subset_default_instance_

OR_PROTO_DLL SetCoverProto_SubsetDefaultTypeInternal operations_research::_SetCoverProto_Subset_default_instance_

Definition at line 54 of file set_cover.pb.cc.

◆ _SetCoverSolutionResponse_default_instance_

OR_PROTO_DLL SetCoverSolutionResponseDefaultTypeInternal operations_research::_SetCoverSolutionResponse_default_instance_

Definition at line 86 of file set_cover.pb.cc.

◆ _SimulatedAnnealingAcceptanceStrategy_default_instance_

OR_PROTO_DLL SimulatedAnnealingAcceptanceStrategyDefaultTypeInternal operations_research::_SimulatedAnnealingAcceptanceStrategy_default_instance_

Definition at line 80 of file routing_ils.pb.cc.

◆ _SISRRuinStrategy_default_instance_

OR_PROTO_DLL SISRRuinStrategyDefaultTypeInternal operations_research::_SISRRuinStrategy_default_instance_

Definition at line 107 of file routing_ils.pb.cc.

◆ _SpatiallyCloseRoutesRuinStrategy_default_instance_

OR_PROTO_DLL SpatiallyCloseRoutesRuinStrategyDefaultTypeInternal operations_research::_SpatiallyCloseRoutesRuinStrategy_default_instance_

Definition at line 52 of file routing_ils.pb.cc.

◆ _Student_default_instance_

OR_PROTO_DLL StudentDefaultTypeInternal operations_research::_Student_default_instance_

Definition at line 114 of file course_scheduling.pb.cc.

◆ _StudentAssignment_default_instance_

OR_PROTO_DLL StudentAssignmentDefaultTypeInternal operations_research::_StudentAssignment_default_instance_

Definition at line 85 of file course_scheduling.pb.cc.

◆ _SubSolverStatistics_default_instance_

OR_PROTO_DLL SubSolverStatisticsDefaultTypeInternal operations_research::_SubSolverStatistics_default_instance_

Definition at line 54 of file search_stats.pb.cc.

◆ _Teacher_default_instance_

OR_PROTO_DLL TeacherDefaultTypeInternal operations_research::_Teacher_default_instance_

Definition at line 56 of file course_scheduling.pb.cc.

◆ _WorkerInfo_default_instance_

OR_PROTO_DLL WorkerInfoDefaultTypeInternal operations_research::_WorkerInfo_default_instance_

Definition at line 55 of file assignment.pb.cc.

◆ AbsencesBasedAcceptanceStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::AbsencesBasedAcceptanceStrategy_class_data_

◆ AcceptanceStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::AcceptanceStrategy_class_data_
Initial value:

Definition at line 4553 of file routing_ils.pb.cc.

◆ AllNodesPerformedAcceptanceStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::AllNodesPerformedAcceptanceStrategy_class_data_

◆ AssignmentProto_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::AssignmentProto_class_data_
Initial value:

Definition at line 2158 of file assignment.pb.cc.

◆ BronKerboschAlgorithm< NodeIndex >::kPushStateDeterministicTimeSecondsPerCandidate

template<typename NodeIndex>
const double operations_research::BronKerboschAlgorithm< NodeIndex >::kPushStateDeterministicTimeSecondsPerCandidate = 0.54663e-7

Definition at line 646 of file cliques.h.

◆ CapacityConstraintProto_CapacityTerm_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::CapacityConstraintProto_CapacityTerm_class_data_

◆ CapacityConstraintProto_CapacityTerm_ElementWeightPair_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::CapacityConstraintProto_CapacityTerm_ElementWeightPair_class_data_

◆ CapacityConstraintProto_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::CapacityConstraintProto_class_data_
Initial value:

Definition at line 920 of file capacity.pb.cc.

◆ ClassAssignment_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::ClassAssignment_class_data_
Initial value:

Definition at line 1533 of file course_scheduling.pb.cc.

◆ ConstraintRuns_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::ConstraintRuns_class_data_
Initial value:

Definition at line 697 of file demon_profiler.pb.cc.

◆ ConstraintSolverParameters_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::ConstraintSolverParameters_class_data_

◆ ConstraintSolverParameters_TrailCompression_internal_data_

OR_PROTO_DLL const uint32_t operations_research::ConstraintSolverParameters_TrailCompression_internal_data_
Initial value:
= {
131072u, 0u, }

Definition at line 209 of file solver_parameters.pb.cc.

◆ ConstraintSolverParameters_TrailCompression_TrailCompression_ARRAYSIZE

int operations_research::ConstraintSolverParameters_TrailCompression_TrailCompression_ARRAYSIZE = 1 + 1
inlineconstexpr

Definition at line 90 of file solver_parameters.pb.h.

◆ ConstraintSolverParameters_TrailCompression_TrailCompression_MAX

ConstraintSolverParameters_TrailCompression operations_research::ConstraintSolverParameters_TrailCompression_TrailCompression_MAX
inlineconstexpr
Initial value:

Definition at line 85 of file solver_parameters.pb.h.

◆ ConstraintSolverParameters_TrailCompression_TrailCompression_MIN

ConstraintSolverParameters_TrailCompression operations_research::ConstraintSolverParameters_TrailCompression_TrailCompression_MIN
inlineconstexpr
Initial value:

Definition at line 83 of file solver_parameters.pb.h.

◆ ConstraintSolverStatistics_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::ConstraintSolverStatistics_class_data_

◆ CoolingScheduleStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::CoolingScheduleStrategy_class_data_
Initial value:

Definition at line 3385 of file routing_ils.pb.cc.

◆ CoolingScheduleStrategy_Value_internal_data_

OR_PROTO_DLL const uint32_t operations_research::CoolingScheduleStrategy_Value_internal_data_
Initial value:
= {
196608u, 0u, }

Definition at line 705 of file routing_ils.pb.cc.

◆ CoolingScheduleStrategy_Value_Value_ARRAYSIZE

int operations_research::CoolingScheduleStrategy_Value_Value_ARRAYSIZE = 2 + 1
inlineconstexpr

Definition at line 242 of file routing_ils.pb.h.

◆ CoolingScheduleStrategy_Value_Value_MAX

CoolingScheduleStrategy_Value operations_research::CoolingScheduleStrategy_Value_Value_MAX
inlineconstexpr
Initial value:

Definition at line 237 of file routing_ils.pb.h.

◆ CoolingScheduleStrategy_Value_Value_MIN

CoolingScheduleStrategy_Value operations_research::CoolingScheduleStrategy_Value_Value_MIN
inlineconstexpr
Initial value:

Definition at line 235 of file routing_ils.pb.h.

◆ Course_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::Course_class_data_
Initial value:

Definition at line 2300 of file course_scheduling.pb.cc.

◆ CourseSchedulingModel_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::CourseSchedulingModel_class_data_

◆ CourseSchedulingResult_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::CourseSchedulingResult_class_data_

◆ CourseSchedulingResultStatus_ARRAYSIZE

int operations_research::CourseSchedulingResultStatus_ARRAYSIZE = 6 + 1
inlineconstexpr

Definition at line 123 of file course_scheduling.pb.h.

◆ CourseSchedulingResultStatus_internal_data_

OR_PROTO_DLL const uint32_t operations_research::CourseSchedulingResultStatus_internal_data_
Initial value:
= {
458752u, 0u, }

Definition at line 452 of file course_scheduling.pb.cc.

◆ CourseSchedulingResultStatus_MAX

CourseSchedulingResultStatus operations_research::CourseSchedulingResultStatus_MAX
inlineconstexpr
Initial value:

Definition at line 118 of file course_scheduling.pb.h.

◆ CourseSchedulingResultStatus_MIN

CourseSchedulingResultStatus operations_research::CourseSchedulingResultStatus_MIN
inlineconstexpr
Initial value:
=

Definition at line 116 of file course_scheduling.pb.h.

◆ DEBUG_MODE

const bool operations_research::DEBUG_MODE = true

Definition at line 266 of file radix_sort.h.

◆ DemonRuns_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::DemonRuns_class_data_
Initial value:

Definition at line 293 of file demon_profiler.pb.cc.

◆ FirstSolutionStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::FirstSolutionStrategy_class_data_
Initial value:

Definition at line 235 of file routing_enums.pb.cc.

◆ FirstSolutionStrategy_Value_internal_data_

OR_PROTO_DLL const uint32_t operations_research::FirstSolutionStrategy_Value_internal_data_
Initial value:
= {
1179648u, 0u, }

Definition at line 157 of file routing_enums.pb.cc.

◆ FirstSolutionStrategy_Value_Value_ARRAYSIZE

int operations_research::FirstSolutionStrategy_Value_Value_ARRAYSIZE = 17 + 1
inlineconstexpr

Definition at line 125 of file routing_enums.pb.h.

◆ FirstSolutionStrategy_Value_Value_MAX

FirstSolutionStrategy_Value operations_research::FirstSolutionStrategy_Value_Value_MAX
inlineconstexpr
Initial value:

Definition at line 120 of file routing_enums.pb.h.

◆ FirstSolutionStrategy_Value_Value_MIN

FirstSolutionStrategy_Value operations_research::FirstSolutionStrategy_Value_Value_MIN
inlineconstexpr
Initial value:
=

Definition at line 118 of file routing_enums.pb.h.

◆ FlowArcProto_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::FlowArcProto_class_data_
Initial value:

Definition at line 290 of file flow_problem.pb.cc.

◆ FlowModelProto_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::FlowModelProto_class_data_
Initial value:

Definition at line 925 of file flow_problem.pb.cc.

◆ FlowModelProto_ProblemType_internal_data_

OR_PROTO_DLL const uint32_t operations_research::FlowModelProto_ProblemType_internal_data_
Initial value:
= {
196608u, 0u, }

Definition at line 195 of file flow_problem.pb.cc.

◆ FlowModelProto_ProblemType_ProblemType_ARRAYSIZE

int operations_research::FlowModelProto_ProblemType_ProblemType_ARRAYSIZE = 2 + 1
inlineconstexpr

Definition at line 95 of file flow_problem.pb.h.

◆ FlowModelProto_ProblemType_ProblemType_MAX

FlowModelProto_ProblemType operations_research::FlowModelProto_ProblemType_ProblemType_MAX
inlineconstexpr
Initial value:

Definition at line 90 of file flow_problem.pb.h.

◆ FlowModelProto_ProblemType_ProblemType_MIN

FlowModelProto_ProblemType operations_research::FlowModelProto_ProblemType_ProblemType_MIN
inlineconstexpr
Initial value:
=

Definition at line 88 of file flow_problem.pb.h.

◆ FlowNodeProto_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::FlowNodeProto_class_data_
Initial value:

Definition at line 615 of file flow_problem.pb.cc.

◆ GlobalCheapestInsertionParameters_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::GlobalCheapestInsertionParameters_class_data_

◆ GRBaddconstr

std::function< int(GRBmodel *model, int numnz, int *cind, double *cval, char sense, double rhs, const char *constrname)> operations_research::GRBaddconstr = nullptr

Definition at line 129 of file gurobi_environment.cc.

◆ GRBaddconstrs

std::function< int(GRBmodel *model, int numconstrs, int numnz, int *cbeg, int *cind, double *cval, char *sense, double *rhs, char **constrnames)> operations_research::GRBaddconstrs = nullptr

Definition at line 133 of file gurobi_environment.cc.

◆ GRBaddgenconstrAbs

std::function< int(GRBmodel *model, const char *name, int resvar, int argvar)> operations_research::GRBaddgenconstrAbs = nullptr

Definition at line 147 of file gurobi_environment.cc.

◆ GRBaddgenconstrAnd

std::function< int(GRBmodel *model, const char *name, int resvar, int nvars, const int *vars)> operations_research::GRBaddgenconstrAnd = nullptr

Definition at line 150 of file gurobi_environment.cc.

◆ GRBaddgenconstrIndicator

std::function< int(GRBmodel *model, const char *name, int binvar, int binval, int nvars, const int *vars, const double *vals, char sense, double rhs)> operations_research::GRBaddgenconstrIndicator = nullptr

Definition at line 157 of file gurobi_environment.cc.

◆ GRBaddgenconstrMax

std::function< int(GRBmodel *model, const char *name, int resvar, int nvars, const int *vars, double constant)> operations_research::GRBaddgenconstrMax = nullptr

Definition at line 142 of file gurobi_environment.cc.

◆ GRBaddgenconstrMin

std::function< int(GRBmodel *model, const char *name, int resvar, int nvars, const int *vars, double constant)> operations_research::GRBaddgenconstrMin = nullptr

Definition at line 145 of file gurobi_environment.cc.

◆ GRBaddgenconstrOr

std::function< int(GRBmodel *model, const char *name, int resvar, int nvars, const int *vars)> operations_research::GRBaddgenconstrOr = nullptr

Definition at line 153 of file gurobi_environment.cc.

◆ GRBaddqconstr

std::function< int(GRBmodel *model, int numlnz, int *lind, double *lval, int numqnz, int *qrow, int *qcol, double *qval, char sense, double rhs, const char *QCname)> operations_research::GRBaddqconstr = nullptr

Definition at line 161 of file gurobi_environment.cc.

◆ GRBaddqpterms

std::function< int(GRBmodel *model, int numqnz, int *qrow, int *qcol, double *qval)> operations_research::GRBaddqpterms = nullptr

Definition at line 164 of file gurobi_environment.cc.

◆ GRBaddrangeconstr

std::function< int(GRBmodel *model, int numnz, int *cind, double *cval, double lower, double upper, const char *constrname)> operations_research::GRBaddrangeconstr = nullptr

Definition at line 136 of file gurobi_environment.cc.

◆ GRBaddsos

std::function< int(GRBmodel *model, int numsos, int nummembers, int *types, int *beg, int *ind, double *weight)> operations_research::GRBaddsos = nullptr

Definition at line 139 of file gurobi_environment.cc.

◆ GRBaddvar

std::function< int(GRBmodel *model, int numnz, int *vind, double *vval, double obj, double lb, double ub, char vtype, const char *varname)> operations_research::GRBaddvar = nullptr

Definition at line 122 of file gurobi_environment.cc.

◆ GRBaddvars

std::function< int(GRBmodel *model, int numvars, int numnz, int *vbeg, int *vind, double *vval, double *obj, double *lb, double *ub, char *vtype, char **varnames)> operations_research::GRBaddvars = nullptr

Definition at line 126 of file gurobi_environment.cc.

◆ GRBcbcut

std::function< int(void *cbdata, int cutlen, const int *cutind, const double *cutval, char cutsense, double cutrhs)> operations_research::GRBcbcut = nullptr

Definition at line 105 of file gurobi_environment.cc.

◆ GRBcbget

std::function< int(void *cbdata, int where, int what, void *resultP)> operations_research::GRBcbget
Initial value:
=
nullptr

Definition at line 99 of file gurobi_environment.cc.

◆ GRBcblazy

std::function< int(void *cbdata, int lazylen, const int *lazyind, const double *lazyval, char lazysense, double lazyrhs)> operations_research::GRBcblazy = nullptr

Definition at line 108 of file gurobi_environment.cc.

◆ GRBcbsolution

std::function< int(void *cbdata, const double *solution, double *objvalP)> operations_research::GRBcbsolution = nullptr

Definition at line 102 of file gurobi_environment.cc.

◆ GRBchgcoeffs

std::function< int(GRBmodel *model, int cnt, int *cind, int *vind, double *val)> operations_research::GRBchgcoeffs = nullptr

Definition at line 173 of file gurobi_environment.cc.

◆ GRBcomputeIIS

std::function< int(GRBmodel *model)> operations_research::GRBcomputeIIS = nullptr

Definition at line 113 of file gurobi_environment.cc.

◆ GRBcopyparams

std::function< int(GRBenv *dest, GRBenv *src)> operations_research::GRBcopyparams = nullptr

Definition at line 208 of file gurobi_environment.cc.

◆ GRBdelconstrs

std::function< int(GRBmodel *model, int len, int *ind)> operations_research::GRBdelconstrs = nullptr

Definition at line 166 of file gurobi_environment.cc.

◆ GRBdelgenconstrs

std::function< int(GRBmodel *model, int len, int *ind)> operations_research::GRBdelgenconstrs
Initial value:
=
nullptr

Definition at line 168 of file gurobi_environment.cc.

◆ GRBdelq

std::function< int(GRBmodel *model)> operations_research::GRBdelq = nullptr

Definition at line 171 of file gurobi_environment.cc.

◆ GRBdelqconstrs

std::function< int(GRBmodel *model, int len, int *ind)> operations_research::GRBdelqconstrs = nullptr

Definition at line 170 of file gurobi_environment.cc.

◆ GRBdelsos

std::function< int(GRBmodel *model, int len, int *ind)> operations_research::GRBdelsos = nullptr

Definition at line 167 of file gurobi_environment.cc.

◆ GRBdelvars

std::function< int(GRBmodel *model, int len, int *ind)> operations_research::GRBdelvars = nullptr

Definition at line 165 of file gurobi_environment.cc.

◆ GRBdiscardmultiobjenvs

std::function< GRBenv *(GRBmodel *model)> operations_research::GRBdiscardmultiobjenvs = nullptr

Definition at line 215 of file gurobi_environment.cc.

◆ GRBemptyenv

std::function< int(GRBenv **envP)> operations_research::GRBemptyenv = nullptr

Definition at line 210 of file gurobi_environment.cc.

◆ GRBfreeenv

std::function< void(GRBenv *env)> operations_research::GRBfreeenv = nullptr

Definition at line 216 of file gurobi_environment.cc.

◆ GRBfreemodel

std::function< int(GRBmodel *model)> operations_research::GRBfreemodel = nullptr

Definition at line 175 of file gurobi_environment.cc.

◆ GRBgetcharattrarray

std::function< int(GRBmodel *model, const char *attrname, int first, int len, char *values)> operations_research::GRBgetcharattrarray = nullptr

Definition at line 66 of file gurobi_environment.cc.

◆ GRBgetcharattrelement

std::function< int(GRBmodel *model, const char *attrname, int element, char *valueP)> operations_research::GRBgetcharattrelement = nullptr

Definition at line 60 of file gurobi_environment.cc.

◆ GRBgetdblattr

std::function< int(GRBmodel *model, const char *attrname, double *valueP)> operations_research::GRBgetdblattr = nullptr

Definition at line 74 of file gurobi_environment.cc.

◆ GRBgetdblattrarray

std::function< int(GRBmodel *model, const char *attrname, int first, int len, double *values)> operations_research::GRBgetdblattrarray = nullptr

Definition at line 85 of file gurobi_environment.cc.

◆ GRBgetdblattrelement

std::function< int(GRBmodel *model, const char *attrname, int element, double *valueP)> operations_research::GRBgetdblattrelement = nullptr

Definition at line 79 of file gurobi_environment.cc.

◆ GRBgetdblparam

std::function< int(GRBenv *env, const char *paramname, double *valueP)> operations_research::GRBgetdblparam = nullptr

Definition at line 184 of file gurobi_environment.cc.

◆ GRBgetdblparaminfo

std::function< int(GRBenv *envP, const char *paramname, double *valueP, double *minP, double *maxP, double *defP)> operations_research::GRBgetdblparaminfo = nullptr

Definition at line 192 of file gurobi_environment.cc.

◆ GRBgetenv

std::function< GRBenv *(GRBmodel *model)> operations_research::GRBgetenv = nullptr

Definition at line 213 of file gurobi_environment.cc.

◆ GRBgeterrormsg

std::function< const char *(GRBenv *env)> operations_research::GRBgeterrormsg = nullptr

Definition at line 217 of file gurobi_environment.cc.

◆ GRBgetintattr

std::function< int(GRBmodel *model, const char *attrname, int *valueP)> operations_research::GRBgetintattr = nullptr

Definition at line 40 of file gurobi_environment.cc.

◆ GRBgetintattrarray

std::function< int(GRBmodel *model, const char *attrname, int first, int len, int *values)> operations_research::GRBgetintattrarray = nullptr

Definition at line 51 of file gurobi_environment.cc.

◆ GRBgetintattrelement

std::function< int(GRBmodel *model, const char *attrname, int element, int *valueP)> operations_research::GRBgetintattrelement = nullptr

Definition at line 45 of file gurobi_environment.cc.

◆ GRBgetintparam

std::function< int(GRBenv *env, const char *paramname, int *valueP)> operations_research::GRBgetintparam = nullptr

Definition at line 182 of file gurobi_environment.cc.

◆ GRBgetintparaminfo

std::function< int(GRBenv *envP, const char *paramname, int *valueP, int *minP, int *maxP, int *defP)> operations_research::GRBgetintparaminfo = nullptr

Definition at line 189 of file gurobi_environment.cc.

◆ GRBgetmultiobjenv

std::function< GRBenv *(GRBmodel *model, int num)> operations_research::GRBgetmultiobjenv = nullptr

Definition at line 214 of file gurobi_environment.cc.

◆ GRBgetnumparams

std::function< int(GRBenv *envP)> operations_research::GRBgetnumparams = nullptr

Definition at line 209 of file gurobi_environment.cc.

◆ GRBgetparamname

std::function< int(GRBenv *envP, int i, char **paramnameP)> operations_research::GRBgetparamname
Initial value:
=
nullptr

Definition at line 197 of file gurobi_environment.cc.

◆ GRBgetparamtype

std::function< int(GRBenv *envP, const char *paramname)> operations_research::GRBgetparamtype
Initial value:
=
nullptr

Definition at line 195 of file gurobi_environment.cc.

◆ GRBgetstrattr

std::function< int(GRBmodel *model, const char *attrname, char **valueP)> operations_research::GRBgetstrattr = nullptr

Definition at line 93 of file gurobi_environment.cc.

◆ GRBgetstrparam

std::function< int(GRBenv *env, const char *paramname, char *valueP)> operations_research::GRBgetstrparam = nullptr

Definition at line 186 of file gurobi_environment.cc.

◆ GRBgetstrparaminfo

std::function< int(GRBenv *envP, const char *paramname, char *valueP, char *defP)> operations_research::GRBgetstrparaminfo = nullptr

Definition at line 194 of file gurobi_environment.cc.

◆ GRBgetvars

std::function< int(GRBmodel *model, int *numnzP, int *vbeg, int *vind, double *vval, int start, int len)> operations_research::GRBgetvars = nullptr

Definition at line 111 of file gurobi_environment.cc.

◆ GRBisattravailable

std::function< int(GRBmodel *model, const char *attrname)> operations_research::GRBisattravailable
Initial value:
=
nullptr

Definition at line 37 of file gurobi_environment.cc.

◆ GRBloadenv

std::function< int(GRBenv **envP, const char *logfilename)> operations_research::GRBloadenv = nullptr

Definition at line 211 of file gurobi_environment.cc.

◆ GRBnewmodel

std::function< int(GRBenv *env, GRBmodel **modelP, const char *Pname, int numvars, double *obj, double *lb, double *ub, char *vtype, char **varnames)> operations_research::GRBnewmodel = nullptr

Definition at line 118 of file gurobi_environment.cc.

◆ GRBoptimize

std::function< int(GRBmodel *model)> operations_research::GRBoptimize = nullptr

Definition at line 112 of file gurobi_environment.cc.

◆ GRBplatform

std::function< char *(void)> operations_research::GRBplatform = nullptr

Definition at line 220 of file gurobi_environment.cc.

◆ GRBresetparams

std::function< int(GRBenv *env)> operations_research::GRBresetparams = nullptr

Definition at line 207 of file gurobi_environment.cc.

◆ GRBsetcallbackfunc

std::function< int(GRBmodel *model, int(GUROBI_STDCALL *cb)(CB_ARGS), void *usrdata)> operations_research::GRBsetcallbackfunc = nullptr

Definition at line 98 of file gurobi_environment.cc.

◆ GRBsetcharattrarray

std::function< int(GRBmodel *model, const char *attrname, int first, int len, char *newvalues)> operations_research::GRBsetcharattrarray = nullptr

Definition at line 69 of file gurobi_environment.cc.

◆ GRBsetcharattrelement

std::function< int(GRBmodel *model, const char *attrname, int element, char newvalue)> operations_research::GRBsetcharattrelement = nullptr

Definition at line 63 of file gurobi_environment.cc.

◆ GRBsetcharattrlist

std::function< int(GRBmodel *model, const char *attrname, int len, int *ind, char *newvalues)> operations_research::GRBsetcharattrlist = nullptr

Definition at line 72 of file gurobi_environment.cc.

◆ GRBsetdblattr

std::function< int(GRBmodel *model, const char *attrname, double newvalue)> operations_research::GRBsetdblattr = nullptr

Definition at line 76 of file gurobi_environment.cc.

◆ GRBsetdblattrarray

std::function< int(GRBmodel *model, const char *attrname, int first, int len, double *newvalues)> operations_research::GRBsetdblattrarray = nullptr

Definition at line 88 of file gurobi_environment.cc.

◆ GRBsetdblattrelement

std::function< int(GRBmodel *model, const char *attrname, int element, double newvalue)> operations_research::GRBsetdblattrelement = nullptr

Definition at line 82 of file gurobi_environment.cc.

◆ GRBsetdblattrlist

std::function< int(GRBmodel *model, const char *attrname, int len, int *ind, double *newvalues)> operations_research::GRBsetdblattrlist = nullptr

Definition at line 91 of file gurobi_environment.cc.

◆ GRBsetdblparam

std::function< int(GRBenv *env, const char *paramname, double value)> operations_research::GRBsetdblparam = nullptr

Definition at line 204 of file gurobi_environment.cc.

◆ GRBsetintattr

std::function< int(GRBmodel *model, const char *attrname, int newvalue)> operations_research::GRBsetintattr = nullptr

Definition at line 42 of file gurobi_environment.cc.

◆ GRBsetintattrarray

std::function< int(GRBmodel *model, const char *attrname, int first, int len, int *newvalues)> operations_research::GRBsetintattrarray = nullptr

Definition at line 54 of file gurobi_environment.cc.

◆ GRBsetintattrelement

std::function< int(GRBmodel *model, const char *attrname, int element, int newvalue)> operations_research::GRBsetintattrelement = nullptr

Definition at line 48 of file gurobi_environment.cc.

◆ GRBsetintattrlist

std::function< int(GRBmodel *model, const char *attrname, int len, int *ind, int *newvalues)> operations_research::GRBsetintattrlist = nullptr

Definition at line 57 of file gurobi_environment.cc.

◆ GRBsetintparam

std::function< int(GRBenv *env, const char *paramname, int value)> operations_research::GRBsetintparam = nullptr

Definition at line 202 of file gurobi_environment.cc.

◆ GRBsetobjectiven

std::function< int(GRBmodel *model, int index, int priority, double weight, double abstol, double reltol, const char *name, double constant, int lnz, int *lind, double *lval)> operations_research::GRBsetobjectiven = nullptr

Definition at line 180 of file gurobi_environment.cc.

◆ GRBsetparam

std::function< int(GRBenv *env, const char *paramname, const char *value)> operations_research::GRBsetparam = nullptr

Definition at line 200 of file gurobi_environment.cc.

◆ GRBsetstrattr

std::function< int(GRBmodel *model, const char *attrname, const char *newvalue)> operations_research::GRBsetstrattr = nullptr

Definition at line 95 of file gurobi_environment.cc.

◆ GRBsetstrparam

std::function< int(GRBenv *env, const char *paramname, const char *value)> operations_research::GRBsetstrparam = nullptr

Definition at line 206 of file gurobi_environment.cc.

◆ GRBstartenv

std::function< int(GRBenv *env)> operations_research::GRBstartenv = nullptr

Definition at line 212 of file gurobi_environment.cc.

◆ GRBterminate

std::function< void(GRBmodel *model)> operations_research::GRBterminate = nullptr

Definition at line 176 of file gurobi_environment.cc.

◆ GRBupdatemodel

std::function< int(GRBmodel *model)> operations_research::GRBupdatemodel = nullptr

Definition at line 174 of file gurobi_environment.cc.

◆ GRBversion

std::function< void(int *majorP, int *minorP, int *technicalP)> operations_research::GRBversion
Initial value:
=
nullptr

Definition at line 218 of file gurobi_environment.cc.

◆ GRBwrite

std::function< int(GRBmodel *model, const char *filename)> operations_research::GRBwrite = nullptr

Definition at line 114 of file gurobi_environment.cc.

◆ GreedyDescentAcceptanceStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::GreedyDescentAcceptanceStrategy_class_data_

◆ GScipOutput_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::GScipOutput_class_data_
Initial value:

Definition at line 2698 of file gscip.pb.cc.

◆ GScipOutput_Status_internal_data_

OR_PROTO_DLL const uint32_t operations_research::GScipOutput_Status_internal_data_
Initial value:
= {
1114112u, 0u, }

Definition at line 493 of file gscip.pb.cc.

◆ GScipOutput_Status_Status_ARRAYSIZE

int operations_research::GScipOutput_Status_Status_ARRAYSIZE = 16 + 1
inlineconstexpr

Definition at line 233 of file gscip.pb.h.

◆ GScipOutput_Status_Status_MAX

GScipOutput_Status operations_research::GScipOutput_Status_Status_MAX
inlineconstexpr
Initial value:
=
static_cast<GScipOutput_Status>(16)

Definition at line 228 of file gscip.pb.h.

◆ GScipOutput_Status_Status_MIN

GScipOutput_Status operations_research::GScipOutput_Status_Status_MIN
inlineconstexpr
Initial value:
=
static_cast<GScipOutput_Status>(0)

Definition at line 226 of file gscip.pb.h.

◆ GScipParameters_BoolParamsEntry_DoNotUse_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::GScipParameters_BoolParamsEntry_DoNotUse_class_data_

◆ GScipParameters_CharParamsEntry_DoNotUse_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::GScipParameters_CharParamsEntry_DoNotUse_class_data_

◆ GScipParameters_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::GScipParameters_class_data_
Initial value:

Definition at line 1249 of file gscip.pb.cc.

◆ GScipParameters_Emphasis_Emphasis_ARRAYSIZE

int operations_research::GScipParameters_Emphasis_Emphasis_ARRAYSIZE = 9 + 1
inlineconstexpr

Definition at line 144 of file gscip.pb.h.

◆ GScipParameters_Emphasis_Emphasis_MAX

GScipParameters_Emphasis operations_research::GScipParameters_Emphasis_Emphasis_MAX
inlineconstexpr
Initial value:

Definition at line 139 of file gscip.pb.h.

◆ GScipParameters_Emphasis_Emphasis_MIN

GScipParameters_Emphasis operations_research::GScipParameters_Emphasis_Emphasis_MIN
inlineconstexpr
Initial value:
=
static_cast<GScipParameters_Emphasis>(0)

Definition at line 137 of file gscip.pb.h.

◆ GScipParameters_Emphasis_internal_data_

OR_PROTO_DLL const uint32_t operations_research::GScipParameters_Emphasis_internal_data_
Initial value:
= {
655360u, 0u, }

Definition at line 481 of file gscip.pb.cc.

◆ GScipParameters_IntParamsEntry_DoNotUse_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::GScipParameters_IntParamsEntry_DoNotUse_class_data_

◆ GScipParameters_LongParamsEntry_DoNotUse_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::GScipParameters_LongParamsEntry_DoNotUse_class_data_

◆ GScipParameters_MetaParamValue_internal_data_

OR_PROTO_DLL const uint32_t operations_research::GScipParameters_MetaParamValue_internal_data_
Initial value:
= {
262144u, 0u, }

Definition at line 487 of file gscip.pb.cc.

◆ GScipParameters_MetaParamValue_MetaParamValue_ARRAYSIZE

int operations_research::GScipParameters_MetaParamValue_MetaParamValue_ARRAYSIZE = 3 + 1
inlineconstexpr

Definition at line 182 of file gscip.pb.h.

◆ GScipParameters_MetaParamValue_MetaParamValue_MAX

GScipParameters_MetaParamValue operations_research::GScipParameters_MetaParamValue_MetaParamValue_MAX
inlineconstexpr
Initial value:

Definition at line 177 of file gscip.pb.h.

◆ GScipParameters_MetaParamValue_MetaParamValue_MIN

GScipParameters_MetaParamValue operations_research::GScipParameters_MetaParamValue_MetaParamValue_MIN
inlineconstexpr
Initial value:

Definition at line 175 of file gscip.pb.h.

◆ GScipParameters_RealParamsEntry_DoNotUse_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::GScipParameters_RealParamsEntry_DoNotUse_class_data_

◆ GScipParameters_StringParamsEntry_DoNotUse_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::GScipParameters_StringParamsEntry_DoNotUse_class_data_

◆ GScipSolvingStats_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::GScipSolvingStats_class_data_
Initial value:

Definition at line 2157 of file gscip.pb.cc.

◆ Int128_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::Int128_class_data_
Initial value:

Definition at line 195 of file int128.pb.cc.

◆ IntervalVarAssignment_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::IntervalVarAssignment_class_data_
Initial value:

Definition at line 821 of file assignment.pb.cc.

◆ IntVarAssignment_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::IntVarAssignment_class_data_
Initial value:

Definition at line 438 of file assignment.pb.cc.

◆ IteratedLocalSearchParameters_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::IteratedLocalSearchParameters_class_data_

◆ kAllBits32

const uint32_t operations_research::kAllBits32 = 0xFFFFFFFFU
static

Definition at line 38 of file bitset.h.

◆ kAllBits64

const uint64_t operations_research::kAllBits64 = uint64_t{0xFFFFFFFFFFFFFFFF}
static

Definition at line 36 of file bitset.h.

◆ kAllBitsButLsb64

const uint64_t operations_research::kAllBitsButLsb64 = uint64_t{0xFFFFFFFFFFFFFFFE}
static

Definition at line 37 of file bitset.h.

◆ kAnyXsanEnabled

bool operations_research::kAnyXsanEnabled
inlineconstexpr
Initial value:
=
constexpr bool kAsanEnabled
constexpr bool kTsanEnabled
constexpr bool kMsanEnabled

Definition at line 24 of file testing_utils.h.

◆ kAsanEnabled

bool operations_research::kAsanEnabled = false
inlineconstexpr

Definition at line 19 of file testing_utils.h.

◆ kBalasFiles

const char* const operations_research::kBalasFiles[]
static
Initial value:
= {
"aa03.txt", "aa04.txt", "aa05.txt", "aa06.txt", "aa11.txt", "aa12.txt",
"aa13.txt", "aa14.txt", "aa15.txt", "aa16.txt", "aa17.txt", "aa18.txt",
"aa19.txt", "aa20.txt", "bus1.txt", "bus2.txt",
}

Definition at line 480 of file set_cover_solve.cc.

◆ kDefaultPrimalTolerance

double operations_research::kDefaultPrimalTolerance = 1e-07
constexpr

Definition at line 177 of file linear_solver.h.

◆ kDisconnectedPathDistance

const PathDistance operations_research::kDisconnectedPathDistance
Initial value:
=
std::numeric_limits<uint32_t>::max()

Definition at line 92 of file shortest_paths.h.

◆ kFimiFiles

const char* const operations_research::kFimiFiles[]
static
Initial value:
= {
"accidents.dat", "chess.dat", "connect.dat", "kosarak.dat",
"mushroom.dat",
"retail.dat", "webdocs.dat",
}

Definition at line 486 of file set_cover_solve.cc.

◆ kInfinity

double operations_research::kInfinity = std::numeric_limits<float>::infinity()
staticconstexpr

Definition at line 41 of file set_cover_heuristics.cc.

◆ kMaxGLPKNameLen

std::size_t operations_research::kMaxGLPKNameLen = 255
inlineconstexpr

Definition at line 36 of file glpk_formatters.h.

◆ kMaxPossibleCost

Cost operations_research::kMaxPossibleCost = std::numeric_limits<Cost>::max()
staticconstexpr

Definition at line 40 of file set_cover_heuristics.cc.

◆ kMsanEnabled

bool operations_research::kMsanEnabled = false
inlineconstexpr

Definition at line 20 of file testing_utils.h.

◆ kOptimizationProblemTypeNames

NamedOptimizationProblemType operations_research::kOptimizationProblemTypeNames[]
constexpr
Initial value:
= {
}

Definition at line 436 of file linear_solver.cc.

◆ kRailFiles

const char* const operations_research::kRailFiles[]
static
Initial value:
= {
"rail507.txt", "rail516.txt", "rail582.txt", "rail2536.txt",
"rail2586.txt", "rail4284.txt", "rail4872.txt",
}

Definition at line 435 of file set_cover_solve.cc.

◆ kRoundTripTestNumber

double operations_research::kRoundTripTestNumber = 0.10000000000000002
inlineconstexpr

Definition at line 33 of file fp_roundtrip_conv_testing.h.

◆ kRoundTripTestNumberStr

absl::string_view operations_research::kRoundTripTestNumberStr
inlineconstexpr
Initial value:
=
"0.10000000000000002"

Definition at line 34 of file fp_roundtrip_conv_testing.h.

◆ kScp4To6Files

const char* const operations_research::kScp4To6Files[]
static
Initial value:
= {
"scp41.txt", "scp42.txt", "scp43.txt", "scp44.txt", "scp45.txt",
"scp46.txt", "scp47.txt", "scp48.txt", "scp49.txt", "scp410.txt",
"scp51.txt", "scp52.txt", "scp53.txt", "scp54.txt", "scp55.txt",
"scp56.txt", "scp57.txt", "scp58.txt", "scp59.txt", "scp510.txt",
"scp61.txt", "scp62.txt", "scp63.txt", "scp64.txt", "scp65.txt",
}

Definition at line 440 of file set_cover_solve.cc.

◆ kScpAToEFiles

const char* const operations_research::kScpAToEFiles[]
static
Initial value:
= {
"scpa1.txt", "scpa2.txt", "scpa3.txt", "scpa4.txt", "scpa5.txt",
"scpb1.txt", "scpb2.txt", "scpb3.txt", "scpb4.txt", "scpb5.txt",
"scpc1.txt", "scpc2.txt", "scpc3.txt", "scpc4.txt", "scpc5.txt",
"scpd1.txt", "scpd2.txt", "scpd3.txt", "scpd4.txt", "scpd5.txt",
"scpe1.txt", "scpe2.txt", "scpe3.txt", "scpe4.txt", "scpe5.txt",
}

Definition at line 448 of file set_cover_solve.cc.

◆ kScpClrFiles

const char* const operations_research::kScpClrFiles[]
static
Initial value:
= {
"scpclr10.txt",
"scpclr11.txt",
"scpclr12.txt",
"scpclr13.txt",
}

Definition at line 463 of file set_cover_solve.cc.

◆ kScpCycFiles

const char* const operations_research::kScpCycFiles[]
static
Initial value:
= {
"scpcyc06.txt", "scpcyc07.txt", "scpcyc08.txt",
"scpcyc09.txt", "scpcyc10.txt", "scpcyc11.txt",
}

Definition at line 470 of file set_cover_solve.cc.

◆ kScpNrFiles

const char* const operations_research::kScpNrFiles[]
static
Initial value:
= {
"scpnre1.txt", "scpnre2.txt", "scpnre3.txt", "scpnre4.txt", "scpnre5.txt",
"scpnrf1.txt", "scpnrf2.txt", "scpnrf3.txt", "scpnrf4.txt", "scpnrf5.txt",
"scpnrg1.txt", "scpnrg2.txt", "scpnrg3.txt", "scpnrg4.txt", "scpnrg5.txt",
"scpnrh1.txt", "scpnrh2.txt", "scpnrh3.txt", "scpnrh4.txt", "scpnrh5.txt",
}

Definition at line 456 of file set_cover_solve.cc.

◆ kStdToCharsDoubleIsSupported

ABSL_CONST_INIT const bool operations_research::kStdToCharsDoubleIsSupported
Initial value:
=
std_to_chars_has_overload_v<double>

Definition at line 107 of file fp_roundtrip_conv.cc.

◆ kTsanEnabled

bool operations_research::kTsanEnabled = false
inlineconstexpr

Definition at line 21 of file testing_utils.h.

◆ kUnassigned

const int operations_research::kUnassigned = -1
static

Definition at line 507 of file routing.cc.

◆ kWedelinFiles

const char* const operations_research::kWedelinFiles[]
static
Initial value:
= {
"a320_coc.txt", "a320.txt", "alitalia.txt",
"b727.txt", "sasd9imp2.txt", "sasjump.txt",
}

Definition at line 475 of file set_cover_solve.cc.

◆ LocalCheapestInsertionParameters_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::LocalCheapestInsertionParameters_class_data_

◆ LocalCheapestInsertionParameters_InsertionSortingProperty_InsertionSortingProperty_ARRAYSIZE

int operations_research::LocalCheapestInsertionParameters_InsertionSortingProperty_InsertionSortingProperty_ARRAYSIZE = 8 + 1
inlineconstexpr

Definition at line 148 of file routing_heuristic_parameters.pb.h.

◆ LocalCheapestInsertionParameters_InsertionSortingProperty_InsertionSortingProperty_MAX

LocalCheapestInsertionParameters_InsertionSortingProperty operations_research::LocalCheapestInsertionParameters_InsertionSortingProperty_InsertionSortingProperty_MAX
inlineconstexpr

◆ LocalCheapestInsertionParameters_InsertionSortingProperty_InsertionSortingProperty_MIN

LocalCheapestInsertionParameters_InsertionSortingProperty operations_research::LocalCheapestInsertionParameters_InsertionSortingProperty_InsertionSortingProperty_MIN
inlineconstexpr
Initial value:

Definition at line 141 of file routing_heuristic_parameters.pb.h.

◆ LocalCheapestInsertionParameters_InsertionSortingProperty_internal_data_

OR_PROTO_DLL const uint32_t operations_research::LocalCheapestInsertionParameters_InsertionSortingProperty_internal_data_
Initial value:
= {
589824u, 0u, }

Definition at line 230 of file routing_heuristic_parameters.pb.cc.

◆ LocalCheapestInsertionParameters_PairInsertionStrategy_internal_data_

OR_PROTO_DLL const uint32_t operations_research::LocalCheapestInsertionParameters_PairInsertionStrategy_internal_data_
Initial value:
= {
262144u, 0u, }

Definition at line 224 of file routing_heuristic_parameters.pb.cc.

◆ LocalCheapestInsertionParameters_PairInsertionStrategy_PairInsertionStrategy_ARRAYSIZE

int operations_research::LocalCheapestInsertionParameters_PairInsertionStrategy_PairInsertionStrategy_ARRAYSIZE = 3 + 1
inlineconstexpr

Definition at line 105 of file routing_heuristic_parameters.pb.h.

◆ LocalCheapestInsertionParameters_PairInsertionStrategy_PairInsertionStrategy_MAX

LocalCheapestInsertionParameters_PairInsertionStrategy operations_research::LocalCheapestInsertionParameters_PairInsertionStrategy_PairInsertionStrategy_MAX
inlineconstexpr

◆ LocalCheapestInsertionParameters_PairInsertionStrategy_PairInsertionStrategy_MIN

LocalCheapestInsertionParameters_PairInsertionStrategy operations_research::LocalCheapestInsertionParameters_PairInsertionStrategy_PairInsertionStrategy_MIN
inlineconstexpr
Initial value:

Definition at line 98 of file routing_heuristic_parameters.pb.h.

◆ LocalSearchMetaheuristic_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::LocalSearchMetaheuristic_class_data_

◆ LocalSearchMetaheuristic_Value_internal_data_

OR_PROTO_DLL const uint32_t operations_research::LocalSearchMetaheuristic_Value_internal_data_
Initial value:
= {
458752u, 0u, }

Definition at line 163 of file routing_enums.pb.cc.

◆ LocalSearchMetaheuristic_Value_Value_ARRAYSIZE

int operations_research::LocalSearchMetaheuristic_Value_Value_ARRAYSIZE = 6 + 1
inlineconstexpr

Definition at line 166 of file routing_enums.pb.h.

◆ LocalSearchMetaheuristic_Value_Value_MAX

LocalSearchMetaheuristic_Value operations_research::LocalSearchMetaheuristic_Value_Value_MAX
inlineconstexpr
Initial value:

Definition at line 161 of file routing_enums.pb.h.

◆ LocalSearchMetaheuristic_Value_Value_MIN

LocalSearchMetaheuristic_Value operations_research::LocalSearchMetaheuristic_Value_Value_MIN
inlineconstexpr
Initial value:

Definition at line 159 of file routing_enums.pb.h.

◆ LocalSearchStatistics_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::LocalSearchStatistics_class_data_
Initial value:

Definition at line 1775 of file search_stats.pb.cc.

◆ LocalSearchStatistics_FirstSolutionStatistics_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::LocalSearchStatistics_FirstSolutionStatistics_class_data_

◆ LocalSearchStatistics_LocalSearchFilterStatistics_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::LocalSearchStatistics_LocalSearchFilterStatistics_class_data_

◆ LocalSearchStatistics_LocalSearchOperatorStatistics_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::LocalSearchStatistics_LocalSearchOperatorStatistics_class_data_

◆ MoreNodesPerformedAcceptanceStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MoreNodesPerformedAcceptanceStrategy_class_data_

◆ MPAbsConstraint_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPAbsConstraint_class_data_
Initial value:

Definition at line 3923 of file linear_solver.pb.cc.

◆ MPArrayConstraint_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPArrayConstraint_class_data_
Initial value:

Definition at line 4227 of file linear_solver.pb.cc.

◆ MPArrayWithConstantConstraint_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPArrayWithConstantConstraint_class_data_

◆ MPConstraintProto_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPConstraintProto_class_data_
Initial value:

Definition at line 1689 of file linear_solver.pb.cc.

◆ MPGeneralConstraintProto_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPGeneralConstraintProto_class_data_

◆ MPIndicatorConstraint_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPIndicatorConstraint_class_data_
Initial value:

Definition at line 2786 of file linear_solver.pb.cc.

◆ MPModelDeltaProto_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPModelDeltaProto_class_data_
Initial value:

Definition at line 7390 of file linear_solver.pb.cc.

◆ MPModelDeltaProto_ConstraintOverridesEntry_DoNotUse_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPModelDeltaProto_ConstraintOverridesEntry_DoNotUse_class_data_

◆ MPModelDeltaProto_VariableOverridesEntry_DoNotUse_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPModelDeltaProto_VariableOverridesEntry_DoNotUse_class_data_

◆ MPModelProto_Annotation_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPModelProto_Annotation_class_data_

◆ MPModelProto_Annotation_TargetType_internal_data_

OR_PROTO_DLL const uint32_t operations_research::MPModelProto_Annotation_TargetType_internal_data_
Initial value:
= {
196608u, 0u, }

Definition at line 1155 of file linear_solver.pb.cc.

◆ MPModelProto_Annotation_TargetType_TargetType_ARRAYSIZE

int operations_research::MPModelProto_Annotation_TargetType_TargetType_ARRAYSIZE = 2 + 1
inlineconstexpr

Definition at line 228 of file linear_solver.pb.h.

◆ MPModelProto_Annotation_TargetType_TargetType_MAX

MPModelProto_Annotation_TargetType operations_research::MPModelProto_Annotation_TargetType_TargetType_MAX
inlineconstexpr
Initial value:

Definition at line 223 of file linear_solver.pb.h.

◆ MPModelProto_Annotation_TargetType_TargetType_MIN

MPModelProto_Annotation_TargetType operations_research::MPModelProto_Annotation_TargetType_TargetType_MIN
inlineconstexpr
Initial value:

Definition at line 221 of file linear_solver.pb.h.

◆ MPModelProto_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPModelProto_class_data_
Initial value:

Definition at line 5979 of file linear_solver.pb.cc.

◆ MPModelRequest_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPModelRequest_class_data_
Initial value:

Definition at line 7770 of file linear_solver.pb.cc.

◆ MPModelRequest_SolverType_internal_data_

OR_PROTO_DLL const uint32_t operations_research::MPModelRequest_SolverType_internal_data_
Initial value:
= {
589824u, 96u, 254u, 0u, 805306368u, }

Definition at line 1167 of file linear_solver.pb.cc.

◆ MPModelRequest_SolverType_SolverType_ARRAYSIZE

int operations_research::MPModelRequest_SolverType_SolverType_ARRAYSIZE = 102 + 1
inlineconstexpr

Definition at line 310 of file linear_solver.pb.h.

◆ MPModelRequest_SolverType_SolverType_MAX

MPModelRequest_SolverType operations_research::MPModelRequest_SolverType_SolverType_MAX
inlineconstexpr
Initial value:

Definition at line 305 of file linear_solver.pb.h.

◆ MPModelRequest_SolverType_SolverType_MIN

MPModelRequest_SolverType operations_research::MPModelRequest_SolverType_SolverType_MIN
inlineconstexpr
Initial value:
=
static_cast<MPModelRequest_SolverType>(0)

Definition at line 303 of file linear_solver.pb.h.

◆ MPQuadraticConstraint_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPQuadraticConstraint_class_data_
Initial value:

Definition at line 3500 of file linear_solver.pb.cc.

◆ MPQuadraticObjective_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPQuadraticObjective_class_data_
Initial value:

Definition at line 4883 of file linear_solver.pb.cc.

◆ MPSolution_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPSolution_class_data_
Initial value:

Definition at line 8226 of file linear_solver.pb.cc.

◆ MPSolutionResponse_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPSolutionResponse_class_data_
Initial value:

Definition at line 8838 of file linear_solver.pb.cc.

◆ MPSolveInfo_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPSolveInfo_class_data_
Initial value:

Definition at line 8504 of file linear_solver.pb.cc.

◆ MPSolverCommonParameters_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPSolverCommonParameters_class_data_

◆ MPSolverCommonParameters_LPAlgorithmValues_internal_data_

OR_PROTO_DLL const uint32_t operations_research::MPSolverCommonParameters_LPAlgorithmValues_internal_data_
Initial value:
= {
262144u, 0u, }

Definition at line 1161 of file linear_solver.pb.cc.

◆ MPSolverCommonParameters_LPAlgorithmValues_LPAlgorithmValues_ARRAYSIZE

int operations_research::MPSolverCommonParameters_LPAlgorithmValues_LPAlgorithmValues_ARRAYSIZE = 3 + 1
inlineconstexpr

Definition at line 262 of file linear_solver.pb.h.

◆ MPSolverCommonParameters_LPAlgorithmValues_LPAlgorithmValues_MAX

MPSolverCommonParameters_LPAlgorithmValues operations_research::MPSolverCommonParameters_LPAlgorithmValues_LPAlgorithmValues_MAX
inlineconstexpr
Initial value:

Definition at line 257 of file linear_solver.pb.h.

◆ MPSolverCommonParameters_LPAlgorithmValues_LPAlgorithmValues_MIN

MPSolverCommonParameters_LPAlgorithmValues operations_research::MPSolverCommonParameters_LPAlgorithmValues_LPAlgorithmValues_MIN
inlineconstexpr
Initial value:

Definition at line 255 of file linear_solver.pb.h.

◆ MPSolverResponseStatus_ARRAYSIZE

int operations_research::MPSolverResponseStatus_ARRAYSIZE = 113 + 1
inlineconstexpr

Definition at line 349 of file linear_solver.pb.h.

◆ MPSolverResponseStatus_internal_data_

OR_PROTO_DLL const uint32_t operations_research::MPSolverResponseStatus_internal_data_
Initial value:
= {
524288u, 128u, 0u, 0u, 234893312u, 512u, }

Definition at line 1173 of file linear_solver.pb.cc.

◆ MPSolverResponseStatus_MAX

MPSolverResponseStatus operations_research::MPSolverResponseStatus_MAX
inlineconstexpr
Initial value:

Definition at line 344 of file linear_solver.pb.h.

◆ MPSolverResponseStatus_MIN

MPSolverResponseStatus operations_research::MPSolverResponseStatus_MIN
inlineconstexpr
Initial value:
=
static_cast<MPSolverResponseStatus>(0)

Definition at line 342 of file linear_solver.pb.h.

◆ MPSosConstraint_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPSosConstraint_class_data_
Initial value:

Definition at line 3130 of file linear_solver.pb.cc.

◆ MPSosConstraint_Type_internal_data_

OR_PROTO_DLL const uint32_t operations_research::MPSosConstraint_Type_internal_data_
Initial value:
= {
131072u, 0u, }

Definition at line 1149 of file linear_solver.pb.cc.

◆ MPSosConstraint_Type_Type_ARRAYSIZE

int operations_research::MPSosConstraint_Type_Type_ARRAYSIZE = 1 + 1
inlineconstexpr

Definition at line 195 of file linear_solver.pb.h.

◆ MPSosConstraint_Type_Type_MAX

MPSosConstraint_Type operations_research::MPSosConstraint_Type_Type_MAX
inlineconstexpr
Initial value:

Definition at line 190 of file linear_solver.pb.h.

◆ MPSosConstraint_Type_Type_MIN

MPSosConstraint_Type operations_research::MPSosConstraint_Type_Type_MIN
inlineconstexpr
Initial value:
=
static_cast<MPSosConstraint_Type>(0)

Definition at line 188 of file linear_solver.pb.h.

◆ MPVariableProto_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::MPVariableProto_class_data_
Initial value:

Definition at line 1291 of file linear_solver.pb.cc.

◆ num_free_elements_

operations_research::num_free_elements_[subset]

Definition at line 196 of file set_cover_invariant.cc.

◆ num_uncovered_elements_

operations_research::num_uncovered_elements_

Definition at line 187 of file set_cover_invariant.cc.

◆ OptionalBoolean_ARRAYSIZE

int operations_research::OptionalBoolean_ARRAYSIZE = 3 + 1
inlineconstexpr

Definition at line 84 of file optional_boolean.pb.h.

◆ OptionalBoolean_internal_data_

OR_PROTO_DLL const uint32_t operations_research::OptionalBoolean_internal_data_
Initial value:
= {
65536u, 32u, 6u, }

Definition at line 67 of file optional_boolean.pb.cc.

◆ OptionalBoolean_MAX

OptionalBoolean operations_research::OptionalBoolean_MAX
inlineconstexpr
Initial value:

Definition at line 79 of file optional_boolean.pb.h.

◆ OptionalBoolean_MIN

OptionalBoolean operations_research::OptionalBoolean_MIN
inlineconstexpr
Initial value:
=
static_cast<OptionalBoolean>(0)

Definition at line 77 of file optional_boolean.pb.h.

◆ OptionalDouble_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::OptionalDouble_class_data_
Initial value:

Definition at line 6488 of file linear_solver.pb.cc.

◆ PartialVariableAssignment_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::PartialVariableAssignment_class_data_

◆ PerturbationStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::PerturbationStrategy_class_data_
Initial value:

Definition at line 3275 of file routing_ils.pb.cc.

◆ PerturbationStrategy_Value_internal_data_

OR_PROTO_DLL const uint32_t operations_research::PerturbationStrategy_Value_internal_data_
Initial value:
= {
131072u, 0u, }

Definition at line 699 of file routing_ils.pb.cc.

◆ PerturbationStrategy_Value_Value_ARRAYSIZE

int operations_research::PerturbationStrategy_Value_Value_ARRAYSIZE = 1 + 1
inlineconstexpr

Definition at line 205 of file routing_ils.pb.h.

◆ PerturbationStrategy_Value_Value_MAX

PerturbationStrategy_Value operations_research::PerturbationStrategy_Value_Value_MAX
inlineconstexpr
Initial value:

Definition at line 200 of file routing_ils.pb.h.

◆ PerturbationStrategy_Value_Value_MIN

PerturbationStrategy_Value operations_research::PerturbationStrategy_Value_Value_MIN
inlineconstexpr
Initial value:
=

Definition at line 198 of file routing_ils.pb.h.

◆ RandomWalkRuinStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::RandomWalkRuinStrategy_class_data_
Initial value:

Definition at line 1037 of file routing_ils.pb.cc.

◆ RecreateParameters_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::RecreateParameters_class_data_
Initial value:

Definition at line 2131 of file routing_ils.pb.cc.

◆ RecreateStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::RecreateStrategy_class_data_
Initial value:

Definition at line 2466 of file routing_ils.pb.cc.

◆ RegularLimitParameters_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::RegularLimitParameters_class_data_
Initial value:

Definition at line 211 of file search_limit.pb.cc.

◆ Room_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::Room_class_data_
Initial value:

Definition at line 3451 of file course_scheduling.pb.cc.

◆ RoutingModelParameters_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::RoutingModelParameters_class_data_

◆ RoutingSearchParameters_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::RoutingSearchParameters_class_data_

◆ RoutingSearchParameters_ImprovementSearchLimitParameters_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::RoutingSearchParameters_ImprovementSearchLimitParameters_class_data_

◆ RoutingSearchParameters_LocalSearchNeighborhoodOperators_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::RoutingSearchParameters_LocalSearchNeighborhoodOperators_class_data_

◆ RoutingSearchParameters_SchedulingSolver_internal_data_

OR_PROTO_DLL const uint32_t operations_research::RoutingSearchParameters_SchedulingSolver_internal_data_
Initial value:
= {
196608u, 0u, }

Definition at line 657 of file routing_parameters.pb.cc.

◆ RoutingSearchParameters_SchedulingSolver_SchedulingSolver_ARRAYSIZE

int operations_research::RoutingSearchParameters_SchedulingSolver_SchedulingSolver_ARRAYSIZE = 2 + 1
inlineconstexpr

Definition at line 110 of file routing_parameters.pb.h.

◆ RoutingSearchParameters_SchedulingSolver_SchedulingSolver_MAX

RoutingSearchParameters_SchedulingSolver operations_research::RoutingSearchParameters_SchedulingSolver_SchedulingSolver_MAX
inlineconstexpr
Initial value:

Definition at line 105 of file routing_parameters.pb.h.

◆ RoutingSearchParameters_SchedulingSolver_SchedulingSolver_MIN

RoutingSearchParameters_SchedulingSolver operations_research::RoutingSearchParameters_SchedulingSolver_SchedulingSolver_MIN
inlineconstexpr
Initial value:

Definition at line 103 of file routing_parameters.pb.h.

◆ RoutingSearchStatus_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::RoutingSearchStatus_class_data_
Initial value:

Definition at line 455 of file routing_enums.pb.cc.

◆ RoutingSearchStatus_Value_internal_data_

OR_PROTO_DLL const uint32_t operations_research::RoutingSearchStatus_Value_internal_data_
Initial value:
= {
524288u, 0u, }

Definition at line 169 of file routing_enums.pb.cc.

◆ RoutingSearchStatus_Value_Value_ARRAYSIZE

int operations_research::RoutingSearchStatus_Value_Value_ARRAYSIZE = 7 + 1
inlineconstexpr

Definition at line 208 of file routing_enums.pb.h.

◆ RoutingSearchStatus_Value_Value_MAX

RoutingSearchStatus_Value operations_research::RoutingSearchStatus_Value_Value_MAX
inlineconstexpr
Initial value:

Definition at line 203 of file routing_enums.pb.h.

◆ RoutingSearchStatus_Value_Value_MIN

RoutingSearchStatus_Value operations_research::RoutingSearchStatus_Value_Value_MIN
inlineconstexpr
Initial value:
=
static_cast<RoutingSearchStatus_Value>(0)

Definition at line 201 of file routing_enums.pb.h.

◆ RuinCompositionStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::RuinCompositionStrategy_class_data_
Initial value:

Definition at line 2728 of file routing_ils.pb.cc.

◆ RuinCompositionStrategy_Value_internal_data_

OR_PROTO_DLL const uint32_t operations_research::RuinCompositionStrategy_Value_internal_data_
Initial value:
= {
262144u, 0u, }

Definition at line 693 of file routing_ils.pb.cc.

◆ RuinCompositionStrategy_Value_Value_ARRAYSIZE

int operations_research::RuinCompositionStrategy_Value_Value_ARRAYSIZE = 3 + 1
inlineconstexpr

Definition at line 169 of file routing_ils.pb.h.

◆ RuinCompositionStrategy_Value_Value_MAX

RuinCompositionStrategy_Value operations_research::RuinCompositionStrategy_Value_Value_MAX
inlineconstexpr
Initial value:

Definition at line 164 of file routing_ils.pb.h.

◆ RuinCompositionStrategy_Value_Value_MIN

RuinCompositionStrategy_Value operations_research::RuinCompositionStrategy_Value_Value_MIN
inlineconstexpr
Initial value:

Definition at line 162 of file routing_ils.pb.h.

◆ RuinRecreateParameters_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::RuinRecreateParameters_class_data_
Initial value:

Definition at line 2904 of file routing_ils.pb.cc.

◆ RuinStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::RuinStrategy_class_data_
Initial value:

Definition at line 1683 of file routing_ils.pb.cc.

◆ SavingsParameters_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::SavingsParameters_class_data_

◆ SearchStatistics_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::SearchStatistics_class_data_
Initial value:

Definition at line 2941 of file search_stats.pb.cc.

◆ SequenceVarAssignment_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::SequenceVarAssignment_class_data_
Initial value:

Definition at line 1402 of file assignment.pb.cc.

◆ SetCoverProto_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::SetCoverProto_class_data_
Initial value:

Definition at line 653 of file set_cover.pb.cc.

◆ SetCoverProto_Subset_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::SetCoverProto_Subset_class_data_
Initial value:

Definition at line 339 of file set_cover.pb.cc.

◆ SetCoverSolutionResponse_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::SetCoverSolutionResponse_class_data_
Initial value:

Definition at line 1042 of file set_cover.pb.cc.

◆ SetCoverSolutionResponse_Status_internal_data_

OR_PROTO_DLL const uint32_t operations_research::SetCoverSolutionResponse_Status_internal_data_
Initial value:
= {
327680u, 0u, }

Definition at line 221 of file set_cover.pb.cc.

◆ SetCoverSolutionResponse_Status_Status_ARRAYSIZE

int operations_research::SetCoverSolutionResponse_Status_Status_ARRAYSIZE = 4 + 1
inlineconstexpr

Definition at line 102 of file set_cover.pb.h.

◆ SetCoverSolutionResponse_Status_Status_MAX

SetCoverSolutionResponse_Status operations_research::SetCoverSolutionResponse_Status_Status_MAX
inlineconstexpr
Initial value:

Definition at line 97 of file set_cover.pb.h.

◆ SetCoverSolutionResponse_Status_Status_MIN

SetCoverSolutionResponse_Status operations_research::SetCoverSolutionResponse_Status_Status_MIN
inlineconstexpr
Initial value:

Definition at line 95 of file set_cover.pb.h.

◆ SimulatedAnnealingAcceptanceStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::SimulatedAnnealingAcceptanceStrategy_class_data_

◆ SISRRuinStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::SISRRuinStrategy_class_data_
Initial value:

Definition at line 1285 of file routing_ils.pb.cc.

◆ SpatiallyCloseRoutesRuinStrategy_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::SpatiallyCloseRoutesRuinStrategy_class_data_

◆ Student_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::Student_class_data_
Initial value:

Definition at line 3137 of file course_scheduling.pb.cc.

◆ StudentAssignment_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::StudentAssignment_class_data_
Initial value:

Definition at line 1923 of file course_scheduling.pb.cc.

◆ SubSolverStatistics_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::SubSolverStatistics_class_data_
Initial value:

Definition at line 2587 of file search_stats.pb.cc.

◆ Teacher_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::Teacher_class_data_
Initial value:

Definition at line 2809 of file course_scheduling.pb.cc.

◆ WorkerInfo_class_data_

OR_PROTO_DLLconst::google::protobuf::internal::ClassDataFull operations_research::WorkerInfo_class_data_
Initial value:

Definition at line 1809 of file assignment.pb.cc.

◆ XPRSaddcbchecktime

std::function< int(XPRSprob prob, int(XPRS_CC *f_checktime)(XPRSprob cbprob, void *cbdata), void *p, int priority)> operations_research::XPRSaddcbchecktime = nullptr

Definition at line 125 of file xpress_environment.cc.

◆ XPRSaddcbintsol

std::function< int(XPRSprob prob, void(XPRS_CC *f_intsol)(XPRSprob cbprob, void *cbdata), void *p, int priority)> operations_research::XPRSaddcbintsol = nullptr

Definition at line 121 of file xpress_environment.cc.

◆ XPRSaddcbmessage

std::function< int(XPRSprob prob, void(XPRS_CC *f_message)(XPRSprob cbprob, void *cbdata, const char *msg, int msglen, int msgtype), void *p, int priority)> operations_research::XPRSaddcbmessage = nullptr

Definition at line 123 of file xpress_environment.cc.

◆ XPRSaddcols

std::function< int(XPRSprob prob, int ncols, int ncoefs, const double objcoef[], const int start[], const int rowind[], const double rowcoef[], const double lb[], const double ub[])> operations_research::XPRSaddcols = nullptr

Definition at line 88 of file xpress_environment.cc.

◆ XPRSaddmipsol

std::function< int(XPRSprob prob, int length, const double solval[], const int colind[], const char *name)> operations_research::XPRSaddmipsol = nullptr

Definition at line 106 of file xpress_environment.cc.

◆ XPRSaddnames

std::function< int(XPRSprob prob, int type, const char names[], int first, int last)> operations_research::XPRSaddnames = nullptr

Definition at line 91 of file xpress_environment.cc.

◆ XPRSaddobj

std::function< int(XPRSprob prob, int ncols, const int colind[], const double objcoef[], int priority, double weight)> operations_research::XPRSaddobj = nullptr

Definition at line 89 of file xpress_environment.cc.

◆ XPRSaddqmatrix64

std::function< int(XPRSprob prob, int row, int ncoefs, const int rowqcol1[], int const rowqcol2[], const double rowqcoef[])> operations_research::XPRSaddqmatrix64 = nullptr

Definition at line 90 of file xpress_environment.cc.

◆ XPRSaddrows

std::function< int(XPRSprob prob, int nrows, int ncoefs, const char rowtype[], const double rhs[], const double rng[], const int start[], const int colind[], const double rowcoef[])> operations_research::XPRSaddrows = nullptr

Definition at line 85 of file xpress_environment.cc.

◆ XPRSaddrows64

std::function< int(XPRSprob prob, int nrows, int ncoefs, const char rowtype[], const double rhs[], const double rng[], const XPRSint64 start[], const int colind[], const double rowcoef[])> operations_research::XPRSaddrows64 = nullptr

Definition at line 86 of file xpress_environment.cc.

◆ XPRSaddsets64

std::function< int(XPRSprob prob, int nsets, XPRSint64 nelems, const char settype[], const XPRSint64 start[], const int colind[], const double refval[])> operations_research::XPRSaddsets64 = nullptr

Definition at line 93 of file xpress_environment.cc.

◆ XPRScalcobjn

std::function< int(XPRSprob prob, int objidx, const double solution[], double *p_objval)> operations_research::XPRScalcobjn = nullptr

Definition at line 74 of file xpress_environment.cc.

◆ XPRSchgbounds

std::function< int(XPRSprob prob, int nbounds, const int colind[], const char bndtype[], const double bndval[])> operations_research::XPRSchgbounds = nullptr

Definition at line 105 of file xpress_environment.cc.

◆ XPRSchgcoef

std::function< int(XPRSprob prob, int row, int col, double coef)> operations_research::XPRSchgcoef = nullptr

Definition at line 113 of file xpress_environment.cc.

◆ XPRSchgcoltype

std::function< int(XPRSprob prob, int ncols, const int colind[], const char coltype[])> operations_research::XPRSchgcoltype = nullptr

Definition at line 95 of file xpress_environment.cc.

◆ XPRSchgmcoef

std::function< int(XPRSprob prob, int ncoefs, const int rowind[], const int colind[], const double rowcoef[])> operations_research::XPRSchgmcoef = nullptr

Definition at line 114 of file xpress_environment.cc.

◆ XPRSchgmcoef64

std::function< int(XPRSprob prob, XPRSint64 ncoefs, const int rowind[], const int colind[], const double rowcoef[])> operations_research::XPRSchgmcoef64 = nullptr

Definition at line 115 of file xpress_environment.cc.

◆ XPRSchgmqobj

std::function< int(XPRSprob prob, int ncoefs, const int objqcol1[], const int objqcol2[], const double objqcoef[])> operations_research::XPRSchgmqobj = nullptr

Definition at line 116 of file xpress_environment.cc.

◆ XPRSchgobj

std::function< int(XPRSprob prob, int ncols, const int colind[], const double objcoef[])> operations_research::XPRSchgobj = nullptr

Definition at line 112 of file xpress_environment.cc.

◆ XPRSchgobjsense

std::function< int(XPRSprob prob, int objsense)> operations_research::XPRSchgobjsense = nullptr

Definition at line 98 of file xpress_environment.cc.

◆ XPRSchgrhs

std::function< int(XPRSprob prob, int nrows, const int rowind[], const double rhs[])> operations_research::XPRSchgrhs = nullptr

Definition at line 117 of file xpress_environment.cc.

◆ XPRSchgrhsrange

std::function< int(XPRSprob prob, int nrows, const int rowind[], const double rng[])> operations_research::XPRSchgrhsrange = nullptr

Definition at line 118 of file xpress_environment.cc.

◆ XPRSchgrowtype

std::function< int(XPRSprob prob, int nrows, const int rowind[], const char rowtype[])> operations_research::XPRSchgrowtype = nullptr

Definition at line 119 of file xpress_environment.cc.

◆ XPRScreateprob

std::function< int(XPRSprob *p_prob)> operations_research::XPRScreateprob = nullptr

Definition at line 48 of file xpress_environment.cc.

◆ XPRSdelcols

std::function< int(XPRSprob prob, int ncols, const int colind[])> operations_research::XPRSdelcols = nullptr

Definition at line 94 of file xpress_environment.cc.

◆ XPRSdelobj

std::function< int(XPRSprob prob, int objidx)> operations_research::XPRSdelobj = nullptr

Definition at line 120 of file xpress_environment.cc.

◆ XPRSdelrows

std::function< int(XPRSprob prob, int nrows, const int rowind[])> operations_research::XPRSdelrows = nullptr

Definition at line 87 of file xpress_environment.cc.

◆ XPRSdestroyprob

std::function< int(XPRSprob prob)> operations_research::XPRSdestroyprob = nullptr

Definition at line 49 of file xpress_environment.cc.

◆ XPRSfree

std::function< int(void)> operations_research::XPRSfree = nullptr

Definition at line 51 of file xpress_environment.cc.

◆ XPRSgetbanner

std::function< int(char *banner)> operations_research::XPRSgetbanner = nullptr

Definition at line 54 of file xpress_environment.cc.

◆ XPRSgetbasis

std::function< int(XPRSprob prob, int rowstat[], int colstat[])> operations_research::XPRSgetbasis = nullptr

Definition at line 100 of file xpress_environment.cc.

◆ XPRSgetcoef

OR_DLL std::function< int(XPRSprob prob, int row, int col, double *p_coef)> operations_research::XPRSgetcoef = nullptr

Definition at line 81 of file xpress_environment.cc.

◆ XPRSgetcoltype

OR_DLL std::function< int(XPRSprob prob, char coltype[], int first, int last)> operations_research::XPRSgetcoltype = nullptr

Definition at line 104 of file xpress_environment.cc.

◆ XPRSgetcontrolinfo

std::function< int(XPRSprob prob, const char *name, int *p_id, int *p_type)> operations_research::XPRSgetcontrolinfo = nullptr

Definition at line 75 of file xpress_environment.cc.

◆ XPRSgetdblattrib

OR_DLL std::function< int(XPRSprob prob, int attrib, double *p_value)> operations_research::XPRSgetdblattrib = nullptr

Definition at line 72 of file xpress_environment.cc.

◆ XPRSgetdblcontrol

OR_DLL std::function< int(XPRSprob prob, int control, double *p_value)> operations_research::XPRSgetdblcontrol = nullptr

Definition at line 68 of file xpress_environment.cc.

◆ XPRSgetduals

std::function< int(XPRSprob prob, int *status, double duals[], int first, int last)> operations_research::XPRSgetduals = nullptr

Definition at line 83 of file xpress_environment.cc.

◆ XPRSgetintattrib

OR_DLL std::function< int(XPRSprob prob, int attrib, int *p_value)> operations_research::XPRSgetintattrib = nullptr

Definition at line 70 of file xpress_environment.cc.

◆ XPRSgetintcontrol

OR_DLL std::function< int(XPRSprob prob, int control, int *p_value)> operations_research::XPRSgetintcontrol = nullptr

Definition at line 66 of file xpress_environment.cc.

◆ XPRSgetintcontrol64

OR_DLL std::function< int(XPRSprob prob, int control, XPRSint64 *p_value)> operations_research::XPRSgetintcontrol64 = nullptr

Definition at line 67 of file xpress_environment.cc.

◆ XPRSgetlasterror

std::function< int(XPRSprob prob, char *errmsg)> operations_research::XPRSgetlasterror = nullptr

Definition at line 99 of file xpress_environment.cc.

◆ XPRSgetlb

OR_DLL std::function< int(XPRSprob prob, double lb[], int first, int last)> operations_research::XPRSgetlb = nullptr

Definition at line 79 of file xpress_environment.cc.

◆ XPRSgetlicerrmsg

std::function< int(char *buffer, int maxbytes)> operations_research::XPRSgetlicerrmsg = nullptr

Definition at line 52 of file xpress_environment.cc.

◆ XPRSgetlpsol

std::function< int(XPRSprob prob, double x[], double slack[], double duals[], double djs[])> operations_research::XPRSgetlpsol = nullptr

Definition at line 110 of file xpress_environment.cc.

◆ XPRSgetmipsol

std::function< int(XPRSprob prob, double x[], double slack[])> operations_research::XPRSgetmipsol = nullptr

Definition at line 111 of file xpress_environment.cc.

◆ XPRSgetnames

std::function< int(XPRSprob prob, int type, char names[], int first, int last)> operations_research::XPRSgetnames = nullptr

Definition at line 92 of file xpress_environment.cc.

◆ XPRSgetobj

OR_DLL std::function< int(XPRSprob prob, double objcoef[], int first, int last)> operations_research::XPRSgetobj = nullptr

Definition at line 76 of file xpress_environment.cc.

◆ XPRSgetobjdblattrib

std::function< int(XPRSprob prob, int objidx, int attrib, double *p_value)> operations_research::XPRSgetobjdblattrib = nullptr

Definition at line 73 of file xpress_environment.cc.

◆ XPRSgetredcosts

std::function< int(XPRSprob prob, int *status, double djs[], int first, int last)> operations_research::XPRSgetredcosts = nullptr

Definition at line 84 of file xpress_environment.cc.

◆ XPRSgetrhs

OR_DLL std::function< int(XPRSprob prob, double rhs[], int first, int last)> operations_research::XPRSgetrhs = nullptr

Definition at line 77 of file xpress_environment.cc.

◆ XPRSgetrhsrange

OR_DLL std::function< int(XPRSprob prob, double rng[], int first, int last)> operations_research::XPRSgetrhsrange = nullptr

Definition at line 78 of file xpress_environment.cc.

◆ XPRSgetrowtype

OR_DLL std::function< int(XPRSprob prob, char rowtype[], int first, int last)> operations_research::XPRSgetrowtype = nullptr

Definition at line 103 of file xpress_environment.cc.

◆ XPRSgetsolution

std::function< int(XPRSprob prob, int *status, double x[], int first, int last)> operations_research::XPRSgetsolution = nullptr

Definition at line 82 of file xpress_environment.cc.

◆ XPRSgetstringattrib

OR_DLL std::function< int(XPRSprob prob, int attrib, char *value, int maxbytes, int *p_nbytes)> operations_research::XPRSgetstringattrib = nullptr

Definition at line 71 of file xpress_environment.cc.

◆ XPRSgetstringcontrol

OR_DLL std::function< int(XPRSprob prob, int control, char *value, int maxbytes, int *p_nbytes)> operations_research::XPRSgetstringcontrol = nullptr

Definition at line 69 of file xpress_environment.cc.

◆ XPRSgetub

OR_DLL std::function< int(XPRSprob prob, double ub[], int first, int last)> operations_research::XPRSgetub = nullptr

Definition at line 80 of file xpress_environment.cc.

◆ XPRSgetversion

std::function< int(char *version)> operations_research::XPRSgetversion = nullptr

Definition at line 55 of file xpress_environment.cc.

◆ XPRSgetversionnumbers

std::function< int(int *p_major, int *p_minor, int *p_build)> operations_research::XPRSgetversionnumbers = nullptr

Definition at line 56 of file xpress_environment.cc.

◆ XPRSinit

std::function< int(const char *path)> operations_research::XPRSinit = nullptr

Definition at line 50 of file xpress_environment.cc.

◆ XPRSinterrupt

std::function< int(XPRSprob prob, int reason)> operations_research::XPRSinterrupt = nullptr

Definition at line 59 of file xpress_environment.cc.

◆ XPRSlicense

std::function< int(int *p_i, char *p_c)> operations_research::XPRSlicense = nullptr

Definition at line 53 of file xpress_environment.cc.

◆ XPRSloadbasis

std::function< int(XPRSprob prob, const int rowstat[], const int colstat[])> operations_research::XPRSloadbasis = nullptr

Definition at line 96 of file xpress_environment.cc.

◆ XPRSloaddelayedrows

std::function< int(XPRSprob prob, int nrows, const int rowind[])> operations_research::XPRSloaddelayedrows = nullptr

Definition at line 107 of file xpress_environment.cc.

◆ XPRSloaddirs

std::function< int(XPRSprob prob, int ndirs, const int colind[], const int priority[], const char dir[], const double uppseudo[], const double downpseudo[])> operations_research::XPRSloaddirs

Definition at line 109 of file xpress_environment.cc.

◆ XPRSlpoptimize

std::function< int(XPRSprob prob, const char *flags)> operations_research::XPRSlpoptimize = nullptr

Definition at line 127 of file xpress_environment.cc.

◆ XPRSmipoptimize

std::function< int(XPRSprob prob, const char *flags)> operations_research::XPRSmipoptimize = nullptr

Definition at line 128 of file xpress_environment.cc.

◆ XPRSoptimize

std::function< int(XPRSprob prob, const char *flags, int *solvestatus, int *solstatus)> operations_research::XPRSoptimize = nullptr

Definition at line 129 of file xpress_environment.cc.

◆ XPRSpostsolve

std::function< int(XPRSprob prob)> operations_research::XPRSpostsolve = nullptr

Definition at line 97 of file xpress_environment.cc.

◆ XPRSremovecbchecktime

std::function< int(XPRSprob prob, int(XPRS_CC *f_checktime)(XPRSprob cbprob, void *cbdata), void *p)> operations_research::XPRSremovecbchecktime = nullptr

Definition at line 126 of file xpress_environment.cc.

◆ XPRSremovecbintsol

std::function< int(XPRSprob prob, void(XPRS_CC *f_intsol)(XPRSprob cbprob, void *cbdata), void *p)> operations_research::XPRSremovecbintsol = nullptr

Definition at line 122 of file xpress_environment.cc.

◆ XPRSremovecbmessage

std::function< int(XPRSprob prob, void(XPRS_CC *f_message)(XPRSprob cbprob, void *cbdata, const char *msg, int msglen, int msgtype), void *p)> operations_research::XPRSremovecbmessage = nullptr

Definition at line 124 of file xpress_environment.cc.

◆ XPRSsaveas

std::function< int(XPRSprob prob, const char *filename)> operations_research::XPRSsaveas = nullptr

Definition at line 102 of file xpress_environment.cc.

◆ XPRSsetdblcontrol

std::function< int(XPRSprob prob, int control, double value)> operations_research::XPRSsetdblcontrol = nullptr

Definition at line 62 of file xpress_environment.cc.

◆ XPRSsetdefaultcontrol

std::function< int(XPRSprob prob, int control)> operations_research::XPRSsetdefaultcontrol = nullptr

Definition at line 58 of file xpress_environment.cc.

◆ XPRSsetindicators

std::function< int(XPRSprob prob, int nrows, const int rowind[], const int colind[], const int complement[])> operations_research::XPRSsetindicators = nullptr

Definition at line 108 of file xpress_environment.cc.

◆ XPRSsetintcontrol

std::function< int(XPRSprob prob, int control, int value)> operations_research::XPRSsetintcontrol = nullptr

Definition at line 60 of file xpress_environment.cc.

◆ XPRSsetintcontrol64

std::function< int(XPRSprob prob, int control, XPRSint64 value)> operations_research::XPRSsetintcontrol64 = nullptr

Definition at line 61 of file xpress_environment.cc.

◆ XPRSsetobjdblcontrol

std::function< int(XPRSprob prob, int objidx, int control, double value)> operations_research::XPRSsetobjdblcontrol = nullptr

Definition at line 65 of file xpress_environment.cc.

◆ XPRSsetobjintcontrol

std::function< int(XPRSprob prob, int objidx, int control, int value)> operations_research::XPRSsetobjintcontrol = nullptr

Definition at line 64 of file xpress_environment.cc.

◆ XPRSsetprobname

std::function< int(XPRSprob prob, const char *probname)> operations_research::XPRSsetprobname = nullptr

Definition at line 57 of file xpress_environment.cc.

◆ XPRSsetstrcontrol

std::function< int(XPRSprob prob, int control, const char *value)> operations_research::XPRSsetstrcontrol = nullptr

Definition at line 63 of file xpress_environment.cc.

◆ XPRSwriteprob

std::function< int(XPRSprob prob, const char *filename, const char *flags)> operations_research::XPRSwriteprob = nullptr

Definition at line 101 of file xpress_environment.cc.