VLC  4.0.0-dev
Modules | Files | Data Structures | Macros | Typedefs | Enumerations | Functions
Threads and synchronization primitives
Collaboration diagram for Threads and synchronization primitives:

Modules

 Interruptible sleep
 
 Mutual exclusion locks
 
 Condition variables
 The condition variable is the most common and generic mean for threads to wait for events triggered by other threads.
 
 Semaphores
 The semaphore is the simplest thread synchronization primitive, consisting of a simple counter.
 
 Read/write locks
 Read/write locks are a type of thread synchronization primitive meant to protect access to data that is mostly read, and rarely written.
 
 Thread-specific variables
 
 Asynchronous/threaded timers
 

Files

file  vlc_threads.h
 Thread primitive declarations.
 

Data Structures

struct  vlc_thread_t
 Thread handle. More...
 
struct  vlc_once_t
 One-time initialization. More...
 

Macros

#define LIBVLC_USE_PTHREAD   1
 Whether LibVLC threads are based on POSIX threads. More...
 
#define LIBVLC_USE_PTHREAD_CLEANUP   1
 Whether LibVLC thread cancellation is based on POSIX threads. More...
 
#define VLC_THREAD_CANCELED   PTHREAD_CANCELED
 Return value of a canceled thread. More...
 
#define VLC_THREAD_PRIORITY_LOW   0
 
#define VLC_THREAD_PRIORITY_INPUT   10
 
#define VLC_THREAD_PRIORITY_AUDIO   5
 
#define VLC_THREAD_PRIORITY_VIDEO   0
 
#define VLC_THREAD_PRIORITY_OUTPUT   15
 
#define VLC_THREAD_PRIORITY_HIGHEST   20
 
#define VLC_STATIC_ONCE   { ATOMIC_VAR_INIT(0) }
 Static initializer for one-time initialization. More...
 
#define vlc_once(once, cb)   vlc_once_inline(once, cb)
 
#define VLC_HARD_MIN_SLEEP   VLC_TICK_FROM_MS(10) /* 10 milliseconds = 1 tick at 100Hz */
 
#define VLC_SOFT_MIN_SLEEP   VLC_TICK_FROM_SEC(9) /* 9 seconds */
 
#define check_delay(d)   (d)
 
#define check_deadline(d)   (d)
 
#define vlc_tick_sleep(d)   vlc_tick_sleep(check_delay(d))
 
#define vlc_tick_wait(d)   vlc_tick_wait(check_deadline(d))
 
#define vlc_cleanup_push(routine, arg)   pthread_cleanup_push (routine, arg)
 Registers a thread cancellation handler. More...
 
#define vlc_cleanup_pop()   pthread_cleanup_pop (0)
 Unregisters the last cancellation handler. More...
 
#define mutex_cleanup_push(lock)   vlc_cleanup_push (vlc_cleanup_lock, lock)
 
#define vlc_global_lock(n)   vlc_global_mutex(n, true)
 Acquires a global mutex. More...
 
#define vlc_global_unlock(n)   vlc_global_mutex(n, false)
 Releases a global mutex. More...
 

Typedefs

typedef struct vlc_cleanup_t vlc_cleanup_t
 

Enumerations

enum  {
  VLC_AVCODEC_MUTEX = 0, VLC_GCRYPT_MUTEX, VLC_XLIB_MUTEX, VLC_MOSAIC_MUTEX,
  VLC_MAX_MUTEX
}
 

Functions

void vlc_testcancel (void)
 Issues an explicit deferred cancellation point. More...
 
void vlc_once_inline (vlc_once_t *restrict once, void(*cb)(void))
 Executes a function one time. More...
 
void vlc_atomic_wait (void *addr, unsigned val)
 Waits on an address. More...
 
int vlc_atomic_timedwait (void *addr, unsigned val, vlc_tick_t deadline)
 Waits on an address with a time-out. More...
 
int vlc_atomic_timedwait_daytime (void *addr, unsigned val, time_t deadline)
 
void vlc_atomic_notify_one (void *addr)
 Wakes up one thread on an address. More...
 
