Searched refs:thread (Results 126 - 150 of 1148) sorted by relevance

1234567891011>>

/external/deqp/framework/delibs/deutil/
H A DdeTimer.c277 /* Generic thread-based implementation for OSes that lack proper timers. */
297 deThread thread; /*!< Thread. */ member in struct:deTimerThread_s
308 deTimerThread* curThread; /*!< Current timer thread. */
313 deTimerThread* thread = (deTimerThread*)arg; local
322 deMutex_lock(thread->lock);
324 if (thread->state == TIMERSTATE_SINGLE && numCallbacks > 0)
327 thread->state = TIMERSTATE_DISABLED;
330 else if (thread->state == TIMERSTATE_DISABLED)
333 deMutex_unlock(thread->lock);
335 sleepTime = thread
357 deTimerThread* thread = (deTimerThread*)deCalloc(sizeof(deTimerThread)); local
[all...]
/external/google-breakpad/src/tools/linux/md2core/
H A Dminidump-2-core.cc142 typedef struct prstatus { /* Information about thread; includes CPU reg*/
252 ParseThreadRegisters(CrashedProcess::Thread* thread, argument
256 thread->regs.ebx = rawregs->ebx;
257 thread->regs.ecx = rawregs->ecx;
258 thread->regs.edx = rawregs->edx;
259 thread->regs.esi = rawregs->esi;
260 thread->regs.edi = rawregs->edi;
261 thread->regs.ebp = rawregs->ebp;
262 thread->regs.eax = rawregs->eax;
263 thread
298 ParseThreadRegisters(CrashedProcess::Thread* thread, const MinidumpMemoryRange& range) argument
343 ParseThreadRegisters(CrashedProcess::Thread* thread, const MinidumpMemoryRange& range) argument
369 ParseThreadRegisters(CrashedProcess::Thread* thread, const MinidumpMemoryRange& range) argument
407 CrashedProcess::Thread thread; local
747 WriteThread(const CrashedProcess::Thread& thread, int fatal_signal) argument
904 const CrashedProcess::Thread& thread = crashinfo->threads[i]; local
[all...]
/external/webrtc/talk/app/webrtc/java/android/org/webrtc/
H A DThreadUtils.java39 * Utility class to be used for checking that a method is called on the correct thread.
42 private Thread thread = Thread.currentThread(); field in class:ThreadUtils.ThreadChecker
45 if (thread == null) {
46 thread = Thread.currentThread();
48 if (Thread.currentThread() != thread) {
49 throw new IllegalStateException("Wrong thread");
54 thread = null;
69 * work, e.g. cleanup, that must complete before returning. If the thread is interrupted during
71 * re-interrupt the thread.
91 public static boolean joinUninterruptibly(final Thread thread, lon argument
114 joinUninterruptibly(final Thread thread) argument
[all...]
/external/webrtc/webrtc/base/
H A Dasyncinvoker.cc39 void AsyncInvoker::Flush(Thread* thread, uint32_t id /*= MQID_ANY*/) { argument
42 // Run this on |thread| to reduce the number of context switches.
43 if (Thread::Current() != thread) {
44 thread->Invoke<void>(Bind(&AsyncInvoker::Flush, this, thread, id));
49 thread->Clear(this, id, &removed);
51 // This message was pending on this thread, so run it now.
52 thread->Send(it->phandler,
58 void AsyncInvoker::DoInvoke(Thread* thread, argument
65 thread
68 DoInvokeDelayed(Thread* thread, const scoped_refptr<AsyncClosure>& closure, uint32_t delay_ms, uint32_t id) argument
[all...]
/external/webrtc/webrtc/p2p/base/
H A Dtestrelayserver.h19 #include "webrtc/base/thread.h"
26 TestRelayServer(rtc::Thread* thread, argument
33 : server_(thread) {
35 thread->socketserver(), udp_int_addr));
37 thread->socketserver(), udp_ext_addr));
39 tcp_int_socket_.reset(CreateListenSocket(thread, tcp_int_addr));
40 tcp_ext_socket_.reset(CreateListenSocket(thread, tcp_ext_addr));
41 ssl_int_socket_.reset(CreateListenSocket(thread, ssl_int_addr));
42 ssl_ext_socket_.reset(CreateListenSocket(thread, ssl_ext_addr));
55 rtc::AsyncSocket* CreateListenSocket(rtc::Thread* thread, argument
[all...]
/external/fio/t/
H A Dread-to-pipe-async.c3 * longer than 'max_us' time, then we schedule a new thread to handle
66 pthread_t thread; member in struct:thread_data
73 struct thread_data thread; member in struct:writer_thread
83 struct thread_data thread; member in struct:reader_thread
97 pthread_t thread; member in struct:work_item
233 static void thread_exiting(struct thread_data *thread) argument
235 __sync_fetch_and_add(&thread->done, 1);
236 pthread_cond_signal(&thread->done_cond);
246 while (!wt->thread.exit || !flist_empty(&wt->list)) {
247 pthread_mutex_lock(&wt->thread
462 init_thread(struct thread_data *thread) argument
471 exit_thread(struct thread_data *thread, void fn(struct writer_thread *), struct writer_thread *wt) argument
[all...]
/external/libcups/cups/
H A Dthread.c20 #include "thread-private.h"
147 * '_cupsThreadCancel()' - Cancel (kill) a thread.
151 _cupsThreadCancel(_cups_thread_t thread)/* I - Thread ID */ argument
153 pthread_cancel(thread);
158 * '_cupsThreadCreate()' - Create a thread.
166 pthread_t thread; local
168 if (pthread_create(&thread, NULL, (void *(*)(void *))func, arg))
171 return (thread);
176 * '_cupsThreadWait()' - Wait for a thread to exit.
180 _cupsThreadWait(_cups_thread_t thread) /* argument
327 _cupsThreadCancel(_cups_thread_t thread) argument
351 _cupsThreadWait(_cups_thread_t thread) argument
478 _cupsThreadCancel(_cups_thread_t thread) argument
508 _cupsThreadWait(_cups_thread_t thread) argument
[all...]
/external/compiler-rt/test/tsan/
H A Dsignal_recursive.cc23 // Mono walks thread stacks to detect unreferenced objects.
42 // Acknowledge that thread is saved and suspended
50 // Acknowledge that thread restarted
63 static void StopWorld(pthread_t thread) { argument
64 if (pthread_kill(thread, kSigSuspend) != 0)
73 static void StartWorld(pthread_t thread) { argument
74 if (pthread_kill(thread, kSigRestart) != 0)
83 static void CollectGarbage(pthread_t thread) { argument
84 StopWorld(thread);
86 StartWorld(thread);
[all...]
/external/mesa3d/src/glx/apple/
H A Dapple_glx_log.c76 uint64_t thread = 0; local
80 thread = (uint64_t)(uintptr_t)pthread_self();
83 pthread_threadid_np(NULL, &thread);
85 thread = (uint64_t)(uintptr_t)pthread_self();
88 pthread_threadid_np(NULL, &thread);
97 _asl_level_string(level), file, line, function, thread);
117 asprintf(&_thread, "%"PRIu64, thread);
/external/webrtc/webrtc/examples/peerconnection/client/linux/
H A Dmain.cc19 #include "webrtc/base/thread.h"
23 CustomSocketServer(rtc::Thread* thread, GtkMainWnd* wnd) argument
24 : thread_(thread), wnd_(wnd), conductor_(NULL), client_(NULL) {}
34 // different thread. Alternatively we could look at merging the two loops
81 rtc::Thread* thread = rtc::Thread::Current(); local
82 CustomSocketServer socket_server(thread, &wnd);
83 thread->set_socketserver(&socket_server);
93 thread->Run();
98 thread->set_socketserver(NULL);
/external/google-breakpad/src/client/linux/dump_writer_common/
H A Dseccomp_unwinder.cc40 const MDRawThread& thread,
44 uint64_t top = thread.stack.start_of_memory_range;
47 bp > thread.stack.start_of_memory_range +
48 thread.stack.memory.data_size - sizeof(bp) ||
54 uint8_t* bp_addr = stack_copy + bp - thread.stack.start_of_memory_range;
80 thread.stack.start_of_memory_range+thread.stack.memory.data_size) {
107 uint32_t top = thread.stack.start_of_memory_range;
110 bp > thread.stack.start_of_memory_range +
111 thread
39 PopSeccompStackFrame(RawContextCPU* cpu, const MDRawThread& thread, uint8_t* stack_copy) argument
[all...]
/external/junit/src/main/java/org/junit/internal/runners/statements/
H A DFailOnTimeout.java63 * thread. This can be useful for disabling timeouts in environments
100 Thread thread = new Thread(task, "Time-limited test");
101 thread.setDaemon(true);
102 thread.start();
104 Throwable throwable = getResult(task, thread);
115 private Throwable getResult(FutureTask<Throwable> task, Thread thread) { argument
128 return createTimeoutException(thread);
132 private Exception createTimeoutException(Thread thread) { argument
133 StackTraceElement[] stackTrace = thread.getStackTrace();
137 thread
[all...]
/external/libchrome/sandbox/linux/services/
H A Dthread_helpers_unittests.cc18 #include "base/threading/thread.h"
61 base::Thread thread("sandbox_tests");
62 ASSERT_TRUE(ThreadHelpers::StartThreadAndWatchProcFS(proc_fd.fd(), &thread));
65 // Explicitly stop the thread here to not pollute the next test.
66 ASSERT_TRUE(ThreadHelpers::StopThreadAndWatchProcFS(proc_fd.fd(), &thread));
84 base::Thread thread("sandbox_tests");
86 ThreadHelpers::StartThreadAndWatchProcFS(proc_fd.fd(), &thread));
88 // Explicitly stop the thread here to not pollute the next test.
89 ASSERT_TRUE(ThreadHelpers::StopThreadAndWatchProcFS(proc_fd.fd(), &thread));
97 base::Thread thread("sandbox_test
[all...]
/external/libcxx/test/std/thread/thread.threads/thread.thread.class/thread.thread.constr/
H A DF.pass.cpp12 // <thread>
14 // class thread
16 // template <class F, class ...Args> thread(F&& f, Args&&... args);
20 #include <thread>
106 // A Each allocation performed during thread construction should be performed
107 // in the parent thread so that std::terminate is not called if
109 // B std::thread's constructor should properly handle exceptions and not leak
112 // 1 Create a thread and count the number of allocations, 'N', it performs.
114 // 2.1 check that the exception can be caught in the parent thread.
116 // 2.3 Check that no memory allocated by the creation of the thread i
[all...]
H A Dmove.pass.cpp12 // <thread>
14 // class thread
16 // thread(thread&& t);
18 #include <thread>
60 std::thread t0(g, 5, 5.5);
61 std::thread::id id = t0.get_id();
62 std::thread t1 = std::move(t0);
64 assert(t0.get_id() == std::thread::id());
/external/libmojo/mojo/edk/system/
H A Dawakable_list_unittest.cc26 // Cancel immediately after thread start.
29 test::SimpleWaiterThread thread(&result, &context);
30 awakable_list.Add(thread.waiter(), MOJO_HANDLE_SIGNAL_READABLE, 1);
31 thread.Start();
34 awakable_list.Remove(thread.waiter());
35 } // Join |thread|.
39 // Cancel before after thread start.
42 test::SimpleWaiterThread thread(&result, &context);
43 awakable_list.Add(thread.waiter(), MOJO_HANDLE_SIGNAL_WRITABLE, 2);
45 thread
[all...]
/external/compiler-rt/lib/msan/
H A Dmsan_thread.cc14 MsanThread *thread = (MsanThread*)MmapOrDie(size, __func__); local
15 thread->start_routine_ = start_routine;
16 thread->arg_ = arg;
17 thread->destructor_iterations_ = GetPthreadDestructorIterations();
19 return thread;
58 // We also clear the shadow on thread destruction because
71 // start_routine_ == 0 if we're on the main thread or on one of the
/external/libcxx/test/std/thread/thread.mutex/thread.mutex.requirements/thread.shared_mutex.requirements/thread.shared_mutex.class/
H A Dlock_shared.pass.cpp22 #include <thread>
72 std::vector<std::thread> v;
74 v.push_back(std::thread(f));
81 t = std::thread(g);
82 std::thread q(f);
/external/libcxx/test/std/thread/thread.mutex/thread.mutex.requirements/thread.sharedtimedmutex.requirements/thread.sharedtimedmutex.class/
H A Dlock_shared.pass.cpp22 #include <thread>
74 std::vector<std::thread> v;
76 v.push_back(std::thread(f));
83 t = std::thread(g);
84 std::thread q(f);
/external/autotest/client/cros/
H A Ddark_resume_listener.py35 # thread is set to daemon below, which means that the program will exit
36 # when the main thread exits.
41 thread = threading.Thread(None, loop_runner)
42 thread.daemon = True
43 thread.start()
/external/boringssl/src/crypto/
H A Dthread_test.cc54 static int wait_for_thread(thread_t thread) { argument
55 return WaitForSingleObject(thread, INFINITE) == 0;
77 static int wait_for_thread(thread_t thread) { argument
78 return pthread_join(thread, NULL) == 0;
161 thread_t thread; local
162 ASSERT_TRUE(run_thread(&thread, []() {
174 ASSERT_TRUE(wait_for_thread(thread));
176 EXPECT_TRUE(g_test_thread_ok) << "Thread-local data didn't work in thread.";
179 // Create a no-op thread to test test that the thread destructo
192 thread_t thread; local
[all...]
/external/deqp/external/glslang/
H A Dosinclude.cpp98 const deThread thread = (deThread)(deUintptr)((void**)threads)[ndx]; local
99 deThread_join(thread);
100 deThread_destroy(thread);
/external/libcxx/test/std/thread/thread.condition/thread.condition.condvar/
H A Ddestructor.pass.cpp20 #include <thread>
50 std::thread th2(g);
55 std::thread th1(f);
/external/libcxx/test/std/thread/thread.condition/thread.condition.condvarany/
H A Ddestructor.pass.cpp20 #include <thread>
51 std::thread th2(g);
56 std::thread th1(f);
/external/libcxx/test/std/thread/thread.threads/thread.thread.class/thread.thread.assign/
H A Dmove2.pass.cpp13 // <thread>
15 // class thread
17 // thread& operator=(thread&& t);
19 #include <thread>
60 std::thread t0(g, 5, 5.5);
61 std::thread t1;

Completed in 5670 milliseconds

1234567891011>>