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

1 2 3 4 5 6 7

  /external/caliper/caliper/src/main/java/com/google/caliper/worker/
WorkerOptions.java 15 package com.google.caliper.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...]
WorkerComponent.java 17 package com.google.caliper.worker;
26 * Creates {@link Worker} for an {@link com.google.caliper.runner.Experiment}.
36 Worker getWorker();
AggregateAllocationsRecorder.java 16 package com.google.caliper.worker;
AllAllocationsRecorder.java 16 package com.google.caliper.worker;
30 * <p>This recorder is enabled via the {@code trackAllocations} worker option.
55 // Don't track locations up into the worker code, or originating within the worker
AllocationRecorder.java 16 package com.google.caliper.worker;
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 {
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) {
ArbitraryMeasurementWorker.java 17 package com.google.caliper.worker;
33 * Worker for arbitrary measurements.
35 public final class ArbitraryMeasurementWorker extends Worker {
MacrobenchmarkWorker.java 17 package com.google.caliper.worker;
39 * The {@link Worker} implementation for macrobenchmarks.
41 public class MacrobenchmarkWorker extends Worker {
  /external/compiler-rt/test/tsan/
fork_atexit.cc 14 void *worker(void *unused) { function
20 pthread_create(&t, NULL, worker, NULL);
pthread_atfork_deadlock.c 11 void *worker(void *unused) { function
26 pthread_create(&t, NULL, worker, NULL);
  /development/ndk/platforms/android-21/samples/native-codec/jni/
looper.h 37 pthread_t worker; member in class:looper
  /external/jacoco/org.jacoco.agent.rt/src/org/jacoco/agent/rt/internal/output/
TcpClientOutput.java 35 private Thread worker; field in class:TcpClientOutput
52 worker = new Thread(new Runnable() {
61 worker.setName(getClass().getName());
62 worker.setDaemon(true);
63 worker.start();
68 worker.join();
TcpServerOutput.java 39 private Thread worker; field in class:TcpServerOutput
54 worker = new Thread(new Runnable() {
74 worker.setName(getClass().getName());
75 worker.setDaemon(true);
76 worker.start();
86 worker.join();
  /external/autotest/client/virt/
virt_scheduler.py 26 # Pipes -- s stands for scheduler, w stands for worker
33 # "Personal" worker dicts contain modifications that are applied
34 # specifically to each worker. For example, each worker must use a
39 def worker(self, index, run_test_func): member in class:scheduler
41 The worker function.
45 @param index: The index of this worker (in the range 0..num_workers-1).
53 # Inform the scheduler this worker is ready
61 # The scheduler wants this worker to run a test
73 # The scheduler wants this worker to free its used resource
    [all...]
  /sdk/hierarchyviewer/src/com/android/hierarchyviewer/ui/action/
BackgroundAction.java 23 protected void executeBackgroundTask(SwingWorker<?, ?> worker) {
24 if (worker != null) {
25 worker.execute();
  /external/caliper/caliper/src/test/java/com/google/caliper/runner/
WorkerProcessTest.java 28 import com.google.caliper.worker.WorkerMain;
106 // followed by worker args...
110 Process worker = createWorkerProcess(FakeWorkers.Exit.class, "0").startWorker(); local
111 assertEquals("worker-shutdown-hook-" + TRIAL_ID,
113 worker.waitFor();
118 Process worker = createWorkerProcess( local
122 assertEquals("worker-shutdown-hook-" + TRIAL_ID, hook.getName());
124 worker.exitValue();
129 worker.destroy(); // clean up
134 Process worker = createWorkerProcess(FakeWorkers.Exit.class, "0").startWorker() local
147 Process worker = createWorkerProcess( local
    [all...]
  /external/caliper/caliper/src/test/java/com/google/caliper/worker/
RuntimeWorkerTest.java 15 package com.google.caliper.worker;
17 import static com.google.caliper.worker.RuntimeWorker.INITIAL_REPS;
18 import static com.google.caliper.worker.RuntimeWorker.calculateTargetReps;
  /external/testng/src/main/java/org/testng/internal/thread/graph/
SuiteWorkerFactory.java 39 SuiteRunnerWorker worker = new SuiteRunnerWorker(suiteRunner, m_suiteRunnerMap, local
41 suiteWorkers.add(worker);
  /hardware/intel/common/omx-components/videocodec/libvpx_internal/libvpx/vp9/decoder/
vp9_thread.c 10 // Multi-threaded worker
30 VP9Worker* const worker = (VP9Worker*)ptr; local
33 pthread_mutex_lock(&worker->mutex_);
34 while (worker->status_ == OK) { // wait in idling mode
35 pthread_cond_wait(&worker->condition_, &worker->mutex_);
37 if (worker->status_ == WORK) {
38 vp9_worker_execute(worker);
39 worker->status_ = OK;
40 } else if (worker->status_ == NOT_OK) { // finish the worke
    [all...]
  /external/apache-xml/src/main/java/org/apache/xml/utils/
ThreadControllerWrapper.java 38 public static void waitThread(Thread worker, Runnable task)
41 m_tpool.waitThread(worker, task);
79 * Wait until the task is completed on the worker
82 * NEEDSDOC @param worker
87 public void waitThread(Thread worker, Runnable task)
92 worker.join();
  /external/autotest/scheduler/
thread_lib.py 13 1. worker: The staticmethod executed by all worker threads.
14 2. execute: Takes a list of drones and invokes a worker thread per drone.
17 3. wait_on_drones: Waits for all worker threads started by execute to finish
91 def worker(drone, results_queue): member in class:ThreadedTaskQueue
92 """Worker for task execution.
98 @param results_queue: A queue, into which the worker places
101 logging.info('(Worker.%s) starting.', drone.hostname)
104 logging.info('(Worker.%s) finished.', drone.hostname)
190 target=ThreadedTaskQueue.worker,
    [all...]
  /external/libunwind/tests/
Gtest-concurrent.c 73 worker (void *arg UNUSED) function
94 if (pthread_create (th + i, &attr, worker, NULL))
  /external/libvpx/libvpx/vp9/decoder/
vp9_dthread.c 20 void vp9_frameworker_lock_stats(VPxWorker *const worker) {
22 FrameWorkerData *const worker_data = worker->data1;
25 (void)worker;
29 void vp9_frameworker_unlock_stats(VPxWorker *const worker) {
31 FrameWorkerData *const worker_data = worker->data1;
34 (void)worker;
38 void vp9_frameworker_signal_stats(VPxWorker *const worker) {
40 FrameWorkerData *const worker_data = worker->data1;
50 (void)worker;
61 // TODO(hkuang): Remove worker parameter as it is only used in debug code
117 VPxWorker *worker = buf->frame_worker_owner; local
    [all...]

Completed in 379 milliseconds

1 2 3 4 5 6 7