void vlc_atomic_notify_all (void *addr)
 Wakes up all thread on an address. More...
 
int vlc_clone (vlc_thread_t *th, void *(*entry)(void *), void *data, int priority)
 Creates and starts a new thread. More...
 
void vlc_cancel (vlc_thread_t)
 Marks a thread as cancelled. More...
 
void vlc_join (vlc_thread_t th, void **result)
 Waits for a thread to complete (if needed), then destroys it. More...
 
int vlc_savecancel (void)
 Disables thread cancellation. More...
 
void vlc_restorecancel (int state)
 Restores the cancellation state. More...
 
void vlc_control_cancel (vlc_cleanup_t *)
 Internal handler for thread cancellation. More...
 
unsigned long vlc_thread_id (void)
 Thread identifier. More...
 
vlc_tick_t vlc_tick_now (void)
 Precision monotonic clock. More...
 
void vlc_tick_wait (vlc_tick_t deadline)
 Waits until a deadline. More...
 
void vlc_tick_sleep (vlc_tick_t delay)
 Waits for an interval of time. More...
 
unsigned vlc_GetCPUCount (void)
 Count CPUs. More...
 
static void vlc_cleanup_lock (void *lock)
 
void vlc_cancel_addr_set (atomic_uint *addr)
 
void vlc_cancel_addr_clear (atomic_uint *addr)
 
void vlc_global_mutex (unsigned, bool)
 Internal handler for global mutexes. More...
 

Detailed Description

Macro Definition Documentation

◆ check_deadline

#define check_deadline (   d)    (d)

◆ check_delay

#define check_delay (   d)    (d)

◆ LIBVLC_USE_PTHREAD

#define LIBVLC_USE_PTHREAD   1

Whether LibVLC threads are based on POSIX threads.

◆ LIBVLC_USE_PTHREAD_CLEANUP

#define LIBVLC_USE_PTHREAD_CLEANUP   1

Whether LibVLC thread cancellation is based on POSIX threads.

◆ mutex_cleanup_push

#define mutex_cleanup_push (   lock)    vlc_cleanup_push (vlc_cleanup_lock, lock)

◆ vlc_cleanup_pop

#define vlc_cleanup_pop ( )    pthread_cleanup_pop (0)

◆ vlc_cleanup_push

#define vlc_cleanup_push (   routine,
  arg 
)    pthread_cleanup_push (routine, arg)

Registers a thread cancellation handler.

This pushes a function to run if the thread is cancelled (or otherwise exits prematurely).

If multiple procedures are registered, they are handled in last-in first-out order.

Note
Any call to vlc_cleanup_push() must paired with a call to vlc_cleanup_pop().
Warning
Branching into or out of the block between these two function calls is not allowed (read: it will likely crash the whole process).
Parameters
routineprocedure to call if the thread ends
argargument for the procedure

Referenced by detached_thread(), spu_PrerenderThread(), TsRun(), vlc_accept_i11e(), vlc_cond_timedwait(), vlc_cond_timedwait_daytime(), vlc_cond_wait(), vlc_global_mutex(), vlc_h2_frame_recv(), vlc_h2_frame_send(), vlc_h2_recv_thread(), vlc_mwait_i11e(), vlc_poll_i11e(), vlc_poll_i11e_inner(), vlc_sem_wait_i11e(), and vlc_tls_ClientSessionCreate().

◆ vlc_global_lock

#define vlc_global_lock (   n)    vlc_global_mutex(n, true)

◆ vlc_global_unlock

#define vlc_global_unlock (   n)    vlc_global_mutex(n, false)

◆ VLC_HARD_MIN_SLEEP

#define VLC_HARD_MIN_SLEEP   VLC_TICK_FROM_MS(10) /* 10 milliseconds = 1 tick at 100Hz */

◆ vlc_once

#define vlc_once (   once,
  cb 
)    vlc_once_inline(once, cb)

Referenced by vlc_once_inline().

◆ VLC_SOFT_MIN_SLEEP

