Searched defs:worker (Results 26 - 50 of 106) sorted by relevance

12345

/external/jacoco/org.jacoco.agent.rt/src/org/jacoco/agent/rt/internal/output/
H A DTcpServerOutput.java39 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/caliper/caliper/src/main/java/com/google/caliper/runner/
H A DTrialModule.java104 WorkerProcess worker,
107 return new StreamService(worker, logMessageParser, trialOutput);
103 provideStreamService( WorkerProcess worker, Parser<LogMessage> logMessageParser, TrialOutputLogger trialOutput) argument
H A DStreamService.java73 * the worker process to be forcibly shutdown and {@link #readItem(long, TimeUnit)},
91 private final WorkerProcess worker; field in class:StreamService
112 @Inject StreamService(WorkerProcess worker, argument
115 this.worker = worker;
123 process = worker.startWorker();
154 // will cause the worker to be killed (if its not dead already) and the various StreamReaders to
157 // use the default charset because worker streams will use the default for output
162 threadRenaming("worker-stderr",
166 threadRenaming("worker
[all...]
/external/caliper/caliper/src/main/java/com/google/caliper/worker/
H A DAllocationStats.java16 package com.google.caliper.worker;
H A DWorkerModule.java17 package com.google.caliper.worker;
37 * Binds classes necessary for the worker. Also manages the injection of {@link Param parameters}
40 * <p>TODO(gak): Ensure that each worker only has bindings for the objects it needs and not the
41 * objects required by different workers. (i.e. don't bind a Ticker if the worker is an allocation
42 * worker).
68 throw new InvalidCommandException("%s is not a supported worker (%s).",
H A DRuntimeWorker.java17 package com.google.caliper.worker;
/external/libunwind/tests/
H A DGtest-concurrent.c73 worker (void *arg UNUSED) function
94 if (pthread_create (th + i, &attr, worker, NULL))
/external/libvpx/libvpx/vp9/decoder/
H A Dvp9_dthread.c20 void vp9_frameworker_lock_stats(VPxWorker *const worker) { argument
22 FrameWorkerData *const worker_data = worker->data1;
25 (void)worker;
29 void vp9_frameworker_unlock_stats(VPxWorker *const worker) { argument
31 FrameWorkerData *const worker_data = worker->data1;
34 (void)worker;
38 void vp9_frameworker_signal_stats(VPxWorker *const worker) { argument
40 FrameWorkerData *const worker_data = worker->data1;
50 (void)worker;
61 // TODO(hkuang): Remove worker paramete
62 vp9_frameworker_wait(VPxWorker *const worker, RefCntBuffer *const ref_buf, int row) argument
116 VPxWorker *worker = buf->frame_worker_owner; local
[all...]
H A Dvp9_decoder.c131 VPxWorker *const worker = &pbi->tile_workers[i]; local
132 vpx_get_worker_interface()->end(worker);
313 VPxWorker *const worker = pbi->frame_worker_owner; local
314 vp9_frameworker_lock_stats(worker);
315 frame_bufs[cm->new_fb_idx].frame_worker_owner = worker;
320 vp9_frameworker_unlock_stats(worker);
340 // Release all the reference buffers if worker thread is holding them.
388 VPxWorker *const worker = pbi->frame_worker_owner; local
389 FrameWorkerData *const frame_worker_data = worker->data1;
390 vp9_frameworker_lock_stats(worker);
[all...]
/external/libvpx/libvpx/vpx_util/
H A Dvpx_thread.c10 // Multi-threaded worker
30 static void execute(VPxWorker *const worker); // Forward declaration.
33 VPxWorker *const worker = (VPxWorker *)ptr; local
36 pthread_mutex_lock(&worker->impl_->mutex_);
37 while (worker->status_ == OK) { // wait in idling mode
38 pthread_cond_wait(&worker->impl_->condition_, &worker->impl_->mutex_);
40 if (worker->status_ == WORK) {
41 execute(worker);
42 worker
54 change_state(VPxWorker *const worker, VPxWorkerStatus new_status) argument
79 init(VPxWorker *const worker) argument
84 sync(VPxWorker *const worker) argument
92 reset(VPxWorker *const worker) argument
130 execute(VPxWorker *const worker) argument
136 launch(VPxWorker *const worker) argument
144 end(VPxWorker *const worker) argument
[all...]
/external/robolectric/v1/src/main/java/com/xtremelabs/robolectric/shadows/
H A DShadowAsyncTask.java23 private final BackgroundWorker worker; field in class:ShadowAsyncTask
27 worker = new BackgroundWorker();
28 future = new FutureTask<Result>(worker) {
80 worker.params = params;
/external/swiftshader/third_party/subzero/pydir/
H A Dwasm-run-torture-tests.py198 def worker(): function
204 t = threading.Thread(target=worker)
/external/libchrome/base/threading/
H A Dworker_pool_posix.cc155 // We have enough worker threads.
161 WorkerThread* worker = new WorkerThread(name_prefix_, this); local
162 PlatformThread::CreateNonJoinable(0, worker);
/external/libvpx/libvpx/test/
H A Dvp9_thread_test.cc34 void Run(VPxWorker *worker) { argument
37 vpx_get_worker_interface()->execute(worker);
39 vpx_get_worker_interface()->launch(worker);
196 // Trivial serialized thread worker interface implementation.
197 // Note any worker that requires synchronization between other workers will
201 void Init(VPxWorker *const worker) { memset(worker, 0, sizeof(*worker)); } argument
202 int Reset(VPxWorker *const /*worker*/) { return 1; }
203 int Sync(VPxWorker *const worker) { retur argument
205 Execute(VPxWorker *const worker) argument
209 Launch(VPxWorker *const worker) argument
[all...]
/external/ltp/testcases/open_posix_testsuite/conformance/interfaces/pthread_cond_broadcast/
H A D4-2.c23 * -> Create a worker thread which broadcasts this condition.
24 * -> Another thread loops on killing the worker thread.
156 static void *worker(void *arg) function
164 "in worker thread");
225 ret = pthread_create(&th_worker, NULL, worker, NULL);
/external/ltp/testcases/open_posix_testsuite/conformance/interfaces/pthread_cond_signal/
H A D4-2.c196 void *worker(void *arg) function
204 "Unable to unblock SIGUSR1 and SIGUSR2 in worker thread");
270 if ((ret = pthread_create(&th_worker, NULL, worker, NULL))) {
/external/ltp/testcases/open_posix_testsuite/conformance/interfaces/pthread_cond_timedwait/
H A D4-3.c147 "Unable to unblock SIGUSR1 and SIGUSR2 in worker thread");
193 void *worker(void *arg) function
282 if ((ret = pthread_create(&th_worker, NULL, worker, NULL))) {
/external/ltp/testcases/open_posix_testsuite/conformance/interfaces/pthread_cond_wait/
H A D4-1.c170 "Unable to unblock SIGUSR1 and SIGUSR2 in worker thread");
203 void *worker(void *arg) function
293 if ((ret = pthread_create(&th_worker, NULL, worker, NULL))) {
/external/ltp/testcases/realtime/func/sched_jitter/
H A Dsched_jitter.c166 int worker, interrupter; local
174 worker = create_fifo_thread(thread_worker, NULL, 10);
176 join_thread(worker);
/external/python/cpython2/Lib/test/
H A Dtest_queue.py143 def worker(self, q): member in class:BaseQueueTest
156 threading.Thread(target=self.worker, args=(q,)).start()
/external/testng/src/main/java/org/testng/internal/thread/graph/
H A DGraphThreadPoolExecutor.java59 * Create one worker per node and execute them.
79 private void setStatus(IWorker<T> worker, Status status) { argument
80 ppp("Set status:" + worker + " status:" + status);
82 m_activeRunnables.remove(worker);
85 for (T m : worker.getTasks()) {
/external/webrtc/webrtc/base/
H A Dmessagequeue_unittest.cc32 // We have to do this on a worker thread, or else the TryEnter will
34 Thread worker; local
35 worker.Start();
36 return worker.Invoke<bool>(
H A Dsignalthread.h23 // 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() { retur function in class:rtc::SignalThread
[all...]
/external/libvpx/libvpx/vp9/common/
H A Dvp9_thread_common.c183 VPxWorker *const worker = &workers[i]; local
186 worker->hook = (VPxWorkerHook)loop_filter_row_worker;
187 worker->data1 = lf_sync;
188 worker->data2 = lf_data;
198 winterface->execute(worker);
200 winterface->launch(worker);
/external/ltp/testcases/kernel/io/direct_io/
H A Ddma_thread_diotest.c155 static worker_t *worker; variable
161 worker_t *worker = (worker_t *)arg; local
162 int offset = worker->offset;
163 int fd = worker->fd;
164 unsigned char *buffer = worker->buffer;
165 int pattern = worker->pattern;
166 int length = worker->length;
176 fprintf(stderr, "read failed in worker thread%d: %s",
177 worker->worker_number, strerror(errno));
261 worker[
[all...]

Completed in 649 milliseconds

12345