Searched refs:thread (Results 201 - 225 of 688) sorted by relevance

1234567891011>>

/macosx-10.10/xnu-2782.1.97/bsd/sys/
H A Dsignalvar.h117 * Check for per-process and per thread signals.
126 * Check for signals and per-thread signals.
130 #define CHECK_SIGNALS(p, thread, uthreadp) \
131 (!thread_should_halt(thread) \
195 void execsigs(struct proc *p, thread_t thread);
220 void psignal_vfork(struct proc *p, task_t new_task, thread_t thread,
/macosx-10.10/xnu-2782.1.97/iokit/IOKit/
H A Dsystem.h50 #include <kern/thread.h>
/macosx-10.10/xnu-2782.1.97/osfmk/kdp/ml/x86_64/
H A Dkdp_vm.c38 #include <i386/thread.h>
60 kern_collectth_state(thread_t thread, void *buffer, size_t size) argument
67 * Fill in thread command structure.
80 * the appropriate thread state struct for each
81 * thread state flavor.
97 * for this kernel thread. This should ideally be
108 if ((current_thread() == thread) && (cpstate != NULL)) {
130 } else if ((kstack = thread->kernel_stack) != 0){
/macosx-10.10/xnu-2782.1.97/osfmk/kern/
H A Dmachine.h87 thread_t thread,
H A Dprocessor.c75 #include <kern/thread.h>
441 thread_t thread; local
476 * Create the idle processor thread.
492 * If there is no active thread, the processor
494 * start up thread.
498 result = kernel_thread_create((thread_continue_t)processor_start_thread, NULL, MAXPRI_KERNEL, &thread);
510 thread_lock(thread);
511 thread->bound_processor = processor;
512 processor->next_thread = thread;
513 thread
881 thread_t thread, *thread_list = (thread_t *)addr; local
[all...]
H A Dtelemetry.h35 #include <kern/thread.h>
H A Dtimer.h72 * at key points in the thread structure (when the thread is locked and
78 * thread must be locked, or be the current executing thread, so that
80 * thread-local value (or in kernel debugger context). In the future,
81 * we make take into account task-level or thread-level policy.
83 #define use_precise_user_kernel_time(thread) ( precise_user_kernel_time )
123 /* Update the thread timer at an event */
H A Dsync_sema.c52 #include <kern/thread.h>
104 thread_t thread,
301 thread_t thread,
316 if (thread != THREAD_NULL) {
321 thread,
377 * If the specified thread is blocked on the semaphore, it is
378 * woken up. If a NULL thread was supplied, then any one
379 * thread is woken up. Otherwise the caller gets KERN_NOT_WAITING
385 thread_t thread)
393 thread,
299 semaphore_signal_internal( semaphore_t semaphore, thread_t thread, int options) argument
383 semaphore_signal_thread( semaphore_t semaphore, thread_t thread) argument
410 thread_t thread; local
[all...]
H A Dtask.h149 #include <kern/thread.h>
265 #define TF_CPUMON_WARNING 0x00000004 /* task has at least one thread in CPU usage warning zone */
299 uint8_t rusage_cpu_perthr_percentage; /* Per-thread CPU limit percentage */
300 uint64_t rusage_cpu_perthr_interval; /* Per-thread CPU limit interval */
556 extern kern_return_t check_actforsig(task_t task, thread_t thread, int setast);
614 /* internal or external, thread or task */
641 /* thread-only attributes */
651 extern void proc_set_task_policy(task_t task, thread_t thread, int category, int flavor, int value);
652 extern int proc_get_task_policy(task_t task, thread_t thread, int category, int flavor);
655 extern void proc_set_task_policy2(task_t task, thread_t thread, in
[all...]
H A Dwait_queue.h110 * queue. It is the common first fields in a thread shuttle
112 * consist of both thread shuttle elements and links off of
115 * WARNING: These fields correspond to fields in the thread
121 void * wqe_type; /* Identifies link vs. thread */
131 * can be constructed so that any thread waiting on any number
133 * the thread only be linked on the single wait queue it blocked on.
135 * One use: ports in multiple portsets. Each thread is queued up
139 * with that port may wake up any thread from any of those portsets,
179 * a problem with a thread lock, it normally times out at the wait
217 #define wait_queue_assert_possible(thread) \
[all...]
/macosx-10.10/JavaScriptCore-7600.1.17/heap/
H A DGCThread.cpp91 // Wait for the main thread to finish creating and initializing us. The main thread grabs this lock before
92 // creating this thread. We aren't guaranteed to have a valid threadID until the main thread releases this lock.
104 // GCThreads only return from drainFromShared() if the main thread sets the m_parallelMarkersShouldExit
105 // flag in the GCThreadSharedData. The only way the main thread sets that flag is if it realizes
110 // We don't have to call startCopying() because it's called for us on the main thread to avoid a
115 // more copying work to do, the main thread will wait in CopiedSpace::doneCopying() until
133 GCThread* thread = static_cast<GCThread*>(data); local
134 thread
[all...]
/macosx-10.10/WebCore-7600.1.25/storage/
H A DStorageThread.cpp64 void StorageThread::threadEntryPointCallback(void* thread) argument
66 static_cast<StorageThread*>(thread)->threadEntryPoint();
91 // Even in weird, exceptional cases, don't wait on a nonexistent thread to terminate.
/macosx-10.10/cups-408/cups/cups/
H A Dthread.c22 #include "thread-private.h"
104 * '_cupsThreadCreate()' - Create a thread.
112 pthread_t thread; local
114 return (pthread_create(&thread, NULL, (void *(*)(void *))func, arg) == 0);
214 * '_cupsThreadCreate()' - Create a thread.
306 * '_cupsThreadCreate()' - Create a thread.
314 fputs("DEBUG: CUPS was compiled without threading support, no thread "
/macosx-10.10/pyobjc-45/2.6/pyobjc/pyobjc-core/libxml2-src/python/tests/
H A Dthread2.py3 import thread
31 # check a per thread-global
35 "lineNumbersDefault in thread %d" % thread.get_ident()
37 # (which is NOT per-thread in the python bindings)
49 # set on the main thread only
60 # the new value has been set on the main thread only
/macosx-10.10/xnu-2782.1.97/osfmk/mach/
H A Dsemaphore.h92 thread_t thread);
109 thread_t thread);
/macosx-10.10/IOFireWireFamily-456/IOFireWireFamily.kmodproj/
H A DIOFireWireUnit.cpp334 // retain since device->close() could start a termination thread
345 retain(); // will be released in thread function
347 thread_t thread; local
348 if( kernel_thread_start((thread_continue_t)IOFireWireUnit::terminateUnitThreadFunc, this, &thread) == KERN_SUCCESS )
350 thread_deallocate(thread);
367 // retain since we could start a termination thread
393 retain(); // will be released in thread function
395 thread_t thread; local
396 if( kernel_thread_start((thread_continue_t)IOFireWireUnit::terminateUnitThreadFunc, this, &thread) == KERN_SUCCESS )
398 thread_deallocate(thread);
[all...]
/macosx-10.10/JavaScriptCore-7600.1.17/runtime/
H A DJSLock.cpp29 #include <thread>
81 : m_ownerThreadID(std::thread::id())
100 void JSLock::setExclusiveThread(std::thread::id threadId)
102 RELEASE_ASSERT(!m_lockCount && m_ownerThreadID == std::thread::id());
103 m_hasExclusiveThread = (threadId != std::thread::id());
132 // FIXME: What should happen to the per-thread identifier table if we don't have a VM?
166 m_ownerThreadID = std::thread::id();
209 // Check if this thread is currently holding the lock.
/macosx-10.10/tcl-105/tcl84/tcl/win/
H A Dbuildall.vc.bat34 :: Build the core and shell for thread support.
39 :: Build a static, thread support core library (no shell).
45 :: but now with thread support.
/macosx-10.10/tcl-105/tk84/tk/win/
H A Dbuildall.vc.bat39 :: Build the core and shell for thread support.
44 :: Build a static, thread support core library (no shell).
50 :: but now with thread support.
/macosx-10.10/WebCore-7600.1.25/workers/
H A DDefaultSharedWorkerRepository.cpp70 void setThread(PassRefPtr<SharedWorkerThread> thread) { m_thread = thread; } argument
71 SharedWorkerThread* thread() { return m_thread.get(); } function in class:WebCore::SharedWorkerProxy
103 GroupSettings* groupSettings() const; // Page GroupSettings used by worker thread.
112 // The thread is freed when the proxy is destroyed, so we need to make sure that the proxy stays around until the SharedWorkerGlobalScope exits.
126 // We should be the sole owner of the SecurityOrigin, as we will free it on another thread.
250 // Stop the worker thread - the proxy will stay around until we get workerThreadExited() notification.
263 // Since close() stops the thread event loop, this should not ever get called while closing.
317 // Hand off the just-loaded code to the repository to start up the worker thread.
353 // Another loader may have already started up a thread fo
355 RefPtr<SharedWorkerThread> thread = SharedWorkerThread::create(proxy.name(), proxy.url(), userAgent, proxy.groupSettings(), workerScript, proxy, proxy, DontPauseWorkerGlobalScopeOnStart, contentSecurityPolicy, contentSecurityPolicyType); local
[all...]
/macosx-10.10/emacs-93/emacs/lisp/gnus/
H A Dgnus-salt.el84 "u" gnus-pick-unmark-article-or-thread
85 "." gnus-pick-article-or-thread
96 ["Thread" gnus-uu-mark-thread t]
102 ["Thread" gnus-uu-unmark-thread t]
192 (defun gnus-pick-article-or-thread (&optional arg)
193 "If `gnus-thread-hide-subtree' is t, then pick the thread on the current line.
195 If ARG, pick the article/thread on that line instead."
199 (if gnus-thread-hide-subtree
202 (gnus-uu-mark-thread))
[all...]
/macosx-10.10/apr-32/apr/apr/test/
H A Dtestcond.c124 apr_thread_t *thread[NTHREADS]; local
144 rv = apr_thread_create(&thread[i], NULL, thread_routine, &box[i], p);
167 rv = apr_thread_join(&retval, thread[i]);
208 apr_thread_t *thread[NTHREADS]; local
228 rv = apr_thread_create(&thread[i], NULL, thread_routine, &box, p);
248 rv = apr_thread_join(&retval, thread[i]);
309 apr_thread_t *thread = NULL; local
328 rv = apr_thread_create(&thread, NULL, thread_routine, &box, p);
340 rv = apr_thread_join(&retval, thread);
390 * a solid test to ensure one thread i
433 apr_thread_t *thread[NTHREADS]; local
[all...]
/macosx-10.10/xnu-2782.1.97/tools/lldbmacros/
H A Dmisc.py162 associated with each thread, timer time-to-deadline frequencies, and
163 CPU time with user/system break down where applicable, with thread tags.
168 print '{:d}({:s}), terminated thread timer wakeups: {:d} {:d} 2ms: {:d} 5ms: {:d} UT: {:d} ST: {:d}'.format(
180 for thread in IterateQueue(task.threads, 'thread_t', 'task_threads'):
181 # if thread.thread_interrupt_wakeups == 0:
184 thread.thread_id,
185 thread.thread_tag,
186 0, #thread.thread_interrupt_wakeups,
187 0, #thread.thread_platform_idle_wakeups,
188 0, #thread
[all...]
/macosx-10.10/dcerpc-61/dcerpc/include/dce/
H A Ddcethread.h110 /* Opaque thread type */
162 void dcethread_signal_to_interrupt(sigset_t *sigset, dcethread* thread);
197 int dcethread_detach(dcethread *thread);
198 int dcethread_detach_throw(dcethread *thread);
200 int dcethread_join(dcethread* thread, void **status);
201 int dcethread_join_throw(dcethread* thread, void **status);
203 int dcethread_setprio(dcethread* thread, int priority);
204 int dcethread_setprio_throw(dcethread* thread, int priority);
206 int dcethread_getprio(dcethread* thread);
207 int dcethread_getprio_throw(dcethread* thread);
[all...]
/macosx-10.10/libauto-186/
H A DThreadLocalCollector.cpp55 // Validates that block is a thread local block start pointer.
194 // we can't return to the general pool because the general collector thread may
297 // TODO: if we keep hitting this condition, we could use feedback to increase the thread local threshold.
317 auto_error(_zone, "not thread local garbage", (const void *)block);
326 // if the thread is not suspended then we can also possibly shrink the locals list size
327 // if the thread IS suspended then we must not allocate
396 bool ThreadLocalCollector::should_collect(Zone *zone, Thread &thread, bool canFinalizeNow) { argument
397 if (thread.thread_local_collector() == NULL) {
400 // bare minimum number of thread local objects. I strongly suggest that we also consider allocation thresholds
402 return (thread
413 should_collect_suspended(Thread &thread) argument
432 operator ()(Thread *thread, Range &range) argument
[all...]

Completed in 435 milliseconds

1234567891011>>