Scippy

SCIP

Solving Constraint Integer Programs

tpi_tnycthrd.c File Reference

Detailed Description

a TPI implementation using tinycthreads

Author
Stephen J. Maher
Leona Gottwald
Marc Pfetsch

Definition in file tpi_tnycthrd.c.

#include "tpi/tpi.h"
#include "blockmemshell/memory.h"
#include "tinycthread/tinycthread.h"
#include "scip/pub_message.h"

Go to the source code of this file.

Data Structures

struct  SCIP_Lock
 
struct  SCIP_Condition
 
struct  SCIP_Job
 
struct  SCIP_JobQueue
 
struct  SCIP_ThreadPool
 

Macros

#define SCIPtnyInitLock(lock)   ( mtx_init((lock), mtx_plain) == thrd_success ? SCIP_OKAY : SCIP_ERROR )
 
#define SCIPtnyDestroyLock(lock)   ( mtx_destroy(lock) )
 
#define SCIPtnyAcquireLock(lock)   ( mtx_lock(lock) == thrd_success ? SCIP_OKAY : SCIP_ERROR )
 
#define SCIPtnyReleaseLock(lock)   ( mtx_unlock(lock) == thrd_success ? SCIP_OKAY : SCIP_ERROR )
 
#define SCIPtnyInitCondition(condition)   ( cnd_init(condition) == thrd_success ? SCIP_OKAY : SCIP_ERROR )
 
#define SCIPtnyDestroyCondition(condition)   ( cnd_destroy(condition) )
 
#define SCIPtnySignalCondition(condition)   ( cnd_signal(condition) == thrd_success ? SCIP_OKAY : SCIP_ERROR )
 
#define SCIPtnyBroadcastCondition(condition)   ( cnd_broadcast(condition) == thrd_success ? SCIP_OKAY : SCIP_ERROR )
 
#define SCIPtnyWaitCondition(condition, lock)   ( cnd_wait((condition), (lock)) == thrd_success ? SCIP_OKAY: SCIP_ERROR )
 

Typedefs

typedef struct SCIP_ThreadPool SCIP_THREADPOOL
 
typedef struct SCIP_JobQueue SCIP_JOBQUEUE
 

Functions

static SCIP_RETCODE threadPoolThreadRetcode (void *threadnum)
 
static int threadPoolThread (void *threadnum)
 
static SCIP_RETCODE createThreadPool (SCIP_THREADPOOL **thrdpool, int nthreads, int qsize, SCIP_Bool blockwhenfull)
 
static void jobQueueAddJob (SCIP_THREADPOOL *threadpool, SCIP_JOB *newjob)
 
static SCIP_RETCODE threadPoolAddWork (SCIP_JOB *newjob, SCIP_SUBMITSTATUS *status)
 
static void freeJobQueue (SCIP_THREADPOOL *thrdpool)
 
static SCIP_RETCODE freeThreadPool (SCIP_THREADPOOL **thrdpool, SCIP_Bool finishjobs, SCIP_Bool completequeue)
 
static SCIP_JOBSTATUS checkJobQueue (SCIP_JOBQUEUE *jobqueue, int jobid)
 
static SCIP_Bool isJobRunning (SCIP_JOBQUEUE *currentjobs, int jobid)
 
int SCIPtpiGetNumThreads (void)
 
SCIP_RETCODE SCIPtpiInit (int nthreads, int queuesize, SCIP_Bool blockwhenfull)
 
SCIP_RETCODE SCIPtpiExit (void)
 
SCIP_RETCODE SCIPtpiCreateJob (SCIP_JOB **job, int jobid, SCIP_RETCODE(*jobfunc)(void *args), void *jobarg)
 
int SCIPtpiGetNewJobID (void)
 
SCIP_RETCODE SCIPtpiSubmitJob (SCIP_JOB *job, SCIP_SUBMITSTATUS *status)
 
SCIP_RETCODE SCIPtpiCollectJobs (int jobid)
 
SCIP_RETCODE SCIPtpiInitLock (SCIP_LOCK **lock)
 
void SCIPtpiDestroyLock (SCIP_LOCK **lock)
 
SCIP_RETCODE SCIPtpiAcquireLock (SCIP_LOCK *lock)
 
SCIP_RETCODE SCIPtpiReleaseLock (SCIP_LOCK *lock)
 
SCIP_RETCODE SCIPtpiInitCondition (SCIP_CONDITION **condition)
 
void SCIPtpiDestroyCondition (SCIP_CONDITION **condition)
 
SCIP_RETCODE SCIPtpiSignalCondition (SCIP_CONDITION *condition)
 
SCIP_RETCODE SCIPtpiBroadcastCondition (SCIP_CONDITION *condition)
 
