suricata
tm-threads.c File Reference
#include "suricata-common.h"
#include "suricata.h"
#include "stream.h"
#include "runmodes.h"
#include "threadvars.h"
#include "tm-queues.h"
#include "tm-queuehandlers.h"
#include "tm-threads.h"
#include "tmqh-packetpool.h"
#include "threads.h"
#include "util-affinity.h"
#include "util-debug.h"
#include "util-privs.h"
#include "util-cpu.h"
#include "util-optimize.h"
#include "util-profiling.h"
#include "util-signal.h"
#include "queue.h"
#include "util-validate.h"
Include dependency graph for tm-threads.c:

Go to the source code of this file.

Data Structures

struct  Thread_
 
struct  Threads_
 

Macros

#define MIN_WAIT_TIME   100
 
#define MAX_WAIT_TIME   999999
 
#define STEP   32
 

Typedefs

typedef struct Thread_ Thread
 
typedef struct Threads_ Threads
 

Functions

int TmThreadsCheckFlag (ThreadVars *tv, uint32_t flag)
 Check if a thread flag is set. More...
 
void TmThreadsSetFlag (ThreadVars *tv, uint32_t flag)
 Set a thread flag. More...
 
void TmThreadsUnsetFlag (ThreadVars *tv, uint32_t flag)
 Unset a thread flag. More...
 
TmEcode TmThreadsProcessDecodePseudoPackets (ThreadVars *tv, PacketQueueNoLock *decode_pq, TmSlot *slot)
 
TmEcode TmThreadsSlotVarRun (ThreadVars *tv, Packet *p, TmSlot *slot)
 Separate run function so we can call it recursively. More...
 
void TmSlotSetFuncAppend (ThreadVars *tv, TmModule *tm, const void *data)
 Appends a new entry to the slots. More...
 
TmEcode TmThreadSetThreadPriority (ThreadVars *tv, int prio)
 Set the thread options (thread priority). More...
 
void TmThreadSetPrio (ThreadVars *tv)
 Adjusting nice value for threads. More...
 
TmEcode TmThreadSetCPUAffinity (ThreadVars *tv, uint16_t cpu)
 Set the thread options (cpu affinity). More...
 
TmEcode TmThreadSetCPU (ThreadVars *tv, uint8_t type)
 
int TmThreadGetNbThreads (uint8_t type)
 
TmEcode TmThreadSetupOptions (ThreadVars *tv)
 Set the thread options (cpu affinitythread). Priority should be already set by pthread_create. More...
 
ThreadVarsTmThreadCreate (const char *name, const char *inq_name, const char *inqh_name, const char *outq_name, const char *outqh_name, const char *slots, void *(*fn_p)(void *), int mucond)
 Creates and returns the TV instance for a new thread. More...
 
ThreadVarsTmThreadCreatePacketHandler (const char *name, const char *inq_name, const char *inqh_name, const char *outq_name, const char *outqh_name, const char *slots)
 Creates and returns a TV instance for a Packet Processing Thread. This function doesn't support custom slots, and hence shouldn't be supplied "custom" as its slot type. All PPT threads are created with a mucond(see TmThreadCreate declaration) of 0. Hence the tv conditional variables are not used to kill the thread. More...
 
ThreadVarsTmThreadCreateMgmtThread (const char *name, void *(fn_p)(void *), int mucond)
 Creates and returns the TV instance for a Management thread(MGMT). This function supports only custom slot functions and hence a function pointer should be sent as an argument. More...
 
ThreadVarsTmThreadCreateMgmtThreadByName (const char *name, const char *module, int mucond)
 Creates and returns the TV instance for a Management thread(MGMT). This function supports only custom slot functions and hence a function pointer should be sent as an argument. More...
 
ThreadVarsTmThreadCreateCmdThreadByName (const char *name, const char *module, int mucond)
 Creates and returns the TV instance for a Command thread (CMD). This function supports only custom slot functions and hence a function pointer should be sent as an argument. More...
 
void TmThreadAppend (ThreadVars *tv, int type)
 Appends this TV to tv_root based on its type. More...
 
void TmThreadDisableReceiveThreads (void)
 Disable all threads having the specified TMs. More...
 
void TmThreadDisablePacketThreads (void)
 Disable all packet threads. More...
 
void TmThreadKillThreadsFamily (int family)
 
void TmThreadKillThreads (void)
 