#define VLC_SOFT_MIN_SLEEP   VLC_TICK_FROM_SEC(9) /* 9 seconds */

◆ VLC_STATIC_ONCE

#define VLC_STATIC_ONCE   { ATOMIC_VAR_INIT(0) }

Static initializer for one-time initialization.

◆ VLC_THREAD_CANCELED

#define VLC_THREAD_CANCELED   PTHREAD_CANCELED

Return value of a canceled thread.

◆ VLC_THREAD_PRIORITY_AUDIO

#define VLC_THREAD_PRIORITY_AUDIO   5

Referenced by decoder_New().

◆ VLC_THREAD_PRIORITY_HIGHEST

#define VLC_THREAD_PRIORITY_HIGHEST   20

◆ VLC_THREAD_PRIORITY_INPUT

#define VLC_THREAD_PRIORITY_INPUT   10

◆ VLC_THREAD_PRIORITY_LOW

#define VLC_THREAD_PRIORITY_LOW   0

◆ VLC_THREAD_PRIORITY_OUTPUT

#define VLC_THREAD_PRIORITY_OUTPUT   15

Referenced by vout_Request().

◆ VLC_THREAD_PRIORITY_VIDEO

#define VLC_THREAD_PRIORITY_VIDEO   0

Referenced by decoder_New(), and spu_Create().

◆ vlc_tick_sleep

#define vlc_tick_sleep (   d)    vlc_tick_sleep(check_delay(d))

◆ vlc_tick_wait

#define vlc_tick_wait (   d)    vlc_tick_wait(check_deadline(d))

Referenced by TsRun(), and vlc_mwait_i11e().

Typedef Documentation

◆ vlc_cleanup_t

typedef struct vlc_cleanup_t vlc_cleanup_t

Enumeration Type Documentation

◆ anonymous enum

anonymous enum
Enumerator
VLC_AVCODEC_MUTEX 
VLC_GCRYPT_MUTEX 
VLC_XLIB_MUTEX 
VLC_MOSAIC_MUTEX 
VLC_MAX_MUTEX 

Function Documentation

◆ vlc_atomic_notify_all()

void vlc_atomic_notify_all ( void *  addr)

Wakes up all thread on an address.

Wakes up all threads sleeping on the specified address (if any). Any thread sleeping within a call to vlc_atomic_wait() or vlc_atomic_timedwait() with the specified address as first call parameter will be woken up.

Parameters
addraddress identifying which threads to wake up

References ARRAY_SIZE, wait_bucket::lock, vlc_clock_id, vlc_futex_wake(), vlc_umtx_wake(), wait_bucket::wait, wait_bucket_get(), wait_buckets, and wait_bucket::waiters.

Referenced by vlc_atomic_notify_one(), vlc_cancel(), and vlc_once().

◆ vlc_atomic_notify_one()

void vlc_atomic_notify_one ( void *  addr)

Wakes up one thread on an address.

Wakes up (at least) one of the thread sleeping on the specified address. The address must be equal to the first parameter given by at least one thread sleeping within the vlc_atomic_wait() or vlc_atomic_timedwait() functions. If no threads are found, this function does nothing.

Parameters
addraddress identifying which threads may be woken up

References vlc_atomic_notify_all(), vlc_futex_wake(), and vlc_umtx_wake().

Referenced by vlc_cond_signal_waiter(), vlc_mutex_unlock(), and vlc_sem_post().

◆ vlc_atomic_timedwait()

int vlc_atomic_timedwait ( void *  addr,
unsigned  val,
vlc_tick_t  deadline 
)

Waits on an address with a time-out.

This function operates as vlc_atomic_wait() but provides an additional time-out. If the deadline is reached, the thread resumes and the function returns.

Parameters
addraddress to check for
valvalue to match at the address
deadlinedeadline to wait until
Return values
0the function was woken up before the time-out
ETIMEDOUTthe deadline was reached

References MS_FROM_VLC_TICK, timespec_from_vlc_tick(), vlc_assert_unreachable, vlc_atomic_timedwait_timespec(), vlc_futex_wait(), VLC_TICK_FROM_MS, vlc_tick_now(), vlc_timespec_adjust(), and vlc_umtx_wait().