SCIP_RETCODE SCIPtpiWaitCondition (SCIP_CONDITION *condition, SCIP_LOCK *lock)
 
int SCIPtpiGetThreadNum (void)
 

Macro Definition Documentation

◆ SCIPtnyInitLock

#define SCIPtnyInitLock (   lock)    ( mtx_init((lock), mtx_plain) == thrd_success ? SCIP_OKAY : SCIP_ERROR )

Definition at line 43 of file tpi_tnycthrd.c.

Referenced by createThreadPool().

◆ SCIPtnyDestroyLock

#define SCIPtnyDestroyLock (   lock)    ( mtx_destroy(lock) )

Definition at line 44 of file tpi_tnycthrd.c.

Referenced by freeThreadPool().

◆ SCIPtnyAcquireLock

#define SCIPtnyAcquireLock (   lock)    ( mtx_lock(lock) == thrd_success ? SCIP_OKAY : SCIP_ERROR )

Definition at line 45 of file tpi_tnycthrd.c.

Referenced by freeThreadPool(), and SCIPtpiCollectJobs().

◆ SCIPtnyReleaseLock

#define SCIPtnyReleaseLock (   lock)    ( mtx_unlock(lock) == thrd_success ? SCIP_OKAY : SCIP_ERROR )

Definition at line 46 of file tpi_tnycthrd.c.

Referenced by freeThreadPool().

◆ SCIPtnyInitCondition

#define SCIPtnyInitCondition (   condition)    ( cnd_init(condition) == thrd_success ? SCIP_OKAY : SCIP_ERROR )

Definition at line 49 of file tpi_tnycthrd.c.

Referenced by createThreadPool().

◆ SCIPtnyDestroyCondition

#define SCIPtnyDestroyCondition (   condition)    ( cnd_destroy(condition) )

Definition at line 50 of file tpi_tnycthrd.c.

Referenced by freeThreadPool().

◆ SCIPtnySignalCondition

#define SCIPtnySignalCondition (   condition)    ( cnd_signal(condition) == thrd_success ? SCIP_OKAY : SCIP_ERROR )

Definition at line 51 of file tpi_tnycthrd.c.

Referenced by jobQueueAddJob().

◆ SCIPtnyBroadcastCondition

#define SCIPtnyBroadcastCondition (   condition)    ( cnd_broadcast(condition) == thrd_success ? SCIP_OKAY : SCIP_ERROR )

Definition at line 52 of file tpi_tnycthrd.c.

Referenced by freeThreadPool().

◆ SCIPtnyWaitCondition

#define SCIPtnyWaitCondition (   condition,
  lock 
)    ( cnd_wait((condition), (lock)) == thrd_success ? SCIP_OKAY: SCIP_ERROR )

Definition at line 53 of file tpi_tnycthrd.c.

Referenced by freeThreadPool().

Typedef Documentation

◆ SCIP_THREADPOOL

Definition at line 68 of file tpi_tnycthrd.c.

◆ SCIP_JOBQUEUE

typedef struct SCIP_JobQueue SCIP_JOBQUEUE

Definition at line 89 of file tpi_tnycthrd.c.

Function Documentation

◆ threadPoolThreadRetcode()

static SCIP_RETCODE threadPoolThreadRetcode ( void *  threadnum)
static

this function controls the execution of each of the threads

Parameters
threadnumthread number is passed in as argument stored inside a void pointer

Definition at line 122 of file tpi_tnycthrd.c.

Referenced by threadPoolThread().

◆ threadPoolThread()

static int threadPoolThread ( void *  threadnum)
static

this function controls the execution of each of the threads

Parameters
threadnumthread number is passed in as argument stored inside a void pointer

Definition at line 249 of file tpi_tnycthrd.c.

References threadPoolThreadRetcode().

Referenced by createThreadPool().

◆ createThreadPool()

static SCIP_RETCODE createThreadPool ( SCIP_THREADPOOL **  thrdpool,
int  nthreads,
int  qsize,
SCIP_Bool  blockwhenfull 
)
static

creates a threadpool

Parameters
thrdpoolpointer to store threadpool
nthreadsnumber of threads in the threadpool
qsizemaximum size of the jobqueue
blockwhenfullshould the jobqueue block if it is full

Definition at line 258 of file tpi_tnycthrd.c.

References BMSallocMemory, BMSallocMemoryArray, FALSE, NULL, SCIP_ALLOC, SCIP_CALL, SCIP_ERROR, SCIPtnyInitCondition, SCIPtnyInitLock, threadPoolThread(), and TRUE.

◆ jobQueueAddJob()

static void jobQueueAddJob ( SCIP_THREADPOOL threadpool,
SCIP_JOB newjob 
)
static

adding a job to the job queue.

This gives some more flexibility in the handling of new jobs. This function needs to be called from within a mutex.