void TmThreadSetGroupName (ThreadVars *tv, const char *name)
 
void TmThreadClearThreadsFamily (int family)
 
TmEcode TmThreadSpawn (ThreadVars *tv)
 Spawns a thread associated with the ThreadVars instance tv. More...
 
void TmThreadInitMC (ThreadVars *tv)
 Initializes the mutex and condition variables for this TV. More...
 
void TmThreadTestThreadUnPaused (ThreadVars *tv)
 Tests if the thread represented in the arg has been unpaused or not. More...
 
void TmThreadWaitForFlag (ThreadVars *tv, uint32_t flags)
 Waits till the specified flag(s) is(are) set. We don't bother if the kill flag has been set or not on the thread. More...
 
void TmThreadContinue (ThreadVars *tv)
 Unpauses a thread. More...
 
TmEcode TmThreadWaitOnThreadRunning (void)
 Waits for all threads to be in a running state. More...
 
void TmThreadContinueThreads (void)
 Unpauses all threads present in tv_root. More...
 
void TmThreadCheckThreadState (void)
 Used to check the thread for certain conditions of failure. More...
 
TmEcode TmThreadWaitOnThreadInit (void)
 Used to check if all threads have finished their initialization. On finding an un-initialized thread, it waits till that thread completes its initialization, before proceeding to the next thread. More...
 
uint32_t TmThreadCountThreadsByTmmFlags (uint8_t flags)
 returns a count of all the threads that match the flag More...
 
void TmThreadsListThreads (void)
 
int TmThreadsRegisterThread (ThreadVars *tv, const int type)
 
void TmThreadsUnregisterThread (const int id)
 
void TmThreadsSetThreadTimestamp (const int id, const SCTime_t ts)
 
bool TmThreadsTimeSubsysIsReady (void)
 
void TmThreadsInitThreadsTimestamp (const SCTime_t ts)
 
void TmThreadsGetMinimalTimestamp (struct timeval *ts)
 
uint16_t TmThreadsGetWorkerThreadMax (void)
 
void TmThreadsInjectFlowById (Flow *f, const int id)
 inject a flow into a threads flow queue More...
 

Variables

ThreadVarstv_root [TVT_MAX] = { NULL }
 
SCMutex tv_root_lock = SCMUTEX_INITIALIZER
 

Detailed Description

Author
Victor Julien victo.nosp@m.r@in.nosp@m.linia.nosp@m.c.ne.nosp@m.t
Anoop Saldanha anoop.nosp@m.sald.nosp@m.anha@.nosp@m.gmai.nosp@m.l.com
Eric Leblond eric@.nosp@m.regi.nosp@m.t.org

Thread management functions.

Definition in file tm-threads.c.

Macro Definition Documentation

◆ MAX_WAIT_TIME

#define MAX_WAIT_TIME   999999

Definition at line 1534 of file tm-threads.c.

◆ MIN_WAIT_TIME

#define MIN_WAIT_TIME   100

Definition at line 1533 of file tm-threads.c.

◆ STEP

#define STEP   32

Definition at line 2110 of file tm-threads.c.

Typedef Documentation

◆ Thread

typedef struct Thread_ Thread

◆ Threads

typedef struct Threads_ Threads

Function Documentation

◆ TmSlotSetFuncAppend()

◆ TmThreadAppend()

void TmThreadAppend ( ThreadVars tv,
int  type 
)

Appends this TV to tv_root based on its type.

Parameters
typeholds the type this TV belongs to.

Definition at line 1152 of file tm-threads.c.

References ThreadVars_::next, SCMutexLock, SCMutexUnlock, tv, tv_root, tv_root_lock, and type.

Referenced by TmThreadSpawn().

Here is the caller graph for this function:

◆ TmThreadCheckThreadState()

void TmThreadCheckThreadState ( void  )

Used to check the thread for certain conditions of failure.

Definition at line 1924 of file tm-threads.c.

References FatalError, ThreadVars_::name, ThreadVars_::next, SCMutexLock, SCMutexUnlock, THV_FAILED, TmThreadsCheckFlag(), tv, tv_root, tv_root_lock, and TVT_MAX.

Referenced by SuricataMainLoop().

Here is the call graph for this function:
Here is the caller graph for this function:

◆ TmThreadClearThreadsFamily()

void TmThreadClearThreadsFamily ( int  family)

