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

1 2

  /external/chromium_org/ui/file_manager/image_loader/
worker.js 8 * Worker for requests. Fetches requests from a queue and processes them
11 function Worker() {
14 * cache, then they are processed immediately after starting the worker.
45 * If the worker has been started.
57 Worker.MAXIMUM_IN_PARALLEL = 5;
62 * processed immediately once the worker is started.
66 Worker.prototype.add = function(request) {
81 * Removes a request from the worker (if exists).
84 Worker.prototype.remove = function(requestId) {
105 Worker.prototype.start = function()
    [all...]
  /external/chromium_org/third_party/webrtc/base/
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 virtual ~Worker();
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...]
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) {
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 before Start to change the worker's priority.
51 // Context: Main Thread. Call to begin the worker thread.
54 // Context: Main Thread. If the worker thread is not running, deletes the
55 // object immediately. Otherwise, asks the worker thread to abort processing,
56 // and schedules the object to be deleted once the worker exits.
61 // Context: Main Thread. If the worker thread is complete, deletes the
63 // the worker thread completes. SignalWorkDone will be signalled
74 Thread* worker() { return &worker_; } function in class:rtc::SignalThread
    [all...]
  /art/compiler/dex/
bb_optimizations.cc 26 bool CodeLayout::Worker(const PassDataHolder* data) const {
41 bool BBCombine::Worker(const PassDataHolder* data) const {
pass.h 65 * @brief Start of the pass: called before the Worker function.
84 virtual bool Worker(const PassDataHolder* data) const {
post_opt_passes.cc 39 bool MethodUseCount::Worker(const PassDataHolder* data) const {
52 bool ClearPhiInstructions::Worker(const PassDataHolder* data) const {
bb_optimizations.h 98 bool Worker(const PassDataHolder* data) const {
135 bool Worker(const PassDataHolder* data) const;
155 bool Worker(const PassDataHolder* data) const {
186 bool Worker(const PassDataHolder* data) const {
221 bool Worker(const PassDataHolder* data) const OVERRIDE {
255 bool Worker(const PassDataHolder* data) const;
post_opt_passes.h 55 bool Worker(const PassDataHolder* data) const;
69 bool Worker(const PassDataHolder* data) const;
225 bool Worker(const PassDataHolder* data) const {
263 bool Worker(const PassDataHolder* data) const {
  /external/chromium_org/net/disk_cache/blockfile/
backend_worker_v3.h 23 class BackendImplV3::Worker : public base::RefCountedThreadSafe<Worker> {
25 Worker(const base::FilePath& path,
32 friend class base::RefCountedThreadSafe<Worker>;
34 ~Worker();
51 DISALLOW_COPY_AND_ASSIGN(Worker);
backend_worker_v3.cc 96 BackendImplV3::Worker::Worker(
460 int BackendImplV3::Worker::Init(const CompletionCallback& callback) {
464 BackendImplV3::Worker::~Worker() {
  /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/chromium_org/third_party/WebKit/Source/core/workers/
Worker.cpp 29 #include "core/workers/Worker.h"
46 inline Worker::Worker(ExecutionContext* context)
52 PassRefPtrWillBeRawPtr<Worker> Worker::create(ExecutionContext* context, const String& url, ExceptionState& exceptionState)
64 RefPtrWillBeRawPtr<Worker> worker = adoptRefWillBeNoop(new Worker(context)); local
66 worker->suspendIfNeeded();
68 KURL scriptURL = worker->resolveURL(url, exceptionState)
    [all...]
  /external/chromium_org/media/audio/
fake_audio_consumer.cc 22 class FakeAudioConsumer::Worker
23 : public base::RefCountedThreadSafe<FakeAudioConsumer::Worker> {
25 Worker(const scoped_refptr<base::SingleThreadTaskRunner>& worker_task_runner,
33 friend class base::RefCountedThreadSafe<Worker>;
34 ~Worker();
36 // Initialize and start regular calls to DoRead() on the worker thread.
39 // Cancel any delayed callbacks to DoRead() in the worker loop's queue.
44 // the worker loop.
55 // Used to cancel any delayed tasks still inside the worker loop's queue.
60 DISALLOW_COPY_AND_ASSIGN(Worker);
    [all...]
  /external/chromium_org/v8/tools/testrunner/local/
pool.py 27 def Worker(fn, work_queue, done_queue, done):
28 """Worker to be run in a child process.
29 The worker stops on two conditions. 1. When the poison pill "STOP" is
45 """Distributes tasks to a number of worker processes.
60 # worker takes an item from the work_queue and before the result is
61 # submitted to the done_queue. It is equal when no worker is working,
72 """Maps function "fn" to items in generator "gen" on the worker processes
80 p = Process(target=Worker, args=(fn,
95 # A keyboard interrupt happened in one of the worker processes.
132 # per worker to make them stop
    [all...]
  /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>'}}
63 worker.Chuck(); // expected-error {{no member named 'Chuck' in 'arrow_suggest::wrapped_ptr<arrow_suggest::Worker>'; did you mean 'Check'?}
    [all...]
  /external/chromium_org/chrome/browser/media/
native_desktop_media_list.cc 85 class NativeDesktopMediaList::Worker
88 Worker(base::WeakPtr<NativeDesktopMediaList> media_list,
91 virtual ~Worker();
112 DISALLOW_COPY_AND_ASSIGN(Worker);
115 NativeDesktopMediaList::Worker::Worker(
128 NativeDesktopMediaList::Worker::~Worker() {}
130 void NativeDesktopMediaList::Worker::Refresh(
224 webrtc::SharedMemory* NativeDesktopMediaList::Worker::CreateSharedMemory
    [all...]
  /external/chromium_org/chrome/browser/media_galleries/
media_folder_finder.cc 171 // The Worker is created on the UI thread, but does all its work on a blocking
173 class MediaFolderFinder::Worker {
175 explicit Worker(const std::vector<base::FilePath>& graylisted_folders);
176 ~Worker();
192 DISALLOW_COPY_AND_ASSIGN(Worker);
195 MediaFolderFinder::Worker::Worker(
211 MediaFolderFinder::Worker::~Worker() {
215 MediaFolderFinder::WorkerReply MediaFolderFinder::Worker::ScanFolder
    [all...]
  /external/chromium_org/tools/findit/
crash_utils.py 32 # Give worker threads a chance to exit.
40 def Worker():
81 thread = threading.Thread(target=Worker, name='worker_%s' % index)
  /external/clang/test/Sema/
attr-capabilities.c 23 ThreadRole GUI, Worker;
25 void Func2(void) __attribute__((requires_shared_capability(Worker))) {}
57 void Func28(void) __attribute__((requires_capability(GUI && Worker)));
58 void Func29(void) __attribute__((requires_capability(GUI || Worker)));
59 void Func30(void) __attribute__((requires_capability((Worker || Worker) && !GUI)));
  /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");
  /cts/suite/cts/deviceTests/opengl/src/com/android/cts/opengl/primitive/
GLPrimitiveActivity.java 80 // Spawns a worker to run the benchmark.
81 Worker worker = new Worker(); local
82 worker.start();
122 private class Worker extends Thread implements WatchDog.TimeoutCallback {
  /cts/suite/cts/deviceTests/opengl/src/com/android/cts/opengl/reference/
GLGameActivity.java 76 // Spawns a worker.
77 Worker worker = new Worker(new Handler() { local
87 worker.start();
100 private class Worker extends Thread implements WatchDog.TimeoutCallback {
105 public Worker(Handler handler) {
  /external/chromium_org/third_party/WebKit/Tools/Scripts/webkitpy/layout_tests/controllers/
layout_test_runner.py 114 self._printer.write_update('Starting %s ...' % grammar.pluralize('worker', num_workers))
146 return Worker(worker_connection, results_directory, self._options)
211 class Worker(object):
387 This is used when there's only one worker, to minimize the per-shard overhead."""

Completed in 1745 milliseconds

1 2