Parameters
threadpoolpointer to store threadpool
newjobpointer to new job

Definition at line 334 of file tpi_tnycthrd.c.

References SCIP_JobQueue::firstjob, SCIP_ThreadPool::jobqueue, SCIP_JobQueue::lastjob, SCIP_Job::nextjob, SCIP_JobQueue::njobs, NULL, SCIP_ThreadPool::queuenotempty, SCIP_ThreadPool::queuesize, SCIP_CALL_ABORT, and SCIPtnySignalCondition.

◆ threadPoolAddWork()

static SCIP_RETCODE threadPoolAddWork ( SCIP_JOB newjob,
SCIP_SUBMITSTATUS status 
)
static

adds a job to the threadpool

Parameters
newjobjob to add to threadpool
statuspointer to store the job's submit status

Definition at line 366 of file tpi_tnycthrd.c.

References NULL.

◆ freeJobQueue()

static void freeJobQueue ( SCIP_THREADPOOL thrdpool)
static

frees the jobqueue of the threadpool

Parameters
thrdpoolpointer to thread pool

Definition at line 423 of file tpi_tnycthrd.c.

References BMSfreeMemory, SCIP_JobQueue::firstjob, SCIP_ThreadPool::jobqueue, SCIP_JobQueue::lastjob, SCIP_Job::nextjob, NULL, SCIP_ThreadPool::queueopen, and SCIP_ThreadPool::shutdown.

Referenced by freeThreadPool().

◆ freeThreadPool()

static SCIP_RETCODE freeThreadPool ( SCIP_THREADPOOL **  thrdpool,
SCIP_Bool  finishjobs,
SCIP_Bool  completequeue 
)
static

free the thread pool

Parameters
thrdpoolpointer to thread pool
finishjobscurrently unused
completequeueWait until the queue has complete?

Definition at line 448 of file tpi_tnycthrd.c.

References BMSfreeMemory, BMSfreeMemoryArray, FALSE, freeJobQueue(), MIN, SCIP_CALL, SCIP_ERROR, SCIP_OKAY, SCIP_UNUSED, SCIPtnyAcquireLock, SCIPtnyBroadcastCondition, SCIPtnyDestroyCondition, SCIPtnyDestroyLock, SCIPtnyReleaseLock, SCIPtnyWaitCondition, and TRUE.

◆ checkJobQueue()

static SCIP_JOBSTATUS checkJobQueue ( SCIP_JOBQUEUE jobqueue,
int  jobid 
)
static
Parameters
jobqueuepointer to the job queue
jobidid of job to check

Definition at line 534 of file tpi_tnycthrd.c.

References SCIP_JobQueue::firstjob, SCIP_Job::jobid, SCIP_JobQueue::lastjob, SCIP_Job::nextjob, NULL, SCIP_JOB_DOESNOTEXIST, and SCIP_JOB_INQUEUE.

Referenced by isJobRunning().

◆ isJobRunning()

static SCIP_Bool isJobRunning ( SCIP_JOBQUEUE currentjobs,
int  jobid 
)
static

returns whether the job id is running

Parameters
currentjobsqueue of current jobs
jobidid of job to check

Definition at line 561 of file tpi_tnycthrd.c.

References checkJobQueue(), FALSE, SCIP_JOB_INQUEUE, and TRUE.

◆ SCIPtpiGetNumThreads()

int SCIPtpiGetNumThreads ( void  )

returns the number of threads

Definition at line 573 of file tpi_tnycthrd.c.

◆ SCIPtpiInit()

SCIP_RETCODE SCIPtpiInit ( int  nthreads,
int  queuesize,
SCIP_Bool  blockwhenfull 
)

initializes tpi

Parameters
nthreadsthe number of threads to be used
queuesizethe size of the queue
blockwhenfullshould the queue block when full

Definition at line 581 of file tpi_tnycthrd.c.

Referenced by SCIPsyncstoreInit().

◆ SCIPtpiExit()

SCIP_RETCODE SCIPtpiExit ( void  )

deinitializes tpi

Definition at line 593 of file tpi_tnycthrd.c.

Referenced by SCIPsyncstoreExit().

◆ SCIPtpiCreateJob()

SCIP_RETCODE SCIPtpiCreateJob ( SCIP_JOB **  job,
int  jobid,
SCIP_RETCODE(*)(void *args)  jobfunc,
void *  jobarg 
)

creates a job for parallel processing

Parameters
jobpointer to the job that will be created
jobidthe id for the current job
jobfuncpointer to the job function
jobargthe job's argument

Definition at line 605 of file tpi_tnycthrd.c.

References BMSallocMemory, NULL, SCIP_ALLOC, and SCIP_OKAY.