Definition at line 1635 of file tm-threads.c.

References ThreadVars_::next, SCMutexLock, tv, tv_root, tv_root_lock, and TVT_MAX.

◆ TmThreadContinue()

void TmThreadContinue ( ThreadVars tv)

Unpauses a thread.

Parameters
tvPointer to a TV instance that has to be unpaused

Definition at line 1794 of file tm-threads.c.

References THV_PAUSE, TmThreadsUnsetFlag(), and tv.

Referenced by TmThreadContinueDetectLoaderThreads(), and TmThreadContinueThreads().

Here is the call graph for this function:
Here is the caller graph for this function:

◆ TmThreadContinueThreads()

void TmThreadContinueThreads ( void  )

Unpauses all threads present in tv_root.

Definition at line 1907 of file tm-threads.c.

References ThreadVars_::next, SCMutexLock, SCMutexUnlock, TmThreadContinue(), tv, tv_root, tv_root_lock, and TVT_MAX.

Referenced by SuricataPostInit().

Here is the call graph for this function:
Here is the caller graph for this function:

◆ TmThreadCountThreadsByTmmFlags()

uint32_t TmThreadCountThreadsByTmmFlags ( uint8_t  flags)

returns a count of all the threads that match the flag

Definition at line 2011 of file tm-threads.c.

References cnt, flags, ThreadVars_::next, SCMutexLock, SCMutexUnlock, ThreadVars_::tmm_flags, tv, tv_root, tv_root_lock, and TVT_MAX.

Referenced by PacketPoolPostRunmodes().

Here is the caller graph for this function:

◆ TmThreadCreate()

ThreadVars* TmThreadCreate ( const char *  name,
const char *  inq_name,
const char *  inqh_name,
const char *  outq_name,
const char *  outqh_name,
const char *  slots,
void *(*)(void *)  fn_p,
int  mucond 
)

Creates and returns the TV instance for a new thread.

Parameters
nameName of this TV instance
inq_nameIncoming queue name
inqh_nameIncoming queue handler name as set by TmqhSetup()
outq_nameOutgoing queue name
outqh_nameOutgoing queue handler as set by TmqhSetup()
slotsString representation for the slot function to be used
fn_pPointer to function when "slots" is of type "custom"
mucondFlag to indicate whether to initialize the condition and the mutex variables for this newly created TV.
Return values
thenewly created TV instance, or NULL on error

Definition at line 907 of file tm-threads.c.

References Tmqh_::InHandler, ThreadVars_::inq, ThreadVars_::inq_id, StatsPublicThreadContext_::m, ThreadVars_::name, ThreadVars_::outctx, Tmqh_::OutHandler, Tmqh_::OutHandlerCtxSetup, ThreadVars_::outq, ThreadVars_::outq_id, ThreadVars_::perf_public_ctx, Tmq_::reader_cnt, SC_ATOMIC_INIT, SCCalloc, SCLogDebug, SCMutexInit, strlcpy(), THV_PAUSE, THV_USE, TmqCreateQueue(), TmqGetQueueByName(), ThreadVars_::tmqh_in, ThreadVars_::tmqh_out, TmqhGetQueueHandlerByName(), TmqhNameToID(), TmThreadsSetFlag(), tv, unlikely, and Tmq_::writer_cnt.

Referenced by NapatechStartStats(), TmThreadCreateCmdThreadByName(), TmThreadCreateMgmtThread(), TmThreadCreateMgmtThreadByName(), and TmThreadCreatePacketHandler().

Here is the call graph for this function:
Here is the caller graph for this function:

◆ TmThreadCreateCmdThreadByName()

ThreadVars* TmThreadCreateCmdThreadByName ( const char *  name,
const char *  module,
int  mucond 
)

Creates and returns the TV instance for a Command thread (CMD). This function supports only custom slot functions and hence a function pointer should be sent as an argument.

Parameters
nameName of this TV instance
moduleName of TmModule with COMMAND flag set.
mucondFlag to indicate whether to initialize the condition and the mutex variables for this newly created TV.
Return values
thenewly created TV instance, or NULL on error

Definition at line 1126 of file tm-threads.c.

References ThreadVars_::id, m, MANAGEMENT_CPU_SET, TmModuleGetByName(), TmSlotSetFuncAppend(), TmThreadCreate(), TmThreadSetCPU(), TmThreadsRegisterThread(), tv, TVT_CMD, and ThreadVars_::type.

