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);
886 void set(
unsigned count);
922 pthread_mutex_t mlock;
924 virtual void _lock(
void);
925 virtual void _unlock(
void);
951 guard(
const void *
object);
963 void set(
const void *
object);
994 {pthread_mutex_lock(&mlock);};
1000 {pthread_mutex_lock(&mlock);};
1006 {pthread_mutex_unlock(&mlock);};
1012 {pthread_mutex_unlock(&mlock);};
1019 {pthread_mutex_lock(lock);};
1026 {pthread_mutex_unlock(lock);};
1034 static void indexing(
unsigned size);
1041 static void protect(
const void *
pointer);
1092 {
return object == NULL;};
1098 inline operator bool()
const
1099 {
return object != NULL;};
1107 void operator=(
const void *
object);
1125 pthread_mutex_t mutex;
1258 Thread(
size_t stack = 0);
1269 virtual bool is_active(
void);
1278 void setPriority(
void);
1284 static void yield(
void);
1298 static Thread *
get(void);
1303 virtual void run(
void) = 0;
1318 virtual void exit(
void);
1323 static void init(
void);
1330 static void policy(
int polid);
1336 static void concurrency(
int level);
1344 static bool equal(pthread_t thread1, pthread_t thread2);
1350 static pthread_t
self(void);
1352 inline operator bool()
1353 {
return is_active();}
1355 inline bool operator!()
1356 {
return !is_active();}
1358 inline bool isRunning(
void)
1359 {
return is_active();}
1378 volatile bool running;
1380 volatile bool joining;
1403 virtual void run(
void) = 0;
1415 void start(
int priority = 0);
1462 virtual void run(
void) = 0;
1471 void start(
int priority = 0);
1618 {SharedPointer::replace(
object);};
1664 {LockedPointer::replace(
object);};
1707 {
return *(
static_cast<T&
>(object));};
1714 {
return static_cast<T*
>(object);};
1720 inline T*
get(void)
const
1721 {
return static_cast<T*
>(object);};
1749 {
return *(
static_cast<const T&
>(ptr->pointer));};
1756 {
return static_cast<const T*
>(ptr->pointer);};
1762 inline const T*
get(void)
const
1763 {
return static_cast<const T*
>(ptr->pointer);};
1792 {
return *(
static_cast<T&
>(auto_protect::object));};
1799 {
return static_cast<T*
>(auto_protect::object);};
1805 inline T*
get(void)
const
1806 {
return static_cast<T*
>(auto_protect::object);};
1815 {thread->
start(priority);}
1823 {thread->
start(priority);}
1878 {semaphore.
wait(timeout);}
1979 {
return lock.
modify(timeout);}
1987 {
return lock.
access(timeout);}
2010 inline bool _sync_protect_(
const void *obj)
2012 Mutex::protect(obj);
2016 inline bool _sync_release_(
const void *obj)
2022 inline bool _rw_reader_(
const void *obj)
2024 ThreadLock::reader(obj);
2028 inline bool _rw_writer_(
const void *obj)
2030 ThreadLock::writer(obj);
2034 inline bool _rw_release_(
const void *obj)
2040 #define ENTER_EXCLUSIVE \
2041 do { static pthread_mutex_t __sync__ = PTHREAD_MUTEX_INITIALIZER; \
2042 pthread_mutex_lock(&__sync__);
2044 #define LEAVE_EXCLUSIVE \
2045 pthread_mutex_unlock(&__sync__);} while(0);
2047 #define SYNC(obj) for(bool _sync_flag_ = _sync_protect_(obj); _sync_flag_; _sync_flag_ = _sync_release_(obj))
2049 #define SHARED(obj) for(bool _sync_flag_ = _rw_reader_(obj); _sync_flag_; _sync_flag_ = _rw_release_(obj))
2051 #define EXCLUSIVE(obj) for(bool _sync_flag_ = _rw_writer_(obj); _sync_flag_; _sync_flag_ = _rw_release_(obj))
void modify(void)
Acquire write (exclusive modify) lock.
Mutex mutex_t
Convenience type for using exclusive mutex locks.
void unlock(void)
Unlock the conditional's supporting mutex.
ObjectProtocol * object
locked object protected by locked_release
locked_instance()
Construct empty locked instance of typed object.
void operator=(void *pointer)
Set guard to mutex lock a new object.
void share(SharedAccess &object)
Convenience function to restore shared locking for object through it's protocol.
void lock(void)
Lock the conditional's supporting mutex.
A generic and portable implimentation of Read/Write locking.
const T * dup(void)
Acquire a shared (duplocate) reference to the typed singleton object.
An object pointer that uses mutex to assure thread-safe singleton use.
void wait(void)
Wait (block) until signalled.
void commit(void)
Commit changes / release a modify lock.
static void release(pthread_mutex_t *lock)
Convenience function to release os native mutex lock directly.
A templated smart pointer instance for shared singleton typed objects.
T * operator->() const
Access member of instance of locked typed object by member reference.
shared_instance()
Construct empty instance to reference shared typed singleton.
RecursiveMutex rexlock_t
Convenience type for using recursive exclusive locks.
bool modify(timeout_t timeout=Timer::inf)
Request modify (write) access through the lock.
bool operator!() const
Test if the pointer is not set.
void start(JoinableThread *thread, int priority=0)
Convenience function to start a joinable thread.
A templated smart pointer instance for lock protected objects.
T * dup(const T &object)
Convenience function to duplicate object pointer to heap.
bool access(timeout_t timeout=Timer::inf)
Request shared (read) access through the lock.
void operator=(T *object)
Replace existing object through assignment.
static void set(struct timespec *hires, timeout_t timeout)
Convert a millisecond timeout into use for high resolution conditional timers.
An exclusive locking access interface base.
void lock(ExclusiveAccess &object)
Convenience function to exclusively lock an object through it's protocol.
An exclusive locking protocol interface base.
A mutex locked object smart pointer helper class.
static void sync(Timer &timer)
Sleep current thread until the specified timer expires.
Class for resource bound memory pools between threads.
const T & operator*() const
Access shared typed singleton object this instance locks and references.
static void release(const void *object)
Release an arbitrary object that has been protected by a rwlock.
void access(void)
Access mode shared thread scheduling.
An optimized and convertable shared lock.
void waitSignal(void)
Wait (block) until signalled.
T * init(T *memory)
Template function to initialize memory by invoking default constructor.
shared_pointer()
Created shared locking for typed singleton pointer.
void operator=(ObjectProtocol *object)
Replace existing object through assignment.
void operator++(void)
Convenience operator to wait on a counting semaphore.
An abstract class for defining classes that operate as a thread.
ReusableObject * getNext(void)
Get next effective reusable object when iterating.
void operator=(T *object)
Replace existing typed singleton object through assignment.
void unlock(ExclusiveAccess &object)
Convenience function to unlock an exclusive object through it's protocol.
static pthread_condattr_t * initializer(void)
Support function for getting conditional attributes for realtime scheduling.
static void set(struct timespec *hires, timeout_t timeout)
Convert a millisecond timeout into use for high resolution conditional timers.
A child thread object that may be joined by parent.
void wait(void)
Wait at the barrier until the count of threads waiting is reached.
virtual void share(void)
Return an exclusive access lock back to share mode.
Guard class to apply scope based exclusive locking to objects.
Guard class to apply scope based mutex locking to objects.
unsigned long timeout_t
Typedef for millisecond timer values.
void unlock(void)
Unlock the conditional's supporting mutex.
TimedEvent timedevent_t
Convenience type for using timed events.
Auto-pointer support class for locked objects.
void operator--(void)
Convenience operator to release a counting semaphore.
T &() max(T &o1, T &o2)
Convenience function to return max of two objects.
void access(condlock_t &lock)
Convenience function for shared access to a conditional lock.
void wait(void)
Wait until the semphore usage count is less than the thread limit.
void exclusive(SharedAccess &object)
Convenience function to exclusive lock shared object through it's protocol.
A common base class for all managed objects.
void operator=(const void *pointer)
Set guard to read lock a new object.
shared_instance(shared_pointer< T > &pointer)
Construct shared access instance of shared typed singleton from matching shared_pointer.
void release(void)
Release a shared lock.
void waitBroadcast(void)
Wait (block) until broadcast.
ConditionalLock condlock_t
Convenience type for using conditional locks.
T * operator*()
Create a duplicate reference counted instance of the current typed object by pointer reference...
virtual void run(void)=0
Abstract interface for thread context run method.
Generic smart pointer class.
T * operator*()
Access shared lock typed singleton object by pointer reference.
Auto-pointer support class for shared singleton objects.
Realtime timers and timer queues.
A general purpose smart pointer helper class.
static void acquire(pthread_mutex_t *lock)
Convenience function to acquire os native mutex lock directly.
Portable recursive exclusive lock.
void release(void)
Release or decrease locking.
Generic non-recursive exclusive lock class.
void unlock(void)
Release acquired lock.
void broadcast(void)
Signal the conditional to release all waiting threads.
void wait(semaphore_t &semaphore, timeout_t timeout=Timer::inf)
Convenience function to wait on a semaphore.
static const time_t reset
A value to use when resetting.
void commit(accesslock_t &lock)
Convenience function to commit an exclusive access lock.
The conditional rw seperates scheduling for optizming behavior or rw locks.
void access(SharedAccess &object)
Convenience function to access (lock) shared object through it's protocol.
The shared pointer is used to manage a singleton instance of shared object.
mutex_pointer(T *object)
Create a pointer with a reference to a heap object.
void modify(void)
Exclusive mode write thread scheduling.
ConditionalAccess accesslock_t
Convenience type for scheduling access.
A portable implimentation of "barrier" thread sychronization.
void operator=(const void *pointer)
Set guard to read lock a new object.
void lock(void)
Acquire mutex lock.
T * operator->() const
Reference member of object we are pointing to.
void lock(rexlock_t &lock)
Convenience function to lock a shared recursive mutex lock.
void start(int priority=0)
Start execution of child context.
void broadcast(void)
Signal the conditional to release all broadcast threads.
T & operator*() const
Extract instance of locked typed object by pointer reference.
void replace(T *object)
Replace existing typed singleton instance with new one.
bool share(rwlock_t &lock, timeout_t timeout=Timer::inf)
Convenience function for shared read access to a read/write lock.
void background(void)
Start execution of child context as background thread.
void start(int priority=0)
Start execution of detached context.
void release(SharedAccess &object)
Convenience function to unlock shared object through it's protocol.
A portable counting semaphore class.
void modify(condlock_t &lock)
Convenience function to exclusively aquire a conditional lock.
Guard class to apply scope based access locking to objects.
virtual bool is_active(void)
Check if running.
Common base class for all objects that can be formed into a linked list.
void commit(condlock_t &lock)
Convenience function to commit and release an exclusively locked conditional lock.
A detached thread object that is stand-alone.
void release(void)
Release the semaphore after waiting for it.
Semaphore semaphore_t
Convenience type for using counting semaphores.
Templated shared pointer for singleton shared objects of specific type.
void lock(void)
Lock the conditional's supporting mutex.
virtual void exit(void)
Exit the thread context.
Event notification to manage scheduled realtime threads.
ReusableObject * next(ReusableObject *object)
Get next reusable object in the pool.
mutex_pointer()
Create a pointer with no reference.
void release(rexlock_t &lock)
Convenience function to release a shared recursive mutex lock.
locked_pointer()
Create an instance of a typed locked pointer.
Templated locked pointer for referencing locked objects of specific type.
SharedPointer * ptr
Shared lock for protected singleton.
void lock(void)
Acquire or increase locking.
Locking protocol classes for member function automatic operations.
void replace(T *object)
Replace existing typed object with a new one for next request.
T & operator*() const
Reference object we are pointing to through pointer indirection.
bool exclusive(rwlock_t &lock, timeout_t timeout=Timer::inf)
Convenience function for exclusive write access to a read/write lock.
T * dup(void)
Create a duplicate reference counted instance of the current typed object.
void acquire(mutex_t &mutex)
Convenience function to acquire a mutex.
barrier barrier_t
Convenience type for using thread barriers.
void modify(accesslock_t &lock)
Convenience function to exclusively schedule conditional access.
void release(void)
Release access mode read scheduling.
void start(DetachedThread *thread, int priority=0)
Convenience function to start a detached thread.
void signal(void)
Signal the conditional to release one signalled thread.
void release(void)
Release acquired lock.
Private heaps, pools, and associations.
locked_instance(locked_pointer< T > &pointer)
Construct locked instance of typed object from matching locked_pointer.
virtual void _share(void)=0
Access interface to share lock the object.
void signal(void)
Signal the conditional to release one waiting thread.
void wait(barrier_t &barrier)
Convenience function to wait on a barrier.
virtual void exclusive(void)
Convert read lock into exclusive (write/modify) access.
void commit(void)
Complete exclusive mode write scheduling.
void acquire(void)
Acquire mutex lock.
void access(void)
Acquire access (shared read) lock.
The conditional is a common base for other thread synchronizing classes.
const T * operator->() const
Access member of shared typed singleton object this instance locks and references.
Timer class to use when scheduling realtime events.
ThreadLock rwlock_t
Convenience type for using read/write locks.
Reusable objects for forming private heaps.
Typed smart locked pointer class.