Referenced by SCIPconcurrentSolve().

◆ SCIPtpiGetNewJobID()

int SCIPtpiGetNewJobID ( void  )

get a new job id for the new set of submitted jobs

Definition at line 623 of file tpi_tnycthrd.c.

Referenced by SCIPconcurrentSolve().

◆ SCIPtpiSubmitJob()

SCIP_RETCODE SCIPtpiSubmitJob ( SCIP_JOB job,
SCIP_SUBMITSTATUS status 
)

submit a job for parallel processing; the return value is a globally defined status

Parameters
jobpointer to the job to be submitted
statuspointer to store the job's submit status

Definition at line 638 of file tpi_tnycthrd.c.

References SCIP_Job::jobid, and NULL.

Referenced by SCIPconcurrentSolve().

◆ SCIPtpiCollectJobs()

SCIP_RETCODE SCIPtpiCollectJobs ( int  jobid)

blocks until all jobs of the given jobid have finished and then returns the smallest SCIP_RETCODE of all the jobs

Parameters
jobidthe jobid of the jobs to wait for

Definition at line 655 of file tpi_tnycthrd.c.

References SCIP_CALL, and SCIPtnyAcquireLock.

Referenced by SCIPconcurrentSolve().

◆ SCIPtpiInitLock()

SCIP_RETCODE SCIPtpiInitLock ( SCIP_LOCK **  lock)

initializes the given lock

Parameters
lockthe lock

Definition at line 726 of file tpi_tnycthrd.c.

References BMSallocMemory, BMSfreeMemory, NULL, SCIP_ALLOC, SCIP_ERROR, and SCIP_OKAY.

Referenced by SCIPsyncstoreCreate(), and SCIPsyncstoreInit().

◆ SCIPtpiDestroyLock()

void SCIPtpiDestroyLock ( SCIP_LOCK **  lock)

destroys the given lock

Parameters
lockthe lock

Definition at line 744 of file tpi_tnycthrd.c.

References BMSfreeMemory, and NULL.

Referenced by SCIPsyncstoreExit(), and SCIPsyncstoreRelease().

◆ SCIPtpiAcquireLock()

SCIP_RETCODE SCIPtpiAcquireLock ( SCIP_LOCK lock)

◆ SCIPtpiReleaseLock()

SCIP_RETCODE SCIPtpiReleaseLock ( SCIP_LOCK lock)

◆ SCIPtpiInitCondition()

SCIP_RETCODE SCIPtpiInitCondition ( SCIP_CONDITION **  condition)

initializes the given condition variable

Parameters
conditioncondition to be created and initialized

Definition at line 780 of file tpi_tnycthrd.c.

References BMSallocMemory, NULL, SCIP_ALLOC, SCIP_ERROR, and SCIP_OKAY.

Referenced by SCIPsyncstoreInit().

◆ SCIPtpiDestroyCondition()

void SCIPtpiDestroyCondition ( SCIP_CONDITION **  condition)

destroys the given condition variable

Parameters
conditioncondition to be destroyed and freed

Definition at line 794 of file tpi_tnycthrd.c.

References BMSfreeMemory.

Referenced by SCIPsyncstoreExit().

◆ SCIPtpiSignalCondition()

SCIP_RETCODE SCIPtpiSignalCondition ( SCIP_CONDITION condition)

signals one waiting thread

Parameters
conditionthe condition variable to signal

Definition at line 803 of file tpi_tnycthrd.c.

References SCIP_Condition::condition, SCIP_ERROR, and SCIP_OKAY.

◆ SCIPtpiBroadcastCondition()

SCIP_RETCODE SCIPtpiBroadcastCondition ( SCIP_CONDITION condition)

signals all waiting threads

Parameters
conditionthe condition variable to broadcast

Definition at line 814 of file tpi_tnycthrd.c.

References SCIP_Condition::condition, SCIP_ERROR, and SCIP_OKAY.

Referenced by SCIPsyncstoreFinishSync().

◆ SCIPtpiWaitCondition()

SCIP_RETCODE SCIPtpiWaitCondition ( SCIP_CONDITION condition,
SCIP_LOCK lock 
)

waits on a condition variable. The given lock must be held by the caller and will be held when this function returns.

Parameters
conditionthe condition variable to wait on
lockthe lock that is held by the caller

Definition at line 826 of file tpi_tnycthrd.c.

References SCIP_Condition::condition, SCIP_Lock::lock, SCIP_ERROR, and SCIP_OKAY.

Referenced by SCIPsyncstoreEnsureAllSynced().

◆ SCIPtpiGetThreadNum()

int SCIPtpiGetThreadNum ( void  )

returns the thread number

Definition at line 837 of file tpi_tnycthrd.c.

Referenced by applyBoundChanges(), and execConcsolver().