Searched refs:task (Results 1 - 25 of 108) sorted by relevance

12345

/packages/apps/Camera2/src/com/android/camera/processing/imagebackend/
H A DImageProcessorListener.java34 * Called when a task starts running.
36 * @param task Task specification that includes unique content id
38 public void onStart(TaskImageContainer.TaskInfo task); argument
43 * @param task Task specification that includes unique content id
46 public void onResultCompressed(TaskImageContainer.TaskInfo task, argument
52 * @param task Task specification that includes unique content id
55 public void onResultUncompressed(TaskImageContainer.TaskInfo task, argument
61 * @param task Task specification that includes unique content id
64 public void onResultUri(TaskImageContainer.TaskInfo task, Uri uri); argument
67 // public void onError(TaskImageContainer.JobInfo task);
[all...]
H A DImageTaskManager.java24 * its task dependencies and manage its image references.
31 * dependent task does NOT require the image reference, it should be passed
33 * called after the task has completed its own computations, but before it
43 * Spawns a single dependent task from internal implementation of a task.
45 * @param task The task to be run
48 public boolean appendTasks(ImageToProcess img, TaskImageContainer task); argument
51 * Signals the ImageTaskManager that a task has released a reference to the
57 * @param img the image to be released by the task
[all...]
/packages/apps/QuickSearchBox/src/com/android/quicksearchbox/util/
H A DNamedTaskExecutor.java25 * Schedules a task for execution. Implementations should not throw
26 * {@link java.util.concurrent.RejectedExecutionException} if the task
29 void execute(NamedTask task); argument
H A DSingleThreadNamedTaskExecutor.java56 public void execute(NamedTask task) { argument
60 mQueue.add(task);
76 NamedTask task;
78 task = mQueue.take();
82 currentThread.setName(threadName + " " + task.getName());
84 if (DBG) Log.d(TAG, "Running task " + task.getName());
85 task.run();
86 if (DBG) Log.d(TAG, "Task " + task.getName() + " complete");
88 Log.e(TAG, "Task " + task
[all...]
H A DBatchingNamedTaskExecutor.java48 public void execute(NamedTask task) { argument
50 if (DBG) Log.d(TAG, "Queuing " + task);
51 mQueuedTasks.add(task);
55 private void dispatch(NamedTask task) { argument
56 if (DBG) Log.d(TAG, "Dispatching " + task);
57 mExecutor.execute(task);
74 for (NamedTask task : batch) {
75 dispatch(task);
H A DPerNameExecutor.java23 * Uses a separate executor for each task name.
51 public synchronized void execute(NamedTask task) { argument
55 String name = task.getName();
61 executor.execute(task);
/packages/services/Telephony/tests/src/com/android/phone/vvm/omtp/scheduling/
H A DBaseTaskTest.java37 DummyBaseTask task = (DummyBaseTask) submitTask(
39 assertTrue(task.getId().equals(new TaskId(1, 123)));
40 assertTrue(!task.hasStarted());
41 assertTrue(!task.hasRun);
43 assertTrue(task.hasStarted());
44 assertTrue(task.hasRun);
45 verify(task.policy).onBeforeExecute();
46 verify(task.policy).onCompleted();
51 FailingBaseTask task = (FailingBaseTask) submitTask(
54 verify(task
[all...]
/packages/apps/Gallery2/src/com/android/gallery3d/filtershow/pipeline/
H A DProcessingTaskController.java42 ProcessingTask task = mTasks.get(msg.what);
43 if (task != null) {
45 task.onResult((ProcessingTask.Result) msg.obj);
47 task.onUpdate((ProcessingTask.Update) msg.obj);
57 ProcessingTask task = mTasks.get(msg.what);
58 if (task != null) {
59 task.processRequest((ProcessingTask.Request) msg.obj);
89 public void add(ProcessingTask task) { argument
90 task.added(this);
91 mTasks.put(task
[all...]
/packages/apps/QuickSearchBox/tests/src/com/android/quicksearchbox/util/
H A DSingleThreadNamedTaskExecutorTest.java50 MockTask task = new MockTask(name, id);
51 mExecutor.execute(task);
52 return task;
H A DMockTask.java22 * A task that knows how many times it has been run.
71 for (MockTask task : tasks) {
72 task.assertRanNever(message);
77 for (MockTask task : tasks) {
78 task.assertRanOnce(message);
H A DMockNamedTaskExecutor.java23 * A simple executor that maintains a queue and executes one task synchronously every
31 public void execute(NamedTask task) { argument
32 mExecutor.execute(task);
H A DMockExecutor.java23 * A simple executor that maintains a queue and executes one task synchronously every
33 public void execute(Runnable task) { argument
35 mQueue.addLast(task);
/packages/services/Telephony/src/com/android/phone/vvm/omtp/scheduling/
H A DTaskSchedulerService.java45 * A service to queue and run {@link Task} on a worker thread. Only one task will be ran at a time,
46 * and same task cannot exist in the queue at the same time. The service will be started when a
58 * Threshold to determine whether to do a short or long sleep when a task is scheduled in the
62 * Handler#postDelayed(Runnable, long)} to wait for the next task.
86 * Used by tests to turn task handling into a single threaded process by calling {@link
109 * Should attempt to run the next task when a task has finished or been added.
124 Task task = (Task) msg.obj;
126 VvmLog.v(TAG, "executing task " + task);
202 addTask(Task task) argument
240 createIntent(Context context, Class<? extends Task> task) argument
[all...]
H A DPolicy.java27 void onCreate(BaseTask task, Intent intent, int flags, int startId); argument
H A DRetryPolicy.java26 * A task with this policy will automatically re-queue itself if {@link BaseTask#fail()} has been
27 * called during {@link BaseTask#onExecuteInBackgroundThread()}. A task will be retried at most
55 * Error status should only be set if retries has exhausted or the task is successful. Status
56 * writes to this editor will be deferred until the task has ended, and will only be committed
57 * if the task is successful or there are no retries left.
64 public void onCreate(BaseTask task, Intent intent, int flags, int startId) { argument
65 mTask = task;
73 .fromSubId(task.getSubId());
75 VvmLog.e(TAG, "null phone account for subId " + task.getSubId());
80 .deferredEdit(task
[all...]
H A DBlockerTask.java25 * Task to block another task of the same ID from being queued for a certain amount of time.
51 public void onDuplicatedTaskAdded(Task task) { argument
53 .v(TAG, task.toString() + "blocked, " + getReadyInMilliSeconds() + "millis remaining");
H A DMinimalIntervalPolicy.java24 * If a task with this policy succeeds, a {@link BlockerTask} with the same {@link TaskId} of the
25 * task will be queued immediately, preventing the same task from running for a certain amount of
39 public void onCreate(BaseTask task, Intent intent, int flags, int startId) { argument
40 mTask = task;
H A DPostponePolicy.java24 * A task with Postpone policy will not be executed immediately. It will wait for a while and if a
25 * duplicated task is queued during the duration, the task will be postponed further. The task will
26 * only be executed if no new task was added in postponeMillis. Useful to batch small tasks in quick
41 public void onCreate(BaseTask task, Intent intent, int flags, int startId) { argument
42 mTask = task;
/packages/apps/Gallery2/gallerycommon/src/com/android/gallery3d/common/
H A DAsyncTaskUtil.java49 public static <Param> void executeInParallel(AsyncTask<Param, ?, ?> task, Param... params) { argument
51 task.execute(params);
54 sMethodExecuteOnExecutor.invoke(task, sExecutor, params);
/packages/apps/Dialer/tests/src/com/android/dialer/util/
H A DFakeAsyncTaskExecutor.java68 /** Encapsulates an async task with the params and identifier it was submitted with. */
125 AsyncTask<T, ?, ?> task, T... params) {
130 Assert.assertNotNull("Already had a valid task.\n"
132 + "onPreExecute() method of another task being submitted?\n"
133 + "Sorry! Not that's not supported.", task);
134 mNextTask = task;
136 return task.executeOnExecutor(this, params);
141 public <T> AsyncTask<T, ?, ?> submit(Object identifier, AsyncTask<T, ?, ?> task, T... params) { argument
143 return mBlockingExecutor.submit(identifier, task, params);
147 * Runs a single task matchin
124 submit(Object identifier, AsyncTask<T, ?, ?> task, T... params) argument
[all...]
/packages/apps/Email/emailcommon/src/com/android/emailcommon/utility/
H A DEmailAsyncTask.java54 private void add(EmailAsyncTask<?, ?, ?> task) { argument
56 mTasks.add(task);
60 private void remove(EmailAsyncTask<?, ?, ?> task) { argument
62 mTasks.remove(task);
72 for (EmailAsyncTask<?, ?, ?> task : mTasks) {
73 task.cancel(true);
88 for (EmailAsyncTask<?, ?, ?> task : mTasks) {
89 if ((task != current) && task.getClass().equals(clazz)) {
90 task
104 containsTaskForTest(EmailAsyncTask<?, ?, ?> task) argument
[all...]
/packages/apps/Camera2/src/com/android/camera/processing/
H A DProcessingTaskConsumer.java29 public void enqueueTask(ProcessingTask task); argument
/packages/apps/Dialer/src/com/android/dialer/util/
H A DAsyncTaskExecutor.java43 * The identifier supplied is any Object that can be used to identify the task later. Most
45 * accepted, though of course this won't help in identifying the task later.
47 <T> AsyncTask<T, ?, ?> submit(Object identifier, AsyncTask<T, ?, ?> task, T... params); argument
/packages/apps/ManagedProvisioning/src/com/android/managedprovisioning/task/
H A DDisableBluetoothSharingTask.java17 package com.android.managedprovisioning.task;
/packages/apps/Gallery2/src/com/android/gallery3d/ui/
H A DPreparePageFadeoutTexture.java68 PreparePageFadeoutTexture task = new PreparePageFadeoutTexture(rootPane);
69 if (task.isCancelled()) return;
74 root.addOnGLIdleListener(task);
75 texture = task.get();

Completed in 366 milliseconds

12345