Home
last modified time | relevance | path

Searched full:thread (Results 1 – 25 of 6508) sorted by relevance

12345678910>>...261

/external/valgrind/memcheck/tests/
Derr_disable4.stderr.exp4 WARNING: exiting thread has error reporting disabled.
7 WARNING: exiting thread has error reporting disabled.
10 WARNING: exiting thread has error reporting disabled.
13 WARNING: exiting thread has error reporting disabled.
16 WARNING: exiting thread has error reporting disabled.
19 WARNING: exiting thread has error reporting disabled.
22 WARNING: exiting thread has error reporting disabled.
25 WARNING: exiting thread has error reporting disabled.
28 WARNING: exiting thread has error reporting disabled.
31 WARNING: exiting thread has error reporting disabled.
[all …]
/external/webrtc/webrtc/base/
Dthread_unittest.cc17 #include "webrtc/base/thread.h"
52 Thread* post_thread, MessageHandler* phandler) in SocketClient()
77 Thread* post_thread_;
84 MessageClient(Thread* pth, Socket* socket) in MessageClient()
103 class CustomThread : public rtc::Thread {
110 return Thread::WrapCurrent(); in WrapCurrent()
113 Thread::UnwrapCurrent(); in UnwrapCurrent()
118 // A thread that does nothing when it runs and signals an event
120 class SignalWhenDestroyedThread : public Thread {
171 // Function objects to test Thread::Invoke.
[all …]
Dthread.cc11 #include "webrtc/base/thread.h"
44 Thread* Thread::Current() { in Current()
57 // maintaining thread safety using immutability within context of GCD dispatch in ThreadManager()
78 Thread *ThreadManager::CurrentThread() { in CurrentThread()
79 return static_cast<Thread *>(pthread_getspecific(key_)); in CurrentThread()
82 void ThreadManager::SetCurrentThread(Thread *thread) { in SetCurrentThread() argument
83 pthread_setspecific(key_, thread); in SetCurrentThread()
100 Thread *ThreadManager::CurrentThread() { in CurrentThread()
101 return static_cast<Thread *>(TlsGetValue(key_)); in CurrentThread()
104 void ThreadManager::SetCurrentThread(Thread *thread) { in SetCurrentThread() argument
[all …]
Dthread.h32 class Thread; variable
43 Thread* CurrentThread();
44 void SetCurrentThread(Thread* thread);
46 // Returns a thread object with its thread_ ivar set
47 // to whatever the OS uses to represent the thread.
48 // If there already *is* a Thread object corresponding to this thread,
49 // this method will return that. Otherwise it creates a new Thread
59 Thread *WrapCurrentThread();
76 Thread *thread; member
84 virtual void Run(Thread* thread) = 0;
[all …]
Dasyncinvoker.h18 #include "webrtc/base/thread.h"
22 // Invokes function objects (aka functors) asynchronously on a Thread, and
28 // AsyncInvoker does not own the thread it calls functors on.
39 // class that owns the Thread and AsyncInvoker objects, and then call its
45 // void FireAsyncTaskWithResult(Thread* thread, int x) {
48 // thread, Bind(&MyClass::AsyncTaskWithResult, this, x),
51 // void FireAnotherAsyncTask(Thread* thread) {
54 // thread, Bind(&MyClass::AnotherAsyncTask, this));
74 // Call |functor| asynchronously on |thread|, with no callback upon
77 void AsyncInvoke(Thread* thread, const FunctorT& functor, uint32_t id = 0) {
[all …]
/external/mockito/src/main/java/org/mockito/internal/util/concurrent/
DDetachedThreadLocal.java9 …* A detached local that allows for explicit control of setting and removing values from a thread-l…
12 * Instances of this class are non-blocking and fully thread safe.
16 final WeakConcurrentMap<Thread, T> map;
20 case THREAD: in DetachedThreadLocal()
22 map = new WeakConcurrentMap<Thread, T>(cleaner == Cleaner.THREAD) { in DetachedThreadLocal()
24 protected T defaultValue(Thread key) { in DetachedThreadLocal()
30 map = new WeakConcurrentMap.WithInlinedExpunction<Thread, T>() { in DetachedThreadLocal()
32 protected T defaultValue(Thread key) { in DetachedThreadLocal()
43 return map.get(Thread.currentThread()); in get()
47 map.put(Thread.currentThread(), value); in set()
[all …]
/external/guava/guava-tests/test/com/google/common/util/concurrent/
DThreadFactoryBuilderTest.java25 import java.lang.Thread.UncaughtExceptionHandler;
44 @Override public void uncaughtException(Thread t, Throwable e) {
58 Thread thread = threadFactory.newThread(monitoredRunnable); in testThreadFactoryBuilder_defaults() local
59 checkThreadPoolName(thread, 1); in testThreadFactoryBuilder_defaults()
61 Thread defaultThread = in testThreadFactoryBuilder_defaults()
63 assertEquals(defaultThread.isDaemon(), thread.isDaemon()); in testThreadFactoryBuilder_defaults()
64 assertEquals(defaultThread.getPriority(), thread.getPriority()); in testThreadFactoryBuilder_defaults()
65 assertSame(defaultThread.getThreadGroup(), thread.getThreadGroup()); in testThreadFactoryBuilder_defaults()
67 thread.getUncaughtExceptionHandler()); in testThreadFactoryBuilder_defaults()
70 thread.start(); in testThreadFactoryBuilder_defaults()
[all …]
/external/libchrome/base/threading/
Dplatform_thread_unittest.cc24 // Trivial tests that thread runs and doesn't crash on create, join, or detach -
46 TrivialThread thread; in TEST() local
49 ASSERT_FALSE(thread.run_event().IsSignaled()); in TEST()
50 ASSERT_TRUE(PlatformThread::Create(0, &thread, &handle)); in TEST()
52 ASSERT_TRUE(thread.run_event().IsSignaled()); in TEST()
56 TrivialThread thread[10]; in TEST() local
57 PlatformThreadHandle handle[arraysize(thread)]; in TEST()
59 for (size_t n = 0; n < arraysize(thread); n++) in TEST()
60 ASSERT_FALSE(thread[n].run_event().IsSignaled()); in TEST()
61 for (size_t n = 0; n < arraysize(thread); n++) in TEST()
[all …]
Dthread.h28 // A simple thread abstraction that establishes a MessageLoop on a new thread.
29 // The consumer uses the MessageLoop of the thread to cause code to execute on
30 // the thread. When this object is destroyed the thread is terminated. All
31 // pending tasks queued on the thread's message loop will run to completion
32 // before the thread is terminated.
34 // WARNING! SUBCLASSES MUST CALL Stop() IN THEIR DESTRUCTORS! See ~Thread().
36 // After the thread is stopped, the destruction sequence is:
38 // (1) Thread::CleanUp()
41 class BASE_EXPORT Thread : PlatformThread::Delegate {
51 // Specifies the type of message loop that will be allocated on the thread.
[all …]
Dthread.cc5 #include "base/threading/thread.h"
25 // We use this thread-local variable to record whether or not a thread exited
28 // using a Thread to setup and run a MessageLoop.
37 Thread::SetThreadWasQuitProperly(true); in ThreadQuitHelper()
40 Thread::Options::Options() in Options()
47 Thread::Options::Options(MessageLoop::Type type, in Options()
55 Thread::Options::Options(const Options& other) = default;
57 Thread::Options::~Options() { in ~Options()
60 Thread::Thread(const std::string& name) in Thread() function in base::Thread
78 Thread::~Thread() { in ~Thread()
[all …]
Dplatform_thread.h7 // You should instead be using a message-loop driven Thread, see thread.h.
35 // Used for thread checking and debugging.
38 // check if we are on the same thread or not by using ==. These are safe
41 // after a thread dies, so a PlatformThreadRef cannot be reliably used
42 // to distinguish a new thread from an old, dead thread.
100 // Valid values for priority of Thread::Options and SimpleThread::Options, and
113 // A namespace for low-level thread functions.
116 // Implement this interface to run code on a background thread. Your
117 // ThreadMain method will be called on the newly created thread.
126 // Gets the current thread id, which may be useful for logging purposes.
[all …]
/external/libmojo/third_party/catapult/devil/devil/utils/
Dreraiser_thread.py5 """Thread and ThreadGroup that reraise exceptions on the main thread."""
22 def LogThreadStack(thread, error_log_func=logging.critical): argument
23 """Log the stack for the given thread.
26 thread: a threading.Thread instance.
29 stack = sys._current_frames()[thread.ident]
31 error_log_func('Stack dump for thread %r', thread.name)
40 class ReraiserThread(threading.Thread):
41 """Thread class that can reraise exceptions."""
44 """Initialize thread.
47 func: callable to call on a new thread.
[all …]
/external/chromium-trace/catapult/devil/devil/utils/
Dreraiser_thread.py5 """Thread and ThreadGroup that reraise exceptions on the main thread."""
22 def LogThreadStack(thread, error_log_func=logging.critical): argument
23 """Log the stack for the given thread.
26 thread: a threading.Thread instance.
29 stack = sys._current_frames()[thread.ident]
31 error_log_func('Stack dump for thread %r', thread.name)
40 class ReraiserThread(threading.Thread):
41 """Thread class that can reraise exceptions."""
44 """Initialize thread.
47 func: callable to call on a new thread.
[all …]
/external/deqp/framework/delibs/dethread/unix/
DdeThreadUnix.c2 * drawElements Thread Library
21 * \brief Unix implementation of thread management.
51 pthread_t thread; member
54 } Thread; typedef
56 DE_STATIC_ASSERT(sizeof(deThread) >= sizeof(Thread*));
60 Thread* thread = (Thread*)entryPtr; in startThread() local
61 deThreadFunc func = thread->func; in startThread()
62 void* arg = thread->arg; in startThread()
64 /* Start actual thread. */ in startThread()
73 Thread* thread = (Thread*)deCalloc(sizeof(Thread)); in deThread_create() local
[all …]
/external/libmojo/mojo/edk/system/
Dwaiter_unittest.cc80 Waiter waiter_; // Thread-safe.
98 // Awake immediately after thread start. in TEST()
100 WaitingThread thread(10 * test::EpsilonDeadline()); in TEST() local
101 thread.Start(); in TEST()
102 thread.waiter()->Awake(MOJO_RESULT_OK, 1); in TEST()
103 thread.WaitUntilDone(&result, &context, &elapsed); in TEST()
109 // Awake before after thread start. in TEST()
111 WaitingThread thread(10 * test::EpsilonDeadline()); in TEST() local
112 thread.waiter()->Awake(MOJO_RESULT_CANCELLED, 2); in TEST()
113 thread.Start(); in TEST()
[all …]
Dawakable_list_unittest.cc26 // Cancel immediately after thread start. in TEST()
29 test::SimpleWaiterThread thread(&result, &context); in TEST() local
30 awakable_list.Add(thread.waiter(), MOJO_HANDLE_SIGNAL_READABLE, 1); in TEST()
31 thread.Start(); in TEST()
34 awakable_list.Remove(thread.waiter()); in TEST()
35 } // Join |thread|. in TEST()
39 // Cancel before after thread start. in TEST()
42 test::SimpleWaiterThread thread(&result, &context); in TEST() local
43 awakable_list.Add(thread.waiter(), MOJO_HANDLE_SIGNAL_WRITABLE, 2); in TEST()
45 thread.Start(); in TEST()
[all …]
/external/elfutils/libdwfl/
Ddwfl_frame.c46 Ebl *ebl = state->thread->process->ebl; in state_fetch_pc()
73 Dwfl_Thread *thread = state->thread; in state_free() local
74 assert (thread->unwound == state); in state_free()
75 thread->unwound = state->unwound; in state_free()
80 thread_free_all_states (Dwfl_Thread *thread) in thread_free_all_states() argument
82 while (thread->unwound) in thread_free_all_states()
83 state_free (thread->unwound); in thread_free_all_states()
87 state_alloc (Dwfl_Thread *thread) in state_alloc() argument
89 assert (thread->unwound == NULL); in state_alloc()
90 Ebl *ebl = thread->process->ebl; in state_alloc()
[all …]
/external/python/cpython2/Lib/test/
Dtest_threading.py10 thread = test.test_support.import_module('thread') variable
35 class TestThread(threading.Thread):
37 threading.Thread.__init__(self, name=name)
93 t = TestThread("<thread %d>"%i, self, sema, mutex, numrunning)
112 # The ident still must work for the main thread and dummy threads.
119 thread.start_new_thread(f, ())
125 # run with a small(ish) thread stack size (256kB)
128 print 'with 256kB thread stack size...'
131 except thread.error:
132 self.skipTest('platform does not support changing thread stack size')
[all …]
/external/nist-sip/java/gov/nist/core/
DThreadAuditor.java6 * Thread Auditor class:
15 * the thread can periodically ping the auditor.
25 private Map<Thread,ThreadHandle> threadHandles = new HashMap<Thread,ThreadHandle>();
32 /// Set to true when the thread pings, periodically reset to false by the auditor
35 /// Thread being monitored
36 private Thread thread; field in ThreadAuditor.ThreadHandle
38 /// Thread auditor monitoring this thread
44 thread = Thread.currentThread(); in ThreadHandle()
48 /// Called by the auditor thread to check the ping status of the thread
53 /// Called by the auditor thread to reset the ping status of the thread
[all …]
/external/libcxx/include/
Dthread2 //===--------------------------- thread -----------------------------------===//
16 thread synopsis
23 class thread
29 thread() noexcept;
30 template <class F, class ...Args> explicit thread(F&& f, Args&&... args);
31 ~thread();
33 thread(const thread&) = delete;
34 thread(thread&& t) noexcept;
36 thread& operator=(const thread&) = delete;
37 thread& operator=(thread&& t) noexcept;
[all …]
/external/python/cpython2/Doc/library/
Dthreading.rst12 level :mod:`thread` module.
16 :mod:`threading` cannot be used because :mod:`thread` is missing.
29 Starting with Python 2.5, several Thread methods raise :exc:`RuntimeError`
34 In CPython, due to the :term:`Global Interpreter Lock`, only one thread
48 Return the number of :class:`Thread` objects currently alive. The returned
60 thread.
68 Return the current :class:`Thread` object, corresponding to the caller's thread
69 of control. If the caller's thread of control was not created through the
70 :mod:`threading` module, a dummy thread object with limited functionality is
79 Return a list of all :class:`Thread` objects currently alive. The list
[all …]
/external/valgrind/drd/tests/
Dtc22_exit_w_lock.stderr.exp-32bit2 Conflicting load by thread 1 at 0x........ size 4
9 Other segment start (thread 2)
10 (thread finished, call stack no longer available)
11 Other segment end (thread 2)
12 (thread finished, call stack no longer available)
14 Conflicting store by thread 1 at 0x........ size 4
21 Other segment start (thread 2)
22 (thread finished, call stack no longer available)
23 Other segment end (thread 2)
24 (thread finished, call stack no longer available)
[all …]
/external/ltp/testcases/open_posix_testsuite/conformance/interfaces/pthread_rwlock_unlock/
D1-1.c19 * 2. Main thread read lock 'rwlock'
20 * 3. Create a child thread, the thread read lock 'rwlock', should not block
21 * 4. Child thread unlock 'rwlock', while the main thread still hold the read lock.
22 * 5. Child thread read lock 'rwlock' again, should succeed, then unlock again
23 * 6. Child thread write lock 'rwlock', should block
24 * 7. Main thread unlock the read lock, the 'rwlock' is in unlocked state
25 * 8. Child thread should get the lock for writing.
37 /* thread_state indicates child thread state:
38 1: not in child thread yet;
39 2: just enter child thread ;
[all …]
/external/python/cpython2/Lib/
Dthreading.py1 """Thread module emulating a subset of Java's threading model."""
6 import thread
32 'Lock', 'RLock', 'Semaphore', 'BoundedSemaphore', 'Thread',
35 _start_new_thread = thread.start_new_thread
36 _allocate_lock = thread.allocate_lock
37 _get_ident = thread.get_ident
38 ThreadError = thread.error
39 del thread
73 name = "<OS thread %d>" % ident
93 The func will be passed to sys.setprofile() for each thread, before its
[all …]
/external/autotest/client/tests/monotonic_time/src/
Dthreads.c19 typedef struct thread { struct
20 pthread_t thread; member
31 * Helper function to run a thread on a specific set of CPUs. argument
35 thread_t *thread = arg; in run_thread() local
38 if (sched_setaffinity(0, sizeof thread->cpus, &thread->cpus) < 0) in run_thread()
41 result = thread->func(thread->arg); in run_thread()
58 thread_t *thread; in create_per_cpu_threads() local
64 thread = &threads[num_threads++]; in create_per_cpu_threads()
65 thread->func = func; in create_per_cpu_threads()
66 thread->arg = arg; in create_per_cpu_threads()
[all …]

12345678910>>...261