Here is the call graph for this function:

◆ TmThreadCreateMgmtThread()

ThreadVars* TmThreadCreateMgmtThread ( const char *  name,
void *  fn_p)(void *,
int  mucond 
)

Creates and returns the TV instance for a Management thread(MGMT). This function supports only custom slot functions and hence a function pointer should be sent as an argument.

Parameters
nameName of this TV instance
fn_pPointer to function when "slots" is of type "custom"
mucondFlag to indicate whether to initialize the condition and the mutex variables for this newly created TV.
Return values
thenewly created TV instance, or NULL on error

Definition at line 1065 of file tm-threads.c.

References ThreadVars_::id, MANAGEMENT_CPU_SET, TmThreadCreate(), TmThreadSetCPU(), TmThreadsRegisterThread(), tv, TVT_MGMT, and ThreadVars_::type.

Here is the call graph for this function:

◆ TmThreadCreateMgmtThreadByName()

ThreadVars* TmThreadCreateMgmtThreadByName ( const char *  name,
const char *  module,
int  mucond 
)

Creates and returns the TV instance for a Management thread(MGMT). This function supports only custom slot functions and hence a function pointer should be sent as an argument.

Parameters
nameName of this TV instance
moduleName of TmModule with MANAGEMENT flag set.
mucondFlag to indicate whether to initialize the condition and the mutex variables for this newly created TV.
Return values
thenewly created TV instance, or NULL on error

Definition at line 1093 of file tm-threads.c.

References ThreadVars_::id, m, MANAGEMENT_CPU_SET, TmModuleGetByName(), TmSlotSetFuncAppend(), TmThreadCreate(), TmThreadSetCPU(), TmThreadsRegisterThread(), tv, TVT_MGMT, and ThreadVars_::type.

Referenced by BypassedFlowManagerThreadSpawn().

Here is the call graph for this function:
Here is the caller graph for this function:

◆ TmThreadCreatePacketHandler()

ThreadVars* TmThreadCreatePacketHandler ( const char *  name,
const char *  inq_name,
const char *  inqh_name,
const char *  outq_name,
const char *  outqh_name,
const char *  slots 
)

Creates and returns a TV instance for a Packet Processing Thread. This function doesn't support custom slots, and hence shouldn't be supplied "custom" as its slot type. All PPT threads are created with a mucond(see TmThreadCreate declaration) of 0. Hence the tv conditional variables are not used to kill the thread.

Parameters
nameName of this TV instance
inq_nameIncoming queue name
inqh_nameIncoming queue handler name as set by TmqhSetup()
outq_nameOutgoing queue name
outqh_nameOutgoing queue handler as set by TmqhSetup()
slotsString representation for the slot function to be used
Return values
thenewly created TV instance, or NULL on error

Definition at line 1036 of file tm-threads.c.

References ThreadVars_::id, TmThreadCreate(), TmThreadsRegisterThread(), tv, TVT_PPT, and ThreadVars_::type.

Referenced by RunModeErfFileAutoFp(), RunModeErfFileSingle(), RunModeFilePcapAutoFp(), RunModeFilePcapSingle(), RunModeSetIPSAutoFp(), RunModeSetIPSWorker(), and RunModeSetLiveCaptureAutoFp().

Here is the call graph for this function:
Here is the caller graph for this function:

◆ TmThreadDisablePacketThreads()

void TmThreadDisablePacketThreads ( void  )

Disable all packet threads.

Definition at line 1483 of file tm-threads.c.

Referenced by PostRunDeinit().

Here is the caller graph for this function:

◆ TmThreadDisableReceiveThreads()

void TmThreadDisableReceiveThreads ( void  )

Disable all threads having the specified TMs.

Breaks out of the packet acquisition loop, and bumps into the 'flow loop', where it will process packets from the flow engine's shutdown handling.

Definition at line 1353 of file tm-threads.c.

References FatalError, TmModule_::flags, ThreadVars_::name, SCMutexLock, TmSlot_::slot_next, TM_FLAG_RECEIVE_TM, TmSlot_::tm_id, ThreadVars_::tm_slots, TmModuleGetById(), tv, tv_root, tv_root_lock, and TVT_PPT.

Referenced by PostRunDeinit().

Here is the call graph for this function:
Here is the caller graph for this function:

◆ TmThreadGetNbThreads()

int TmThreadGetNbThreads ( uint8_t  type)

Definition at line 832 of file tm-threads.c.

References MAX_CPU_SET, ThreadsAffinityType_::nb_threads, SCLogError, thread_affinity, and type.

Referenced by RunModeErfFileAutoFp(), RunModeFilePcapAutoFp(), and TmThreadsGetWorkerThreadMax().

Here is the caller graph for this function:

◆ TmThreadInitMC()

void TmThreadInitMC ( ThreadVars tv)

Initializes the mutex and condition variables for this TV.

It can be used by a thread to control a wait loop that can also be influenced by other threads.

Parameters
tvPointer to a TV instance

Definition at line 1716 of file tm-threads.c.

References ThreadVars_::ctrl_cond, ThreadVars_::ctrl_mutex, FatalError, SCCtrlCondInit, SCCtrlMutexInit, SCMalloc, and tv.

◆ TmThreadKillThreads()

void TmThreadKillThreads ( void  )

Definition at line 1563 of file tm-threads.c.

References TmThreadKillThreadsFamily(), and TVT_MAX.

Referenced by SuricataShutdown().

Here is the call graph for this function:
Here is the caller graph for this function:

◆ TmThreadKillThreadsFamily()

void TmThreadKillThreadsFamily ( int  family)

Definition at line 1534 of file tm-threads.c.

References BUG_ON, MIN_WAIT_TIME, SCMutexLock, tv, tv_root, tv_root_lock, and TVT_MAX.

Referenced by TmThreadKillThreads().

Here is the caller graph for this function:

◆ TmThreadsCheckFlag()

int TmThreadsCheckFlag ( ThreadVars tv,
uint32_t  flag 
)

Check if a thread flag is set.

Return values
1flag is set.
0flag is not set.

Definition at line 91 of file tm-threads.c.

References SC_ATOMIC_GET, and tv.

Referenced by FlowDisableFlowManagerThread(), TmThreadCheckThreadState(), TmThreadTestThreadUnPaused(), TmThreadWaitForFlag(), TmThreadWaitOnThreadInit(), and TmThreadWaitOnThreadRunning().

Here is the caller graph for this function:

◆ TmThreadSetCPU()

◆ TmThreadSetCPUAffinity()

TmEcode TmThreadSetCPUAffinity ( ThreadVars tv,
uint16_t  cpu 
)

Set the thread options (cpu affinity).

Parameters
tvpointer to the ThreadVars to setup the affinity.
cpucpu on which affinity is set.
Return values
TM_ECODE_OK

Definition at line 807 of file tm-threads.c.

References ThreadVars_::cpu_affinity, THREAD_SET_AFFINITY, ThreadVars_::thread_setup_flags, TM_ECODE_OK, and tv.

Referenced by RunModeErfFileAutoFp().

Here is the caller graph for this function:

◆ TmThreadSetGroupName()

void TmThreadSetGroupName ( ThreadVars tv,
const char *  name 
)

Definition at line 1617 of file tm-threads.c.

References SCLogError, SCStrdup, ThreadVars_::thread_group_name, tv, and unlikely.

Referenced by RunModeErfFileAutoFp(), RunModeFilePcapAutoFp(), RunModeSetIPSAutoFp(), and RunModeSetLiveCaptureAutoFp().

Here is the caller graph for this function:

◆ TmThreadSetPrio()

void TmThreadSetPrio ( ThreadVars tv)

Adjusting nice value for threads.

Definition at line 770 of file tm-threads.c.

References ThreadVars_::name, SCEnter, SCLogDebug, SCLogError, SCReturn, ThreadVars_::thread_priority, and tv.

◆ TmThreadSetThreadPriority()

TmEcode TmThreadSetThreadPriority ( ThreadVars tv,
int  prio 
)

Set the thread options (thread priority).

Parameters
tvPointer to the ThreadVars to setup the thread priority.
Return values
TM_ECODE_OK.

Definition at line 759 of file tm-threads.c.

References ThreadVars_::thread_priority, THREAD_SET_PRIORITY, ThreadVars_::thread_setup_flags, TM_ECODE_OK, and tv.

Referenced by RunModeErfFileAutoFp().

Here is the caller graph for this function:

◆ TmThreadSetupOptions()

TmEcode TmThreadSetupOptions ( ThreadVars tv)

