HomeSort by relevance Sort by last modified time
    Searched refs:Worker (Results 51 - 75 of 99) sorted by null

1 23 4

  /external/vulkan-validation-layers/demos/smoke/
Smoke.cpp 88 Worker *worker = new Worker(*this, i, object_begin, object_end); local
89 workers_.emplace_back(std::unique_ptr<Worker>(worker));
146 for (auto &worker : workers_)
147 worker->start();
154 for (auto &worker : workers_)
155 worker->stop();
699 void Smoke::update_simulation(const Worker &worker
    [all...]
  /external/chromium-trace/catapult/third_party/gsutil/third_party/boto/boto/beanstalk/
layer1.py 314 "WebServer" and "Worker". Defaults to "WebServer".
320 * "Worker" and "SQS/HTTP"
325 if ``tier_name`` is "Worker". Defaults to "Standard".
    [all...]
  /external/gemmlowp/internal/
multi_thread_gemm.h 88 // (e.g. worker threads having finished a GEMM and waiting until the next GEMM)
121 // This is how the master thread waits for all the worker threads
177 // A workload for a worker.
185 // A worker thread.
186 class Worker {
195 explicit Worker(BlockingCounter* counter_to_decrement_when_ready)
204 ~Worker() {
209 // Changes State; may be called from either the worker thread
213 ScopedProfilingLabel label("Worker::ChangeState");
241 ScopedProfilingLabel label("Worker::ThreadFunc")
    [all...]
  /external/v8/src/
d8.h 220 class Worker {
222 Worker();
223 ~Worker();
225 // Run the given script on this Worker. This function should only be called
226 // once, and should only be called by the thread that created the Worker.
228 // Post a message to the worker's incoming message queue. The worker will
230 // This function should only be called by the thread that created the Worker.
232 // Synchronously retrieve messages from the worker's outgoing message queue.
234 // If there are no messages in the queue and the worker is no longer running
    [all...]
d8.cc 189 Worker* GetWorkerFromInternalField(Isolate* isolate, Local<Object> object) {
191 Throw(isolate, "this is not a Worker");
195 Worker* worker = local
196 static_cast<Worker*>(object->GetAlignedPointerFromInternalField(0));
197 if (worker == NULL) {
198 Throw(isolate, "Worker is defunct because main thread is terminating");
202 return worker;
260 i::List<Worker*> Shell::workers_;
768 Throw(args.GetIsolate(), "Worker must be constructed with new")
810 Worker* worker = GetWorkerFromInternalField(isolate, args.Holder()); local
853 Worker* worker = GetWorkerFromInternalField(isolate, args.Holder()); local
873 Worker* worker = GetWorkerFromInternalField(isolate, args.Holder()); local
    [all...]
  /external/caliper/caliper/src/main/java/com/google/caliper/runner/
ArbitraryMeasurementInstrument.java 30 import com.google.caliper.worker.ArbitraryMeasurementWorker;
31 import com.google.caliper.worker.Worker;
104 public Class<? extends Worker> workerClass() {
AllocationInstrument.java 29 import com.google.caliper.worker.MacrobenchmarkAllocationWorker;
30 import com.google.caliper.worker.MicrobenchmarkAllocationWorker;
31 import com.google.caliper.worker.Worker;
116 public Class<? extends Worker> workerClass() {
157 public Class<? extends Worker> workerClass() {
197 * This instrument's worker requires the allocationinstrumenter agent jar, specified
198 * on the worker VM's command line with "-javaagent:[jarfile]".
RuntimeInstrument.java 44 import com.google.caliper.worker.MacrobenchmarkWorker;
45 import com.google.caliper.worker.RuntimeWorker;
46 import com.google.caliper.worker.Worker;
152 public Class<? extends Worker> workerClass() {
217 @Override public Class<? extends Worker> workerClass() {
237 @Override public Class<? extends Worker> workerClass() {
Instrument.java 28 import com.google.caliper.worker.Worker;
120 public abstract Class<? extends Worker> workerClass();
124 * worker. Returns all instrument options by default.
154 * this instrument's worker.
  /external/caliper/caliper/src/test/java/com/google/caliper/runner/
ExperimentingRunnerModuleTest.java 29 import com.google.caliper.worker.Worker;
131 public Class<? extends Worker> workerClass() {
  /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
116 p = Process(target=Worker, args=(fn,
140 # A keyboard interrupt happened in one of the worker processes
    [all...]
  /external/caliper/caliper/src/main/java/com/google/caliper/worker/
ArbitraryMeasurementWorker.java 17 package com.google.caliper.worker;
33 * Worker for arbitrary measurements.
35 public final class ArbitraryMeasurementWorker extends Worker {
WorkerMain.java 17 package com.google.caliper.worker;
31 * the benchmark and hands it off to the instrument's worker.
50 Worker worker = workerComponent.getWorker(); local
55 worker.setUpBenchmark();
57 worker.bootstrap();
62 worker.preMeasure(isInWarmup);
65 ShouldContinueMessage message = log.notifyMeasurementEnding(worker.measure());
69 worker.postMeasure();
76 worker.tearDownBenchmark()
    [all...]
MacrobenchmarkWorker.java 17 package com.google.caliper.worker;
39 * The {@link Worker} implementation for macrobenchmarks.
41 public class MacrobenchmarkWorker extends Worker {
MicrobenchmarkAllocationWorker.java 17 package com.google.caliper.worker;
31 * The {@link Worker} for the {@code AllocationInstrument}. This class invokes the benchmark method
35 public final class MicrobenchmarkAllocationWorker extends Worker {
RuntimeWorker.java 17 package com.google.caliper.worker;
39 * A {@link Worker} base class for micro and pico benchmarks.
41 public abstract class RuntimeWorker extends Worker {
101 * A {@link Worker} for micro benchmarks.
127 * A {@link Worker} for pico benchmarks.
  /external/clang/test/FixIt/
fixit.cpp 238 class Worker {
244 wrapped_ptr<Worker> worker(new Worker);
245 worker.DoSomething(); // expected-error {{no member named 'DoSomething' in 'arrow_suggest::wrapped_ptr<arrow_suggest::Worker>'; did you mean to use '->' instead of '.'?}}
  /libcore/harmony-tests/src/test/java/org/apache/harmony/tests/java/io/
PipedInputStreamTest.java 331 static class Worker extends Thread {
334 Worker(PipedOutputStream pos) {
352 Thread worker = new Worker(out); local
353 worker.start();
356 worker.join();
  /external/drm_hwcomposer/
drmeventlistener.cpp 31 : Worker("drm-event-listener", HAL_PRIORITY_URGENT_DISPLAY),
drmdisplaycompositor.h 111 class FrameWorker : public Worker {
virtualcompositorworker.cpp 17 #define LOG_TAG "hwc-virtual-compositor-worker"
20 #include "worker.h"
38 : Worker("virtual-compositor", HAL_PRIORITY_URGENT_DISPLAY),
99 ALOGE("Failed to lock worker, %d", ret);
116 ALOGE("Failed to unlock worker, %d", ret);
vsyncworker.cpp 17 #define LOG_TAG "hwc-vsync-worker"
21 #include "worker.h"
35 : Worker("vsync", HAL_PRIORITY_URGENT_DISPLAY),
55 ALOGE("Failed to lock vsync worker lock %d\n", ret);
63 ALOGE("Failed to unlock vsync worker lock %d\n", ret);
72 ALOGE("Failed to lock vsync worker lock %d\n", ret);
82 ALOGE("Failed to unlock vsync worker lock %d\n", ret);
121 ALOGW("Vsync worker active with conn=%p refresh=%f\n", conn,
141 ALOGE("Failed to lock worker %d", ret);
158 ALOGE("Failed to unlock worker %d", ret)
    [all...]
  /external/libchrome/base/threading/
sequenced_worker_pool.h 33 // A worker thread pool that enforces ordering between sets of tasks. It also
70 // not enforce shutdown semantics or allow us to specify how many worker
81 // Defines what should happen to a task posted to the worker pool on
86 // shutdown will be ignored (the worker thread will not be joined).
125 // Opaque identifier that defines sequencing of tasks posted to the worker
163 // If current thread is not a SequencedWorkerPool worker thread or is running
181 // current thread is not a SequencedWorkerPool worker thread.
227 // Posts the given task for execution in the worker pool. Tasks posted with
234 // all worker threads are busy running CONTINUE_ON_SHUTDOWN tasks, there
341 // Implements the worker pool shutdown. This should be called during ap
    [all...]
  /libcore/support/src/test/java/tests/support/
Support_TestWebServer.java 214 * The AcceptThread is responsible for initiating worker threads
245 new Thread(new Worker(s), "additional worker").start();
302 * The worker thread handles all interactions with a current open
307 class Worker implements Support_HttpConstants, Runnable {
336 /* Create a new worker thread */
337 Worker(Socket s) {
  /external/valgrind/drd/tests/
tsan_thread_wrappers_pthread.h 346 MyThread(worker_t worker, void *arg = NULL, const char *name = NULL)
347 :w_(worker), arg_(arg), name_(name) {}
348 MyThread(void (*worker)(void), void *arg = NULL, const char *name = NULL)
349 :w_(reinterpret_cast<worker_t>(worker)), arg_(arg), name_(name) {}
350 MyThread(void (*worker)(void *), void *arg = NULL, const char *name = NULL)
351 :w_(reinterpret_cast<worker_t>(worker)), arg_(arg), name_(name) {}
507 MyThread *thread = new MyThread(&ThreadPool::Worker, this);
540 static void *Worker(void *p) {

Completed in 318 milliseconds

1 23 4