HomeSort by relevance Sort by last modified time
    Searched defs:Worker (Results 1 - 25 of 55) sorted by null

1 2 3

  /external/v8/test/mjsunit/regress/
regress-crbug-518747.js 5 if (this.Worker) {
6 Worker.prototype = 12;
7 var __v_6 = new Worker('');
  /external/webrtc/webrtc/base/
worker.cc 11 #include "webrtc/base/worker.h"
23 Worker::Worker() : worker_thread_(NULL) {}
25 Worker::~Worker() {
32 bool Worker::StartWork() {
49 bool Worker::StopWork() {
64 void Worker::HaveWork() {
69 void Worker::OnMessage(rtc::Message *msg) {
worker.h 21 // A worker is an object that performs some specific long-lived task in an
27 // each other, and it is an error to call them while the worker is running on
29 // The destructor may not be called if the worker is currently running
32 class Worker : private MessageHandler {
34 Worker();
36 // Destroys this Worker, but it must have already been stopped via StopWork().
37 ~Worker() override;
39 // Attaches the worker to the current thread and begins processing work if not
52 // Called on the worker thread to start working.
54 // Called on the worker thread when work has been signalled via HaveWork()
    [all...]
signalthread.cc 108 // Before signaling that the work is done, make sure that the worker
110 // Run() posted the ST_MSG_WORKER_DONE message. This means the worker
115 // Calling Stop() on the worker ensures that the OS thread that underlies
116 // the worker will finish, and will be set to NULL, enabling us to call
127 SignalThread::Worker::~Worker() {
131 void SignalThread::Worker::Run() {
signalthread.h 23 // SignalThread - Base class for worker threads. The main thread should call
26 // Cancellation: Call Release(true), to abort the worker thread.
45 // Context: Main Thread. Call before Start to change the worker's name.
48 // Context: Main Thread. Call to begin the worker thread.
51 // Context: Main Thread. If the worker thread is not running, deletes the
52 // object immediately. Otherwise, asks the worker thread to abort processing,
53 // and schedules the object to be deleted once the worker exits.
58 // Context: Main Thread. If the worker thread is complete, deletes the
60 // the worker thread completes. SignalWorkDone will be signalled.
71 Thread* worker() { return &worker_; function in class:rtc::SignalThread
    [all...]
  /external/compiler-rt/test/tsan/
mmap_stress.cc 28 void *Worker(void *arg) {
41 pthread_create(&th[i], 0, Worker, 0);
  /external/drm_hwcomposer/
worker.h 26 class Worker {
40 Worker(const char *name, int priority);
41 virtual ~Worker();
58 static void *InternalRoutine(void *worker);
worker.cpp 17 #define LOG_TAG "hwc-drm-worker"
19 #include "worker.h"
34 Worker::Worker(const char *name, int priority)
38 Worker::~Worker() {
47 int Worker::InitWorker() {
75 bool Worker::initialized() const {
79 int Worker::Lock() {
83 int Worker::Unlock()
165 Worker *worker = (Worker *)arg; local
    [all...]
  /prebuilts/gdb/darwin-x86/lib/python2.7/test/
threaded_import_hangers.py 21 class Worker(threading.Thread):
38 t = Worker(func, args)
  /prebuilts/gdb/linux-x86/lib/python2.7/test/
threaded_import_hangers.py 21 class Worker(threading.Thread):
38 t = Worker(func, args)
  /prebuilts/python/darwin-x86/2.7.5/lib/python2.7/test/
threaded_import_hangers.py 21 class Worker(threading.Thread):
38 t = Worker(func, args)
  /prebuilts/python/linux-x86/2.7.5/lib/python2.7/test/
threaded_import_hangers.py 21 class Worker(threading.Thread):
38 t = Worker(func, args)
  /external/caliper/caliper/src/main/java/com/google/caliper/worker/
Worker.java 16 package com.google.caliper.worker;
28 * A {@link Worker} collects measurements on behalf of a particular Instrument.
30 public abstract class Worker {
42 protected Worker(Object benchmark, Method method) {
  /external/opencv3/samples/gpu/
multi.cpp 47 struct Worker { void operator()(int device_id) const; };
73 tbb::parallel_do(devices, devices + 2, Worker());
79 void Worker::operator()(int device_id) const
driver_api_multi.cpp 54 struct Worker { void operator()(int device_id) const; };
114 tbb::parallel_do(devices, devices + 2, Worker());
121 void Worker::operator()(int device_id) const
driver_api_stereo_multi.cpp 56 struct Worker { void operator()(int device_id) const; };
177 tbb::parallel_do(devices, devices + 2, Worker());
203 void Worker::operator()(int device_id) const
  /external/valgrind/none/tests/darwin/
bug228343.c 35 void *Worker() {
53 pthread_create(&w_1, NULL, Worker, NULL);
54 pthread_create(&w_2, NULL, Worker, NULL);
  /external/clang/test/SemaCXX/
arrow-operator.cpp 53 class Worker {
60 wrapped_ptr<Worker> worker(new Worker);
61 worker.DoSomething(); // expected-error {{no member named 'DoSomething' in 'arrow_suggest::wrapped_ptr<arrow_suggest::Worker>'; did you mean to use '->' instead of '.'?}}
62 worker.DoSamething(); // expected-error {{no member named 'DoSamething' in 'arrow_suggest::wrapped_ptr<arrow_suggest::Worker>'; did you mean to use '->' instead of '.'?}} \
63 // expected-error {{no member named 'DoSamething' in 'arrow_suggest::Worker'; did you mean 'DoSomething'?}}
64 worker.Chuck(); // expected-error {{no member named 'Chuck' in 'arrow_suggest::wrapped_ptr<arrow_suggest: (…)
    [all...]
  /external/v8/tools/testrunner/local/
pool.py 44 def Worker(fn, work_queue, done_queue, done,
46 """Worker to be run in a child process.
47 The worker stops on two conditions. 1. When the poison pill "STOP" is
67 """Distributes tasks to a number of worker processes.
82 # worker takes an item from the work_queue and before the result is
83 # submitted to the done_queue. It is equal when no worker is working,
96 """Maps function "fn" to items in generator "gen" on the worker processes
104 process_context_fn: Function executed once by each worker. Expected to
117 p = Process(target=Worker, args=(fn,
143 # A keyboard interrupt happened in one of the worker processes
    [all...]
  /external/snakeyaml/src/test/java/org/yaml/snakeyaml/stress/
ParallelTest.java 34 Worker worker = new Worker(i, doc); local
35 Thread thread = new Thread(worker);
47 private class Worker implements Runnable {
51 public Worker(int id, String doc) {
  /external/clang/test/Sema/
attr-capabilities.c 27 ThreadRole GUI, Worker;
29 void Func2(void) __attribute__((requires_shared_capability(Worker))) {}
61 void Func28(void) __attribute__((requires_capability(GUI && Worker)));
62 void Func29(void) __attribute__((requires_capability(GUI || Worker)));
63 void Func30(void) __attribute__((requires_capability((Worker || Worker) && !GUI)));
  /external/icu/android_icu4j/src/main/tests/android/icu/dev/test/translit/
ThreadTest.java 25 private ArrayList<Worker> threads = new ArrayList<Worker>();
35 Worker thread = new Worker();
40 for (Worker thread: threads) {
58 private class Worker extends Thread {
  /external/icu/icu4j/main/tests/translit/src/com/ibm/icu/dev/test/translit/
ThreadTest.java 21 private ArrayList<Worker> threads = new ArrayList<Worker>();
31 Worker thread = new Worker();
36 for (Worker thread: threads) {
54 private class Worker extends Thread {
  /packages/apps/QuickSearchBox/src/com/android/quicksearchbox/util/
SingleThreadNamedTaskExecutor.java 38 mWorker = threadFactory.newThread(new Worker());
63 private class Worker implements Runnable {
68 if (!mClosed) Log.w(TAG, "Worker exited before close");
  /external/gemmlowp/internal/
multi_thread_gemm.h 116 // (e.g. worker threads having finished a GEMM and waiting until the next GEMM)
149 // This is how the master thread waits for all the worker threads
205 // A workload for a worker.
213 // A worker thread.
214 class Worker {
223 explicit Worker(BlockingCounter* counter_to_decrement_when_ready)
232 ~Worker() {
237 // Changes State; may be called from either the worker thread
241 ScopedProfilingLabel label("Worker::ChangeState");
269 ScopedProfilingLabel label("Worker::ThreadFunc")
    [all...]

Completed in 682 milliseconds

1 2 3