53 #ifndef _UCOMMON_THREAD_H_
54 #define _UCOMMON_THREAD_H_
56 #ifndef _UCOMMON_CPR_H_
60 #ifndef _UCOMMON_ACCESS_H_
64 #ifndef _UCOMMON_TIMERS_H_
68 #ifndef _UCOMMON_MEMORY_H_
91 #if defined(_MSCONDITIONAL_)
92 CRITICAL_SECTION mutex;
93 CONDITION_VARIABLE cond;
94 #elif defined(_MSWINDOWS_)
95 enum {SIGNAL = 0, BROADCAST = 1};
98 CRITICAL_SECTION mlock;
99 CRITICAL_SECTION mutex;
102 class __LOCAL attribute
105 pthread_condattr_t attr;
109 __LOCAL
static attribute attr;
113 pthread_mutex_t mutex;
131 bool wait(
struct timespec *timeout);
134 inline void lock(
void)
135 {EnterCriticalSection(&mutex);};
138 {LeaveCriticalSection(&mutex);};
142 void broadcast(
void);
149 {pthread_mutex_lock(&mutex);};
155 {pthread_mutex_unlock(&mutex);};
161 {pthread_cond_wait(&cond, &mutex);};
167 {pthread_cond_signal(&cond);};
173 {pthread_cond_broadcast(&cond);};
187 #if !defined(_MSWINDOWS_) && !defined(__PTH__)
194 {
return &attr.attr;};
203 static void set(
struct timespec *hires,
timeout_t timeout);
216 #if defined _MSCONDITIONAL_
217 CONDITION_VARIABLE bcast;
218 #elif !defined(_MSWINDOWS_)
219 pthread_cond_t bcast;
222 unsigned pending, waiting, sharing;
244 bool waitSignal(
struct timespec *timeout);
251 bool waitBroadcast(
struct timespec *timeout);
264 inline void lock(
void)
265 {EnterCriticalSection(&mutex);};
268 {LeaveCriticalSection(&mutex);};
270 void waitSignal(
void);
271 void waitBroadcast(
void);
284 {pthread_mutex_lock(&mutex);};
290 {pthread_mutex_unlock(&mutex);};
296 {pthread_cond_wait(&cond, &mutex);};
302 {pthread_cond_wait(&bcast, &mutex);};
309 {pthread_cond_signal(&cond);};
315 {pthread_cond_broadcast(&bcast);};
354 void limit_sharing(
unsigned max);
374 pthread_mutex_t mutex;
461 virtual void _lock(
void);
462 virtual void _unlock(
void);
504 virtual void _lock(
void);
505 virtual void _share(
void);
506 virtual void _unlock(
void);
544 void set(
const void *
object);
595 void set(
const void *
object);
636 static void indexing(
unsigned size);
645 static bool writer(
const void *
object,
timeout_t timeout = Timer::inf);
654 static bool reader(
const void *
object,
timeout_t timeout = Timer::inf);
660 static void release(
const void *
object);
728 virtual void _share(
void);
729 virtual void _unlock(
void);
731 Context *getContext(
void);
773 virtual void share(
void);
811 void set(
unsigned count);
827 unsigned operator++(
void);
829 unsigned operator--(
void);
856 unsigned count, waits, used;
858 virtual void _share(
void);
859 virtual void _unlock(
void);
873 Semaphore(
unsigned count,
unsigned avail);
894 void set(
unsigned count);
930 pthread_mutex_t mlock;
932 virtual void _lock(
void);
933 virtual void _unlock(
void);
959 guard(
const void *
object);
971 void set(
const void *
object);
1002 {pthread_mutex_lock(&mlock);};
1008 {pthread_mutex_lock(&mlock);};
1014 {pthread_mutex_unlock(&mlock);};
1020 {pthread_mutex_unlock(&mlock);};
1027 {pthread_mutex_lock(lock);};
1034 {pthread_mutex_unlock(lock);};
1042 static void indexing(
unsigned size);
1049 static void protect(
const void *
pointer);
1100 {
return object == NULL;};
1106 inline operator bool()
const
1107 {
return object != NULL;};
1115 void operator=(
const void *
object);
1133 pthread_mutex_t mutex;
1266 Thread(
size_t stack = 0);
1277 virtual bool is_active(
void);
1286 void setPriority(
void);
1292 static void yield(
void);
1306 static Thread *
get(void);
1311 virtual void run(
void) = 0;
1326 virtual void exit(
void);
1331 static void init(
void);
1338 static void policy(
int polid);
1344 static void concurrency(
int level);
1352 static bool equal(pthread_t thread1, pthread_t thread2);
1358 static pthread_t
self(void);
1360 inline operator bool()
1361 {
return is_active();}
1363 inline bool operator!()
1364 {
return !is_active();}
1366 inline bool isRunning(
void)
1367 {
return is_active();}
1386 volatile bool running;
1388 volatile bool joining;
1411 virtual void run(
void) = 0;
1423 void start(
int priority = 0);
1470 virtual void run(
void) = 0;
1479 void start(
int priority = 0);
1626 {SharedPointer::replace(
object);};
1672 {LockedPointer::replace(
object);};
1715 {
return *(
static_cast<T&
>(object));};
1722 {
return static_cast<T*
>(object);};
1728 inline T*
get(void)
const
1729 {
return static_cast<T*
>(object);};
1757 {
return *(
static_cast<const T&
>(ptr->pointer));};
1764 {
return static_cast<const T*
>(ptr->pointer);};
1770 inline const T*
get(void)
const
1771 {
return static_cast<const T*
>(ptr->pointer);};
1800 {
return *(
static_cast<T&
>(auto_protect::object));};
1807 {
return static_cast<T*
>(auto_protect::object);};
1813 inline T*
get(void)
const
1814 {
return static_cast<T*
>(auto_protect::object);};
1823 {thread->
start(priority);}
1831 {thread->
start(priority);}
1886 {semaphore.
wait(timeout);}
1987 {
return lock.
modify(timeout);}
1995 {
return lock.
access(timeout);}
2018 inline bool _sync_protect_(
const void *obj)
2020 Mutex::protect(obj);
2024 inline bool _sync_release_(
const void *obj)
2030 inline bool _rw_reader_(
const void *obj)
2032 ThreadLock::reader(obj);
2036 inline bool _rw_writer_(
const void *obj)
2038 ThreadLock::writer(obj);
2042 inline bool _rw_release_(
const void *obj)
2048 #define ENTER_EXCLUSIVE \
2049 do { static pthread_mutex_t __sync__ = PTHREAD_MUTEX_INITIALIZER; \
2050 pthread_mutex_lock(&__sync__);
2052 #define LEAVE_EXCLUSIVE \
2053 pthread_mutex_unlock(&__sync__);} while(0);
2055 #define SYNC(obj) for(bool _sync_flag_ = _sync_protect_(obj); _sync_flag_; _sync_flag_ = _sync_release_(obj))
2057 #define SHARED(obj) for(bool _sync_flag_ = _rw_reader_(obj); _sync_flag_; _sync_flag_ = _rw_release_(obj))
2059 #define EXCLUSIVE(obj) for(bool _sync_flag_ = _rw_writer_(obj); _sync_flag_; _sync_flag_ = _rw_release_(obj))
locked_pointer()
Create an instance of a typed locked pointer.
void wait(void)
Wait at the barrier until the count of threads waiting is reached.
void operator--(void)
Convenience operator to release a counting semaphore.
void acquire(mutex_t &mutex)
Convenience function to acquire a mutex.
An exclusive locking access interface base.
Semaphore semaphore_t
Convenience type for using counting semaphores.
void exclusive(SharedAccess &object)
Convenience function to exclusive lock shared object through it's protocol.
void operator=(T *object)
Replace existing object through assignment.
void broadcast(void)
Signal the conditional to release all waiting threads.
void wait(void)
Wait until the semphore usage count is less than the thread limit.
void operator=(void *pointer)
Set guard to mutex lock a new object.
Templated shared pointer for singleton shared objects of specific type.
An object pointer that uses mutex to assure thread-safe singleton use.
void wait(void)
Wait (block) until signalled.
T * dup(void)
Create a duplicate reference counted instance of the current typed object.
A common base class for all managed objects.
An optimized and convertable shared lock.
An abstract class for defining classes that operate as a thread.
virtual void share(void)
Return an exclusive access lock back to share mode.
shared_pointer()
Created shared locking for typed singleton pointer.
void modify(void)
Acquire write (exclusive modify) lock.
static void sync(Timer &timer)
Sleep current thread until the specified timer expires.
void waitBroadcast(void)
Wait (block) until broadcast.
void operator=(const void *pointer)
Set guard to read lock a new object.
void access(void)
Access mode shared thread scheduling.
void waitSignal(void)
Wait (block) until signalled.
void release(SharedAccess &object)
Convenience function to unlock shared object through it's protocol.
Guard class to apply scope based exclusive locking to objects.
A child thread object that may be joined by parent.
void unlock(void)
Release acquired lock.
void start(int priority=0)
Start execution of detached context.
ReusableObject * next(ReusableObject *object)
Get next reusable object in the pool.
virtual void run(void)=0
Abstract interface for thread context run method.
void unlock(void)
Unlock the conditional's supporting mutex.
void broadcast(void)
Signal the conditional to release all broadcast threads.
locked_instance()
Construct empty locked instance of typed object.
void release(void)
Release or decrease locking.
Auto-pointer support class for shared singleton objects.
Timer class to use when scheduling realtime events.
A templated smart pointer instance for shared singleton typed objects.
void signal(void)
Signal the conditional to release one signalled thread.
Auto-pointer support class for locked objects.
locked_instance(locked_pointer< T > &pointer)
Construct locked instance of typed object from matching locked_pointer.
Typed smart locked pointer class.
static pthread_condattr_t * initializer(void)
Support function for getting conditional attributes for realtime scheduling.
Generic non-recursive exclusive lock class.
void lock(void)
Lock the conditional's supporting mutex.
void start(int priority=0)
Start execution of child context.
An exclusive locking protocol interface base.
Generic smart pointer class.
void operator=(const void *pointer)
Set guard to read lock a new object.
void background(void)
Start execution of child context as background thread.
void wait(barrier_t &barrier)
Convenience function to wait on a barrier.
void access(void)
Acquire access (shared read) lock.
ConditionalLock condlock_t
Convenience type for using conditional locks.
void start(JoinableThread *thread, int priority=0)
Convenience function to start a joinable thread.
Common base class for all objects that can be formed into a linked list.
mutex_pointer()
Create a pointer with no reference.
shared_instance(shared_pointer< T > &pointer)
Construct shared access instance of shared typed singleton from matching shared_pointer.
The shared pointer is used to manage a singleton instance of shared object.
The conditional rw seperates scheduling for optizming behavior or rw locks.
mutex_pointer(T *object)
Create a pointer with a reference to a heap object.
void lock(void)
Acquire mutex lock.
T & operator*() const
Reference object we are pointing to through pointer indirection.
A portable implimentation of "barrier" thread sychronization.
void replace(T *object)
Replace existing typed singleton instance with new one.
virtual void _share(void)=0
Access interface to share lock the object.
void unlock(ExclusiveAccess &object)
Convenience function to unlock an exclusive object through it's protocol.
void release(void)
Release the semaphore after waiting for it.
Class for resource bound memory pools between threads.
A mutex locked object smart pointer helper class.
void signal(void)
Signal the conditional to release one waiting thread.
virtual void exclusive(void)
Convert read lock into exclusive (write/modify) access.
void commit(accesslock_t &lock)
Convenience function to commit an exclusive access lock.
void operator++(void)
Convenience operator to wait on a counting semaphore.
Guard class to apply scope based mutex locking to objects.
Locking protocol classes for member function automatic operations.
Guard class to apply scope based access locking to objects.
static void release(const void *object)
Release an arbitrary object that has been protected by a rwlock.
void replace(T *object)
Replace existing typed object with a new one for next request.
A portable counting semaphore class.
T &() max(T &o1, T &o2)
Convenience function to return max of two objects.
bool access(timeout_t timeout=Timer::inf)
Request shared (read) access through the lock.
static void set(struct timespec *hires, timeout_t timeout)
Convert a millisecond timeout into use for high resolution conditional timers.
A detached thread object that is stand-alone.
Mutex mutex_t
Convenience type for using exclusive mutex locks.
static void release(pthread_mutex_t *lock)
Convenience function to release os native mutex lock directly.
void lock(void)
Acquire or increase locking.
void release(void)
Release access mode read scheduling.
void modify(void)
Exclusive mode write thread scheduling.
Event notification to manage scheduled realtime threads.
const T & operator*() const
Access shared typed singleton object this instance locks and references.
ReusableObject * getNext(void)
Get next effective reusable object when iterating.
SharedPointer * ptr
Shared lock for protected singleton.
Templated locked pointer for referencing locked objects of specific type.
static const time_t reset
A value to use when resetting.
ConditionalAccess accesslock_t
Convenience type for scheduling access.
virtual bool is_active(void)
Check if running.
The conditional is a common base for other thread synchronizing classes.
virtual void exit(void)
Exit the thread context.
shared_instance()
Construct empty instance to reference shared typed singleton.
T & operator*() const
Extract instance of locked typed object by pointer reference.
void commit(void)
Complete exclusive mode write scheduling.
RecursiveMutex rexlock_t
Convenience type for using recursive exclusive locks.
Reusable objects for forming private heaps.
T * operator->() const
Access member of instance of locked typed object by member reference.
void operator=(ObjectProtocol *object)
Replace existing object through assignment.
ThreadLock rwlock_t
Convenience type for using read/write locks.
void acquire(void)
Acquire mutex lock.
Portable recursive exclusive lock.
A general purpose smart pointer helper class.
T * operator*()
Access shared lock typed singleton object by pointer reference.
Private heaps, pools, and associations.
const T * operator->() const
Access member of shared typed singleton object this instance locks and references.
void unlock(void)
Unlock the conditional's supporting mutex.
A generic and portable implimentation of Read/Write locking.
void commit(void)
Commit changes / release a modify lock.
T * operator*()
Create a duplicate reference counted instance of the current typed object by pointer reference...
void share(SharedAccess &object)
Convenience function to restore shared locking for object through it's protocol.
bool operator!() const
Test if the pointer is not set.
T * operator->() const
Reference member of object we are pointing to.
barrier barrier_t
Convenience type for using thread barriers.
void operator=(T *object)
Replace existing typed singleton object through assignment.
A templated smart pointer instance for lock protected objects.
void release(void)
Release a shared lock.
TimedEvent timedevent_t
Convenience type for using timed events.
void modify(accesslock_t &lock)
Convenience function to exclusively schedule conditional access.
void lock(void)
Lock the conditional's supporting mutex.
Realtime timers and timer queues.
T * dup(const T &object)
Convenience function to duplicate object pointer to heap.
void access(SharedAccess &object)
Convenience function to access (lock) shared object through it's protocol.
T * init(T *memory)
Template function to initialize memory by invoking default constructor.
bool modify(timeout_t timeout=Timer::inf)
Request modify (write) access through the lock.
static void acquire(pthread_mutex_t *lock)
Convenience function to acquire os native mutex lock directly.
unsigned long timeout_t
Typedef for millisecond timer values.
void lock(ExclusiveAccess &object)
Convenience function to exclusively lock an object through it's protocol.
ObjectProtocol * object
locked object protected by locked_release
static void set(struct timespec *hires, timeout_t timeout)
Convert a millisecond timeout into use for high resolution conditional timers.
const T * dup(void)
Acquire a shared (duplocate) reference to the typed singleton object.
void release(void)
Release acquired lock.