Set the thread options (cpu affinitythread). Priority should be already set by pthread_create.

Parameters
tvpointer to the ThreadVars of the calling thread.

Definition at line 848 of file tm-threads.c.

References ThreadVars_::cpu_affinity, ThreadVars_::name, SCGetThreadIdLong, SCLogPerf, THREAD_SET_AFFINITY, ThreadVars_::thread_setup_flags, and tv.

◆ TmThreadsGetMinimalTimestamp()

void TmThreadsGetMinimalTimestamp ( struct timeval *  ts)

Definition at line 2238 of file tm-threads.c.

References SCMutexLock.

◆ TmThreadsGetWorkerThreadMax()

uint16_t TmThreadsGetWorkerThreadMax ( void  )

Definition at line 2274 of file tm-threads.c.

References SCLogWarning, threading_detect_ratio, TmThreadGetNbThreads(), UtilCpuGetNumProcessorsOnline(), and WORKER_CPU_SET.

Referenced by RunModeSetIPSAutoFp(), and RunModeSetLiveCaptureAutoFp().

Here is the call graph for this function:
Here is the caller graph for this function:

◆ TmThreadsInitThreadsTimestamp()

void TmThreadsInitThreadsTimestamp ( const SCTime_t  ts)

Definition at line 2223 of file tm-threads.c.

References SCMutexLock.

Referenced by PcapFileDispatch().

Here is the caller graph for this function:

◆ TmThreadsInjectFlowById()

void TmThreadsInjectFlowById ( Flow f,
const int  id 
)

inject a flow into a threads flow queue

Definition at line 2292 of file tm-threads.c.

References BUG_ON.

Referenced by FlowForceReassemblyForFlow().

Here is the caller graph for this function:

◆ TmThreadsListThreads()

void TmThreadsListThreads ( void  )

Definition at line 2089 of file tm-threads.c.

References SCMutexLock.

◆ TmThreadSpawn()

TmEcode TmThreadSpawn ( ThreadVars tv)

Spawns a thread associated with the ThreadVars instance tv.

Return values
TM_ECODE_OKon success and TM_ECODE_FAILED on failure

Definition at line 1660 of file tm-threads.c.

References FatalError, SCLogDebug, ThreadVars_::t, threading_set_stack_size, THV_INIT_DONE, THV_RUNNING_DONE, TM_ECODE_OK, ThreadVars_::tm_func, TmThreadAppend(), TmThreadWaitForFlag(), tv, and ThreadVars_::type.

Referenced by BypassedFlowManagerThreadSpawn(), RunModeErfFileAutoFp(), RunModeErfFileSingle(), RunModeFilePcapAutoFp(), RunModeFilePcapSingle(), RunModeSetIPSAutoFp(), RunModeSetIPSWorker(), and RunModeSetLiveCaptureAutoFp().

Here is the call graph for this function:
Here is the caller graph for this function:

◆ TmThreadsProcessDecodePseudoPackets()

TmEcode TmThreadsProcessDecodePseudoPackets ( ThreadVars tv,
PacketQueueNoLock decode_pq,
TmSlot slot 
)

Definition at line 112 of file tm-threads.c.

References DEBUG_VALIDATE_BUG_ON, Packet_::flow, PacketDequeueNoLock(), PacketQueueNoLock_::top, and unlikely.

Here is the call graph for this function:

◆ TmThreadsRegisterThread()

int TmThreadsRegisterThread ( ThreadVars tv,
const int  type 
)
Return values
idthread id, or 0 if not found

Definition at line 2113 of file tm-threads.c.

References SCMutexLock.

Referenced by TmThreadCreateCmdThreadByName(), TmThreadCreateMgmtThread(), TmThreadCreateMgmtThreadByName(), and TmThreadCreatePacketHandler().

Here is the caller graph for this function:

◆ TmThreadsSetFlag()

void TmThreadsSetFlag ( ThreadVars tv,
uint32_t  flag 
)

Set a thread flag.

Definition at line 99 of file tm-threads.c.

References SC_ATOMIC_OR, and tv.

Referenced by FlowDisableFlowManagerThread(), ReceiveErfDagLoop(), ReceiveErfFileLoop(), ReceivePfringLoop(), and TmThreadCreate().

Here is the caller graph for this function:

◆ TmThreadsSetThreadTimestamp()