Referenced by vlc_cond_timedwait(), and vlc_sem_timedwait().

◆ vlc_atomic_timedwait_daytime()

int vlc_atomic_timedwait_daytime ( void *  addr,
unsigned  val,
time_t  deadline 
)

◆ vlc_atomic_wait()

void vlc_atomic_wait ( void *  addr,
unsigned  val 
)

Waits on an address.

Puts the calling thread to sleep if a specific unsigned 32-bits value is stored at a specified address. The thread will sleep until it is woken up by a call to vlc_atomic_notify_one() or vlc_atomic_notify_all() in another thread, or spuriously.

If the value does not match, do nothing and return immediately.

Parameters
addraddress to check for
valvalue to match at the address

References wait_bucket::lock, vlc_futex_wait(), vlc_umtx_wait(), wait_bucket::wait, wait_bucket_enter(), and wait_bucket_leave().

Referenced by vlc_cond_wait(), vlc_mutex_lock(), vlc_once(), and vlc_sem_wait().

◆ vlc_cancel()

void vlc_cancel ( vlc_thread_t  )

Marks a thread as cancelled.

Next time the target thread reaches a cancellation point (while not having disabled cancellation), it will run its cancellation cleanup handler, the thread variable destructors, and terminate.

vlc_join() must be used regardless of a thread being cancelled or not, to avoid leaking resources.

References vlc_thread::addr, vlc_thread_t::handle, vlc_atomic_notify_all(), vlc_cancel_self(), vlc_mutex_lock(), and vlc_mutex_unlock().

Referenced by httpd_HostDelete(), spu_Destroy(), TsStop(), vlc_getaddrinfo_i11e(), vlc_h2_conn_destroy(), vlc_h2_output_destroy(), and vout_StopDisplay().

◆ vlc_cancel_addr_clear()

void vlc_cancel_addr_clear ( atomic_uint *  addr)

◆ vlc_cancel_addr_set()

void vlc_cancel_addr_set ( atomic_uint *  addr)

◆ vlc_cleanup_lock()

static void vlc_cleanup_lock ( void *  lock)
inlinestatic

References vlc_mutex_unlock().

◆ vlc_clone()

int vlc_clone ( vlc_thread_t th,
void *(*)(void *)  entry,
void *  data,
int  priority 
)

Creates and starts a new thread.

The thread must be joined with vlc_join() to reclaim resources when it is not needed anymore.

Parameters
thstorage space for the handle of the new thread (cannot be NULL) [OUT]
entryentry point for the thread
datadata parameter given to the entry point
prioritythread priority value
Returns
0 on success, a standard error code on error.
Note
In case of error, the value of *th is undefined.

References vlc_clone_attr().

Referenced by addons_manager_Gather(), decoder_New(), httpd_HostCreate(), input_Start(), InstallEntry(), sout_AnnounceRegisterSDP(), spu_Create(), StartWorker(), TsStart(), update_Check(), update_Download(), vlc_demux_chained_New(), vlc_getaddrinfo_i11e(), vlc_h2_conn_create(), vlc_h2_output_create(), vlc_mta_acquire(), vlc_player_New(), vlc_timer_create(), vlm_New(), and vout_Request().

◆ vlc_control_cancel()

void vlc_control_cancel ( vlc_cleanup_t )

Internal handler for thread cancellation.

Do not call this function directly. Use wrapper macros instead: vlc_cleanup_push(), vlc_cleanup_pop().

References vlc_thread::cleaners, thread_key, vlc_assert_unreachable, and vlc_threadvar_get().

◆ vlc_GetCPUCount()

unsigned vlc_GetCPUCount ( void  )

Count CPUs.

Returns
number of available (logical) CPUs.

References count, unlikely, and vlc_alloc().

Referenced by vlc_timer_schedule_asap().

◆ vlc_global_mutex()

void vlc_global_mutex ( unsigned  ,
bool   
)

