HomeSort by relevance Sort by last modified time
    Searched refs:Worker (Results 26 - 50 of 121) sorted by null

12 3 4 5

  /external/webrtc/webrtc/base/
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() {
  /external/drm_hwcomposer/
vsyncworker.h 21 #include "worker.h"
31 class VSyncWorker : public Worker {
queue_worker.h 20 #include "worker.h"
27 class QueueWorker : public Worker {
33 : Worker(name, priority),
  /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) {
MacrobenchmarkAllocationWorker.java 17 package com.google.caliper.worker;
29 * The {@link Worker} for the {@code AllocationInstrument}. This class invokes the benchmark method
33 public final class MacrobenchmarkAllocationWorker extends Worker {
  /external/compiler-rt/test/tsan/
mmap_stress.cc 35 void *Worker(void *arg) {
56 if (pthread_create(&th[i], 0, Worker, 0))
  /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");
  /packages/apps/Settings/src/com/android/settings/dashboard/
SummaryLoader.java 54 private final Worker mWorker;
70 mWorker = new Worker(mWorkerThread.getLooper());
76 mWorker.obtainMessage(Worker.MSG_GET_PROVIDER, tile).sendToTarget();
88 mWorker = new Worker(mWorkerThread.getLooper());
99 mWorker.obtainMessage(Worker.MSG_GET_PROVIDER, tile).sendToTarget();
167 mWorker.removeMessages(Worker.MSG_SET_LISTENING);
168 mWorker.obtainMessage(Worker.MSG_SET_LISTENING, listening ? 1 : 0, 0).sendToTarget();
291 private class Worker extends Handler {
295 public Worker(Looper looper) {
  /cts/tests/openglperf2/src/android/opengl2/cts/reference/
GLGameActivity.java 76 // Spawns a worker.
77 Worker worker = new Worker(new Handler() { local
88 worker.start();
101 private class Worker extends Thread implements WatchDog.TimeoutCallback {
106 public Worker(Handler handler) {
  /external/libchrome/base/threading/
sequenced_worker_pool.cc 226 // Worker ---------------------------------------------------------------------
228 class SequencedWorkerPool::Worker : public SimpleThread {
232 Worker(scoped_refptr<SequencedWorkerPool> worker_pool,
235 ~Worker() override;
240 // Gets the worker for the current thread out of thread-local storage.
241 static Worker* GetForCurrentThread();
255 // Whether the worker is processing a task.
273 static LazyInstance<ThreadLocalPointer<SequencedWorkerPool::Worker>>::Leaky
283 // Whether the Worker is processing a task.
286 DISALLOW_COPY_AND_ASSIGN(Worker);
1212 Worker* worker = Worker::GetForCurrentThread(); local
1222 Worker* worker = Worker::GetForCurrentThread(); local
1232 Worker* worker = Worker::GetForCurrentThread(); local
    [all...]
  /packages/apps/Gallery2/gallerycommon/src/com/android/gallery3d/util/
ThreadPool.java 98 Worker<T> w = new Worker<T>(job, listener);
107 private class Worker<T> implements Runnable, Future<T>, JobContext {
109 private static final String TAG = "Worker";
119 public Worker(Job<T> job, FutureListener<T> listener) {
  /packages/apps/Dialer/java/com/android/dialer/callcomposer/
CopyAndResizeImageWorker.java 31 import com.android.dialer.common.concurrent.DialerExecutor.Worker;
40 class CopyAndResizeImageWorker implements Worker<Uri, Pair<File, String>> {
  /libcore/ojluni/src/main/java/java/util/concurrent/
ThreadPoolExecutor.java 90 * created to handle the request, even if other worker threads are
124 * worker threads or other threads using the pool do not possess this
265 * internal worker threads may in turn fail, abruptly terminate, and
453 * The queue used for holding tasks and handing off to worker
481 * Set containing all worker threads in pool. Accessed only when
484 private final HashSet<Worker> workers = new HashSet<>();
499 * worker threads. Accessed only under mainLock.
571 * have permission to actually interrupt threads in the worker set
592 * Class Worker mainly maintains interrupt control state for
597 * intended to wake up a worker thread waiting for a task fro
    [all...]
  /cts/tests/openglperf2/src/android/opengl2/cts/primitive/
GLPrimitiveActivity.java 80 // Spawns a worker to run the benchmark.
81 Worker worker = new Worker(); local
82 worker.start();
115 private class Worker extends Thread implements WatchDog.TimeoutCallback {
  /packages/apps/Dialer/java/com/android/dialer/common/concurrent/
DialerUiTaskFragment.java 30 import com.android.dialer.common.concurrent.DialerExecutor.Worker;
42 private Worker<InputT, OutputT> worker; field in class:DialerUiTaskFragment
55 * @param worker a function executed on a worker thread which accepts an {@link InputT} and
76 Worker<InputT, OutputT> worker,
92 fragment.worker = worker;
137 return new InternalTaskResult<>(null, worker.doInBackground(params[0]))
    [all...]
DialerExecutor.java 33 interface Worker<InputT, OutputT> {
65 * Optional. If this is not set and your worker throws an exception, the application will crash.
  /external/llvm/lib/Support/
ThreadPool.cpp 109 for (auto &Worker : Threads)
110 Worker.join();
  /frameworks/base/tests/CoreTests/android/core/
TestWebServer.java 41 /* Where worker threads stand idle */
44 /* List of all active worker threads */
50 /* max # worker threads */
216 * The AcceptThread is responsible for initiating worker threads
263 Worker w = null;
266 Worker ws = new Worker();
269 (new Thread(ws, "additional worker")).start();
271 w = (Worker) threads.elementAt(0);
298 // Stop worker threads from continuin
    [all...]
  /packages/apps/Dialer/java/com/android/dialer/blocking/
BlockedNumbersAutoMigrator.java 28 import com.android.dialer.common.concurrent.DialerExecutor.Worker;
94 private static class ShouldAttemptAutoMigrate implements Worker<Void, Boolean> {
  /packages/apps/Dialer/java/com/android/dialer/simulator/impl/
SimulatorActionProvider.java 31 import com.android.dialer.common.concurrent.DialerExecutor.Worker;
39 private static class ShareLogWorker implements Worker<Void, String> {
  /external/toolchain-utils/bestflags/
pipeline_worker.py 8 This module defines the helper and the worker. If there are duplicate tasks, for
13 The worker invokes the work method of the tasks that are not duplicate.
26 tasks from the worker queue and let the results of the duplicate tasks be the
109 # Pull completed task from the worker queue.
121 def Worker(stage, task, helper_queue, result_queue):
122 """Worker that performs the task.
132 the communication channel between the worker and the helper.
134 the communication channel between the worker and the next stage.
pipeline_worker_test.py 8 This module tests the helper method and the worker method.
90 """"Test the worker method.
92 The worker should process all the input tasks and output the tasks to the
108 # Submit the mock tasks to the worker.
110 pipeline_worker.Worker(TEST_STAGE, mock_task, completed_queue,
  /external/vulkan-validation-layers/demos/smoke/
Smoke.cpp 83 Worker *worker = new Worker(*this, i, object_begin, object_end); local
84 workers_.emplace_back(std::unique_ptr<Worker>(worker));
141 for (auto &worker : workers_)
142 worker->start();
149 for (auto &worker : workers_)
150 worker->stop();
694 void Smoke::update_simulation(const Worker &worker
    [all...]
  /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...]
  /external/v8/src/
d8.h 210 class Worker {
212 Worker();
213 ~Worker();
215 // Run the given script on this Worker. This function should only be called
216 // once, and should only be called by the thread that created the Worker.
218 // Post a message to the worker's incoming message queue. The worker will
220 // This function should only be called by the thread that created the Worker.
222 // Synchronously retrieve messages from the worker's outgoing message queue.
224 // If there are no messages in the queue and the worker is no longer running
    [all...]

Completed in 242 milliseconds

12 3 4 5