我是线程新手,我想弄明白,为什么在这个带队列的线程池的实现中有一个互斥锁(dstrymutex) 它在c文件中定义,而不是作为所有其他互斥锁的struct threadpool的一部分。是否有一个原因? 虽然我们在这里,我很想知道正确的地方来声明正在使用的互斥量,就像在这里使用它们一样。 非常感谢!
这是代码: h文件:
#ifndef __THREAD_POOL__
#define __THREAD_POOL__
#include <pthread.h>
#include <stdio.h>
#include <stdlib.h>
#include <unistd.h>
#include "osqueue.h"
#define FAILURE -1
#define SUCCESS 0
#define DONT_WAIT_FOR_TASKS 0
typedef struct thread_pool
{
//The field x is here because a struct without fields
//doesn't compile. Remove it once you add fields of your own
int numOfThreads;
pthread_t* threads;
struct os_queue* tasksQueue;
pthread_mutex_t lock;
pthread_mutex_t queueLock;
pthread_cond_t notify;
int stopped;
int canInsert;
}ThreadPool;
/**
* creates a thread pool struct.
* @param numOfThreads number of threads in the thread pool.
* @return reference to new thread pool struct if succeeded, NULL if failed.
*/
ThreadPool* tpCreate(int numOfThreads);
/**
* Destroys the thread pool.
* @param threadPool thread pool
* @param shouldWaitForTasks 0 - dont wait for tasks in the queue, else - wait for tasks.
*/
void tpDestroy(ThreadPool* threadPool, int shouldWaitForTasks);
/**
* inserts a task to the tasks queue of the thread pool.
* @param threadPool thread pool
* @param computeFunc task
* @param param argument to the task
* @return 0- success , -1 - fail
*/
int tpInsertTask(ThreadPool* threadPool, void (*computeFunc) (void *), void* param);
#endif
c file:
#include <fcntl.h>
#include "threadPool.h"
#define STDERR_FD 2
#define SYS_CALL_FAILURE 10
pthread_mutex_t destryLock;
typedef struct task
{
void (*computeFunc)(void *param);
void* param;
}Task;
/**
* prints error in sys call to stderr.
*/
void printErrorInSysCallToSTDERR() {
char error_msg[] = "Error in system call\n";
write(STDERR_FD, error_msg, sizeof(error_msg));
}
/**
* threads function. tasks are taken and executed by the threads in the thread pool from the tasks queue.
* @param args expected ThreadPool*
* @return void
*/
void* execute(void* args) {
ThreadPool* tp = (ThreadPool*)args;
struct os_queue* taskQueue = tp->tasksQueue;
printf("New thread was created\n");
while (!tp->stopped && !(tp->canInsert == 0 && osIsQueueEmpty(taskQueue))) {
/* Lock must be taken to wait on conditional variable */
pthread_mutex_lock(&(tp->queueLock));
/* Wait on condition variable, check for spurious wakeups.
When returning from pthread_cond_wait(), we own the lock. */
if((osIsQueueEmpty(taskQueue)) && (!tp->stopped)) {
printf("Busy\n");
pthread_cond_wait(&(tp->notify), &(tp->queueLock));
}
pthread_mutex_unlock(&(tp->queueLock));
pthread_mutex_lock(&(tp->lock));
if (!(osIsQueueEmpty(taskQueue))) {
// take task from the queue
Task* task = osDequeue(taskQueue);
pthread_mutex_unlock(&(tp->lock));
// execute task
task->computeFunc(task->param);
free(task);
}
else {
pthread_mutex_unlock(&(tp->lock));
}
}
}
/**
* creates a thread pool struct.
* @param numOfThreads number of threads in the thread pool.
* @return reference to new thread pool struct if succeeded, NULL if failed.
*/
ThreadPool* tpCreate(int numOfThreads) {
int out = open("output", O_CREAT | O_TRUNC | O_WRONLY, 0644);
if (out == -1) {
printf("Failed to open output file\n");
printErrorInSysCallToSTDERR();
exit(SYS_CALL_FAILURE);
}
// replace standard output with output file
if (dup2(out, STDOUT_FILENO) == -1) {
printf("Failed to operate dup2 for out\n");
printErrorInSysCallToSTDERR();
exit(SYS_CALL_FAILURE);
}
ThreadPool* tp = (ThreadPool*)malloc(sizeof(ThreadPool));
if (tp == NULL) {
printf("Failure: allocate memory for thread pool struct");
return NULL;
}
tp->numOfThreads = numOfThreads;
tp->threads = (pthread_t*)malloc(sizeof(pthread_t) * tp->numOfThreads);
if (tp->threads == NULL) {
printf("Failure: allocate memory for threads array");
return NULL;
}
tp->tasksQueue = osCreateQueue();
pthread_mutex_init(&(tp->lock), NULL);
tp->stopped = 0;
tp->canInsert = 1;
if (pthread_mutex_init(&(tp->queueLock), NULL) != 0 ||
pthread_mutex_init(&(tp->queueLock), NULL) != 0 ||
pthread_cond_init(&(tp->notify), NULL) != 0) {
printf("Failure: initialize one required mutex or more\n");
tpDestroy(tp, 0);
return NULL;
}
int i;
for (i = 0; i < tp->numOfThreads; i++) {
if(pthread_create(&(tp->threads[i]), NULL, execute, (void *)tp) != 0) {
printf("Failure: creating a thread failed.\n");
}
}
return tp;
}
/**
* inserts a task to the tasks queue of the thread pool.
* @param threadPool thread pool
* @param computeFunc task
* @param param argument to the task
* @return 0- success , -1 - fail
*/
int tpInsertTask(ThreadPool* threadPool, void (*computeFunc) (void *), void* param) {
if(threadPool == NULL || computeFunc == NULL) {
return FAILURE;
}
if (!(threadPool->canInsert)) {
return FAILURE;
}
Task* task = (Task*)malloc(sizeof(Task));
if (task == NULL) {
printf("Failure: allocate memory for threads array");
return FAILURE;
}
task->computeFunc = computeFunc;
task->param = param;
osEnqueue(threadPool->tasksQueue, (void *)task);
pthread_mutex_lock(&(threadPool->queueLock));
// wake up thread that wait as long as the tasks queue is empty
if(pthread_cond_signal(&(threadPool->notify)) != 0) {
printf("Failure: signal opertion in tpInsertTask\n");
}
pthread_mutex_unlock(&(threadPool->queueLock));
return SUCCESS;
}
/**
* Destroys the thread pool.
* @param threadPool thread pool
* @param shouldWaitForTasks 0 - dont wait for tasks in the queue, else - wait for tasks.
*/
void tpDestroy(ThreadPool* threadPool, int shouldWaitForTasks) {
if (threadPool == NULL) {
return;
}
pthread_mutex_lock(&destryLock);
// first time enter to tpDestory with valid thread pool
if ( threadPool->canInsert != 0) {
threadPool->canInsert = 0;
// make sure tpDestroy will ne called only once for thr thread pool
} else {
return;
}
pthread_mutex_unlock(&destryLock);
if (shouldWaitForTasks == DONT_WAIT_FOR_TASKS) {
threadPool->stopped = 1;
}
int i, err;
pthread_mutex_lock(&(threadPool->queueLock));
/* Wake up all worker threads */
if((pthread_cond_broadcast(&(threadPool->notify)) != 0) ||
(pthread_mutex_unlock(&(threadPool->queueLock)) != 0)) {
printf("Exit due failure in tpDestory\n");
exit(1);
}
for (i = 0; i < threadPool->numOfThreads; i++) {
err = pthread_join(threadPool->threads[i], NULL);
if (err != 0) {
printf("Failure: waiting for thread no. %d\n", i);
}
}
threadPool->stopped = 1;
//free memory
while (!osIsQueueEmpty(threadPool->tasksQueue)) {
printf("Task was erased from tasks queue\n");
Task* task = osDequeue(threadPool->tasksQueue);
free(task);
}
osDestroyQueue(threadPool->tasksQueue);
free(threadPool->threads);
pthread_mutex_destroy(&(threadPool->lock));
pthread_mutex_destroy(&(threadPool->queueLock));
pthread_mutex_destroy(&destryLock);
free(threadPool);
}
答案 0 :(得分:2)
从代码中可以清楚地看出destryLock
互斥锁的意图是什么,特别是因为它没有使用PTHREAD_MUTEX_INITIALIZER
静态初始化程序初始化,也没有使用pthread_mutex_init
进行初始化。但是,在tpDestroy
函数中,它已被销毁,因此对pthread_mutex_lock
的任何调用都可能产生EINVAL
错误。
话虽如此,基于tpDestroy
看起来假设要做的事情,也就是说,销毁用tpCreate
创建的线程池对象,它不清楚编码逻辑的意图;应该注意的是,这可以发生死锁情况:
pthread_mutex_lock(&destryLock);
// first time enter to tpDestory with valid thread pool
if ( threadPool->canInsert != 0) {
threadPool->canInsert = 0;
// make sure tpDestroy will ne called only once for thr thread pool
} else {
return; // dead lock since not unlocking after having locked
}
pthread_mutex_unlock(&destryLock);
这使人们相信这段代码是由一个不完全理解多线程的人构建的(至少部分),或者不太明白设计如何适应线程池。
将destryLock
互斥体置于线程池结构本身是有意义的,因为该函数在传入的线程池对象上运行,而不是在全局线程池对象上运行。
我很想知道正确的地方来声明正在使用的互斥量,就像在这里使用它们一样。
考虑到您对多线程和同步原语的理解,这个问题有点宽泛,相反,我会专注于为什么你想要一个mutex而不是你想要它
互斥锁允许多个线程阻止代码区域,这样一次只有一个线程可以访问代码。这样做是因为在多核系统上完全有可能让多个线程同时访问相同的数据,从而导致竞争条件发生,从而发生未定义的行为。
如果要阻止来自多个线程的代码,那么 where 可以变得更加清晰,因为您将能够确定互斥锁是否应该是全局/本地静态对象,或者它应该是成员对象。
举个例子,假设我和一群敌人玩游戏;我可能会将这些敌人保留在某种列表中。当我想迭代敌人列表时,比如碰撞检测,AI或其他游戏效果,如果我的游戏中有多个线程作用于敌人列表,我可能需要一个互斥锁来锁定整个列表无论敌人的游戏逻辑是什么,所以敌人的状态对于所有线程都是准确的。然而,这可能不是最佳选择,因为它可能会引入滞后;相反,我可能想要在每个敌人身上使用互斥锁,并且只能锁定受逻辑影响的敌人。
所以更多的是关于你想要保护的具有可变状态的对象。
我希望可以提供帮助。