◆ vlc_join()

void vlc_join ( vlc_thread_t  th,
void **  result 
)

Waits for a thread to complete (if needed), then destroys it.

Note
This is a cancellation point. In case of cancellation, the thread is not joined.
Warning
A thread cannot join itself (normally VLC will abort if this is attempted). Also a detached thread cannot be joined.
Parameters
ththread handle
result[OUT] pointer to write the thread return value or NULL

References clean_detached_thread(), vlc_thread_t::handle, vlc_testcancel(), VLC_THREAD_ASSERT, vlc_thread_destroy(), and vlc_WaitForSingleObject().

Referenced by addons_manager_Delete(), CloseWorker(), httpd_HostDelete(), input_Close(), sout_AnnounceUnRegister(), spu_Destroy(), TsStop(), update_Check(), update_Delete(), update_Download(), vlc_demux_chained_Delete(), vlc_getaddrinfo_i11e(), vlc_h2_conn_destroy(), vlc_h2_output_destroy(), vlc_input_decoder_Delete(), vlc_mta_release(), vlc_player_Delete(), vlc_timer_destroy(), vlm_Delete(), and vout_StopDisplay().

◆ vlc_once_inline()

static void vlc_once_inline ( vlc_once_t *restrict  once,
void(*)(void)  cb 
)
inline

Executes a function one time.

The first time this function is called with a given one-time initialization object, it executes the provided callback. Any further call with the same object will be a no-op.

In the corner case that the first time execution is ongoing in another thread, then the function will wait for completion on the other thread (and then synchronize memory) before it returns. This ensures that, no matter what, the callback has been executed exactly once and its side effects are visible after the function returns.

Parameters
oncea one-time initialization object
cbcallback to execute (the first time)

References unlikely, and vlc_once.

◆ vlc_restorecancel()

void vlc_restorecancel ( int  state)

◆ vlc_savecancel()

int vlc_savecancel ( void  )

Disables thread cancellation.

This functions saves the current cancellation state (enabled or disabled), then disables cancellation for the calling thread. It must be called before entering a piece of code that is not cancellation-safe, unless it can be proven that the calling thread will not be cancelled.

Note
This function is not a cancellation point.
Returns
Previous cancellation state (opaque value for vlc_restorecancel()).

References vlc_thread::killable, state, thread_key, VLC_THREAD_ASSERT, and vlc_threadvar_get().

Referenced by FinderThread(), httpdLoop(), InstallerThread(), spu_PrerenderThread(), Thread(), TsRun(), update_CheckReal(), update_DownloadReal(), vlc_h2_output_dequeue(), vlc_h2_recv_thread(), vlc_https_connect_proxy(), vlc_https_recv(), vlc_https_send(), vlc_mutex_lock(), vlc_object_deinit(), vlc_poll_i11e_inner(), vlc_poll_i11e_wake(), vlc_thread_fatal(), vlc_tls_ClientSessionCreate(), vlc_tls_ServerSessionCreate(), vlc_tls_SessionDelete(), and vlc_vaLogCallback().

◆ vlc_testcancel()

void vlc_testcancel ( void  )

Issues an explicit deferred cancellation point.

This has no effects if thread cancellation is disabled. This can be called when there is a rather slow non-sleeping operation. This is also used to force a cancellation point in a function that would otherwise not always be one (block_FifoGet() is an example).

References vlc_thread::cancel_event, vlc_thread::cleaners, vlc_thread::data, vlc_thread::done_event, vlc_thread::id, vlc_thread::killable, vlc_thread::killed, p, thread_key, vlc_cancel_self(), vlc_thread_cleanup(), vlc_thread_destroy(), and vlc_threadvar_get().

Referenced by block_FifoGet(), net_Read(), net_Write(), vlc_global_mutex(), vlc_join(), vlc_poll_i11e_inner(), vlc_select(), vlc_tick_now(), and vlc_tick_wait().

◆ vlc_thread_id()

unsigned long vlc_thread_id ( void  )

Thread identifier.