void TmThreadsSetThreadTimestamp ( const int  id,
const SCTime_t  ts 
)

Definition at line 2189 of file tm-threads.c.

References SCMutexLock.

◆ TmThreadsSlotVarRun()

TmEcode TmThreadsSlotVarRun ( ThreadVars tv,
Packet p,
TmSlot slot 
)

Separate run function so we can call it recursively.

Definition at line 131 of file tm-threads.c.

References DEBUG_VALIDATE_BUG_ON, Packet_::flow, PACKET_PROFILING_TMM_END, PACKET_PROFILING_TMM_START, SC_ATOMIC_GET, TmSlot_::slot_next, TM_ECODE_FAILED, tv, and unlikely.

◆ TmThreadsTimeSubsysIsReady()

bool TmThreadsTimeSubsysIsReady ( void  )

Definition at line 2206 of file tm-threads.c.

References SCMutexLock.

◆ TmThreadsUnregisterThread()

void TmThreadsUnregisterThread ( const int  id)

Definition at line 2156 of file tm-threads.c.

References SCMutexLock.

◆ TmThreadsUnsetFlag()

void TmThreadsUnsetFlag ( ThreadVars tv,
uint32_t  flag 
)

Unset a thread flag.

Definition at line 107 of file tm-threads.c.

References SC_ATOMIC_AND, and tv.

Referenced by TmThreadContinue().

Here is the caller graph for this function:

◆ TmThreadTestThreadUnPaused()

void TmThreadTestThreadUnPaused ( ThreadVars tv)

Tests if the thread represented in the arg has been unpaused or not.

   The function would return if the thread tv has been unpaused or if the
   kill flag for the thread has been set.
Parameters
tvPointer to the TV instance.

Definition at line 1762 of file tm-threads.c.

References SleepUsec, THV_KILL, THV_PAUSE, TmThreadsCheckFlag(), and tv.

Here is the call graph for this function:

◆ TmThreadWaitForFlag()

void TmThreadWaitForFlag ( ThreadVars tv,
uint32_t  flags 
)

Waits till the specified flag(s) is(are) set. We don't bother if the kill flag has been set or not on the thread.

Parameters
tvPointer to the TV instance.

Definition at line 1780 of file tm-threads.c.

References flags, SleepUsec, TmThreadsCheckFlag(), and tv.

Referenced by TmThreadSpawn().

Here is the call graph for this function:
Here is the caller graph for this function:

◆ TmThreadWaitOnThreadInit()

TmEcode TmThreadWaitOnThreadInit ( void  )

Used to check if all threads have finished their initialization. On finding an un-initialized thread, it waits till that thread completes its initialization, before proceeding to the next thread.

Return values
TM_ECODE_OKall initialized properly
TM_ECODE_FAILEDfailure

Definition at line 1948 of file tm-threads.c.

References ThreadVars_::name, ThreadVars_::next, SC_ATOMIC_GET, SCLogError, SCMutexLock, SCMutexUnlock, SleepUsec, THV_CLOSED, THV_DEAD, THV_FAILED, THV_INIT_DONE, TM_ECODE_FAILED, TM_ECODE_OK, TmThreadsCheckFlag(), tv, tv_root, tv_root_lock, and TVT_MAX.

Referenced by SuricataPostInit().

Here is the call graph for this function:
Here is the caller graph for this function:

◆ TmThreadWaitOnThreadRunning()

TmEcode TmThreadWaitOnThreadRunning ( void  )

Waits for all threads to be in a running state.

Return values
TM_ECODE_OKif all are running or error if a thread failed

Definition at line 1805 of file tm-threads.c.

References ThreadVars_::name, ThreadVars_::next, SC_ATOMIC_GET, SCLogError, SCLogNotice, SCMutexLock, SCMutexUnlock, SleepUsec, strlcat(), strlcpy(), thread_name_autofp, thread_name_flow_mgr, thread_name_flow_rec, thread_name_verdict, thread_name_workers, THV_CLOSED, THV_DEAD, THV_FAILED, THV_RUNNING, THV_RUNNING_DONE, TM_ECODE_FAILED, TM_ECODE_OK, TmThreadsCheckFlag(), tv, tv_root, tv_root_lock, and TVT_MAX.

Referenced by SuricataPostInit().

Here is the call graph for this function:
Here is the caller graph for this function:

Variable Documentation

◆ tv_root

◆ tv_root_lock