This function returns the identifier of the calling thread. The identifier cannot change for the entire duration of the thread, and no other thread can have the same identifier at the same time in the same process. Typically, the identifier is also unique across all running threads of all existing processes, but that depends on the operating system.

There are no particular semantics to the thread ID with LibVLC. It is provided mainly for tracing and debugging.

Warning
This function is not currently implemented on all supported platforms. Where not implemented, it returns (unsigned long)-1.
Returns
the thread identifier (or -1 if unimplemented)

References unlikely.

Referenced by vlc_thread_fatal(), vlc_thread_fatal_print(), and vlc_vaLog().

◆ vlc_tick_now()

vlc_tick_t vlc_tick_now ( void  )

Precision monotonic clock.

In principles, the clock has a precision of 1 MHz. But the actual resolution may be much lower, especially when it comes to sleeping with vlc_tick_wait() or vlc_tick_sleep(). Most general-purpose operating systems provide a resolution of only 100 to 1000 Hz.

Warning
The origin date (time value "zero") is not specified. It is typically the time the kernel started, but this is platform-dependent. If you need wall clock time, use gettimeofday() instead.
Returns
a timestamp in microseconds.

References freq, lldiv(), mdate_selected, Q2LL, lldiv_t::quot, lldiv_t::rem, unlikely, vlc_clock_conversion, vlc_clock_setup, vlc_testcancel(), VLC_TICK_FROM_NS, vlc_tick_from_samples(), vlc_tick_from_sec, vlc_tick_from_timespec, vlc_tick_now(), vlc_tick_sleep(), and vlc_tick_wait().

Referenced by aout_DecDrain(), aout_DecPlay(), aout_DecSilence(), CmdInitAdd(), CmdInitControl(), CmdInitDel(), CmdInitPrivControl(), CmdInitSend(), Control(), EsOutDecodersStopBuffering(), EsOutGetBuffering(), EsOutVaControlLocked(), httpdLoop(), ImageRead(), Init(), input_clock_ConvertTS(), input_rate_Add(), input_thread_Events(), MainLoop(), net_Connect(), OSDWidget(), QueueTake(), RunThread(), sout_AnnounceRegisterSDP(), spu_PrerenderText(), spu_PutSubpicture(), Thread(), ThreadDisplayPicture(), ThreadDisplayPreparePicture(), ThreadDisplayRenderPicture(), TsStart(), vlc_atomic_timedwait(), vlc_demux_chained_Thread(), vlc_input_decoder_AddVoutOverlay(), vlc_msleep_i11e(), vlc_player_input_GetPos(), vlc_player_input_GetTime(), vlc_player_WaitRetryDelay(), vlc_tick_now(), vlc_tick_sleep(), vlc_tick_wait(), vlc_timer_schedule(), vlc_timer_thread(), vlc_tls_ClientSessionCreate(), vout_chrono_Start(), vout_chrono_Stop(), vout_display_window_MouseEvent(), vout_OSDEpg(), vout_OSDText(), vout_SetInterlacingState(), vout_snapshot_Get(), and VoutSnapshotPip().

◆ vlc_tick_sleep()

void vlc_tick_sleep ( vlc_tick_t  delay)

Waits for an interval of time.

Parameters
delayhow long to wait (in microseconds)
Note
The delay may be exceeded due to OS scheduling.
This function is a cancellation point.

References timespec_from_vlc_tick(), vlc_tick_now(), and vlc_tick_wait().

Referenced by vlc_tick_now(), and vlc_tick_wait().

◆ vlc_tick_wait()

void vlc_tick_wait ( vlc_tick_t  deadline)

Waits until a deadline.

Parameters
deadlinetimestamp to wait for (vlc_tick_now())
Note
The deadline may be exceeded due to OS scheduling.
This function is a cancellation point.

References timespec_from_vlc_tick(), unlikely, vlc_clock_once, vlc_clock_prec, vlc_clock_setup_once(), vlc_Sleep(), vlc_testcancel(), vlc_tick_now(), and vlc_tick_sleep().

Referenced by vlc_tick_now(), and vlc_tick_sleep().