Searched defs:task (Results 1 - 25 of 56) sorted by relevance

123

/frameworks/support/v4/honeycomb/android/support/v4/os/
H A DAsyncTaskCompatHoneycomb.java27 AsyncTask<Params, Progress, Result> task,
29 task.executeOnExecutor(AsyncTask.THREAD_POOL_EXECUTOR, params);
26 executeParallel( AsyncTask<Params, Progress, Result> task, Params... params) argument
/frameworks/support/v4/java/android/support/v4/os/
H A DAsyncTaskCompat.java29 * Executes the task with the specified parameters, allowing multiple tasks to run in parallel
32 * @param task The {@link android.os.AsyncTask} to execute.
33 * @param params The parameters of the task.
37 AsyncTask<Params, Progress, Result> task,
39 if (task == null) {
40 throw new IllegalArgumentException("task can not be null");
45 AsyncTaskCompatHoneycomb.executeParallel(task, params);
48 task.execute(params);
51 return task;
36 executeParallel( AsyncTask<Params, Progress, Result> task, Params... params) argument
/frameworks/base/libs/hwui/thread/
H A DTaskProcessor.h33 virtual void process(const sp<TaskBase>& task) = 0;
42 void add(const sp<Task<T> >& task) { argument
43 if (!addImpl(task)) {
45 process(task);
49 virtual void onProcess(const sp<Task<T> >& task) = 0;
52 bool addImpl(const sp<Task<T> >& task);
54 virtual void process(const sp<TaskBase>& task) override {
55 sp<Task<T> > realTask = static_cast<Task<T>* >(task.get());
57 // sp<Task<T> > realTask = static_cast<sp<Task<T> > >(task);
65 bool TaskProcessor<T>::addImpl(const sp<Task<T> >& task) { argument
[all...]
H A DTaskManager.h44 * Returns true if this task manager can run tasks,
61 bool addTask(const sp<Task<T> >& task, const sp<TaskProcessor<T> >& processor) { argument
62 return addTaskBase(sp<TaskBase>(task), sp<TaskProcessorBase>(processor));
65 bool addTaskBase(const sp<TaskBase>& task, const sp<TaskProcessorBase>& processor);
70 TaskWrapper(const sp<TaskBase>& task, const sp<TaskProcessorBase>& processor): argument
71 mTask(task), mProcessor(processor) {
82 bool addTask(TaskWrapper task);
95 // task is available in the list
H A DTaskManager.cpp62 bool TaskManager::addTaskBase(const sp<TaskBase>& task, const sp<TaskProcessorBase>& processor) { argument
64 TaskWrapper wrapper(task, processor);
100 const TaskWrapper& task = tasks.itemAt(i); local
101 task.mProcessor->process(task.mTask);
107 bool TaskManager::WorkerThread::addTask(TaskWrapper task) { argument
117 index = mTasks.add(task);
/frameworks/base/tools/aidl/
H A Doptions.h18 int task; member in struct:Options
/frameworks/base/packages/DocumentsUI/src/com/android/documentsui/
H A DProviderExecutor.java73 * Execute the given task. If given task is not {@link Preemptable}, it will
76 public <P> void execute(AsyncTask<P, ?, ?> task, P... params) { argument
77 if (task instanceof Preemptable) {
79 mPreemptable.add(new WeakReference<Preemptable>((Preemptable) task));
81 task.executeOnExecutor(mNonPreemptingExecutor, params);
83 task.executeOnExecutor(this, params);
/frameworks/base/core/java/android/hardware/camera2/utils/
H A DTaskDrainer.java31 * <p>The initial state is to allow all tasks to be started and finished. A task may only be started
32 * once, after which it must be finished before starting again. Likewise, finishing a task
69 * Create a new task drainer; {@code onDrained} callbacks will be posted to the listener
82 * Create a new task drainer; {@code onDrained} callbacks will be posted to the listener
97 * Mark an asynchronous task as having started.
99 * <p>A task cannot be started more than once without first having finished. Once
102 * @param task a key to identify a task
108 * If attempting to start a task which is already started (and not finished),
109 * or if attempting to start a task afte
111 taskStarted(T task) argument
142 taskFinished(T task) argument
[all...]
/frameworks/base/libs/hwui/renderthread/
H A DRenderTask.h61 // Takes ownership of task, caller owns lock and signal
62 SignalingRenderTask(RenderTask* task, Mutex* lock, Condition* signal) argument
63 : mTask(task), mLock(lock), mSignal(signal) {}
H A DRenderThread.cpp63 void TaskQueue::queue(RenderTask* task) { argument
65 // to have the same task queued twice
66 LOG_ALWAYS_FATAL_IF(task->mNext || mTail == task, "Task is already in the queue!");
69 if (mTail->mRunAt <= task->mRunAt) {
70 mTail->mNext = task;
71 mTail = task;
76 while (next && next->mRunAt <= task->mRunAt) {
81 task->mNext = mHead;
82 mHead = task;
97 queueAtFront(RenderTask* task) argument
106 remove(RenderTask* task) argument
306 queue(RenderTask* task) argument
315 queueAtFront(RenderTask* task) argument
321 queueAt(RenderTask* task, nsecs_t runAtNs) argument
326 remove(RenderTask* task) argument
[all...]
H A DCanvasContext.cpp391 void CanvasContext::runWithGlContext(RenderTask* task) { argument
394 task->run();
/frameworks/opt/bitmap/src/com/android/bitmap/
H A DContiguousFIFOAggregator.java29 * An implementation of a task aggregator that executes tasks in the order that they are expected
32 * The task will be scheduled to run when its corresponding key becomes the first expected key
35 * If on {@link #execute(Object, Runnable)} the key is not expected, the task will be executed
42 * <li>Execute task <b>2</b> for key <b>B</b>. The first expected key is <b>A</b>,
43 * which has no task associated with it, so we store task <b>2</b>. </li>
44 * <li>Execute task <b>4</b> for key <b>Z</b>. We store task <b>4</b>. </li>
45 * <li>Execute task <b>1</b> for key <b>A</b>. We run task <
165 execute(final T key, final Runnable task) argument
301 Runnable task; field in class:ContiguousFIFOAggregator.Value
303 Value(final Callback<T> callback, final Runnable task) argument
[all...]
/frameworks/base/services/core/java/com/android/server/am/
H A DRecentTasks.java78 Slog.i(TAG, "Can't remove recent task on user " + userId);
116 TaskRecord task = get(i);
117 if (task.userId != user) {
121 if (task.autoRemoveRecents && task.getTopActivity() == null) {
124 task.removedFromRecents();
125 Slog.w(TAG, "Removing auto-remove without activity: " + task);
129 if (task.realActivity != null) {
130 ActivityInfo ai = tmpAvailActCache.get(task.realActivity);
133 ai = pm.getActivityInfo(task
204 moveAffiliatedTasksToFront(TaskRecord task, int taskIndex) argument
306 addLocked(TaskRecord task) argument
436 trimForTaskLocked(TaskRecord task, boolean doTrim) argument
[all...]
H A DTaskPersister.java69 * task being launched a chance to load its resources without this occupying IO bandwidth. */
84 private static final String TAG_TASK = "task";
106 TaskWriteQueueItem(TaskRecord task) { argument
107 mTask = task;
151 private void removeThumbnails(TaskRecord task) { argument
152 final String taskString = Integer.toString(task.taskId);
176 void wakeup(TaskRecord task, boolean flush) { argument
178 if (task != null) {
183 ((TaskWriteQueueItem) item).mTask == task) {
184 if (!task
280 saveToXml(TaskRecord task) argument
[all...]
/frameworks/base/core/java/android/content/
H A DAsyncTaskLoader.java60 // Set to true to indicate that the task has been posted to a handler for
78 // reflect the fact that the task was being canceled.
109 /* Runs on the UI thread, when the waiting task is posted to a handler.
110 * This method is only executed when task execution was deferred (waiting was true). */
117 /* Used for testing purposes to wait for the task to complete. */
174 // There was a pending task already waiting for a previous
177 "cancelLoad: still waiting for cancelled task; dropping next");
185 // There is a task, but it is waiting for the time it should
187 if (DEBUG) Log.v(TAG, "cancelLoad: task is waiting, dropping it");
207 * Called if the task wa
239 dispatchOnCancelled(LoadTask task, D data) argument
252 dispatchOnLoadComplete(LoadTask task, D data) argument
[all...]
/frameworks/base/packages/SystemUI/src/com/android/systemui/recents/views/
H A DTaskStackViewLayoutAlgorithm.java81 /** Computes the stack and task rects */
93 // Compute the task rect
141 // Update the task offsets
146 Task task = tasks.get(i);
147 mTaskProgressMap.put(task.key, pAtFrontMostCardTop);
151 float pPeek = task.group.isFrontMostTask(task) ?
161 // Center the top most task, since that will be focused first
178 // Walk backwards in the task stack and count the number of tasks and visible thumbnails
185 Task task
221 getStackTransform(Task task, float stackScroll, TaskViewTransform transformOut, TaskViewTransform prevTransform) argument
[all...]
/frameworks/base/tests/ActivityTests/src/com/google/android/test/activity/
H A DActivityTestMain.java120 final ActivityManager.RecentTaskInfo task,
134 if (task.id >= 0 && thumbs != null) {
135 mAm.moveTaskToFront(task.id, ActivityManager.MOVE_TASK_WITH_HOME);
138 startActivity(task.baseIntent);
140 Log.w("foo", "Unable to start task: " + e);
149 if (task.id >= 0 && thumbs != null) {
150 mAm.removeTask(task.id);
398 ActivityManager.AppTask task = findDocTask();
399 if (task == null) {
406 task
119 addThumbnail(LinearLayout container, Bitmap bm, final ActivityManager.RecentTaskInfo task, final ActivityManager.TaskThumbnail thumbs) argument
[all...]
/frameworks/support/v4/java/android/support/v4/content/
H A DAsyncTaskLoader.java45 // Set to true to indicate that the task has been posted to a handler for
63 // reflect the fact that the task was being canceled.
94 /* Runs on the UI thread, when the waiting task is posted to a handler.
95 * This method is only executed when task execution was deferred (waiting was true). */
102 /* Used for testing purposes to wait for the task to complete. */
158 // There was a pending task already waiting for a previous
161 "cancelLoad: still waiting for cancelled task; dropping next");
169 // There is a task, but it is waiting for the time it should
171 if (DEBUG) Log.v(TAG, "cancelLoad: task is waiting, dropping it");
191 * Called if the task wa
223 dispatchOnCancelled(LoadTask task, D data) argument
236 dispatchOnLoadComplete(LoadTask task, D data) argument
[all...]
H A DModernAsyncTask.java87 * Indicates the current status of the task. Each status will be set only once
88 * during the lifetime of a task.
92 * Indicates that the task has not been executed yet.
96 * Indicates that the task is running.
120 * Creates a new asynchronous task. This constructor must be invoked on the UI thread.
169 * Returns the current status of this task.
180 * by the caller of this task.
185 * @param params The parameters of the task.
187 * @return A result, defined by the subclass of this task.
208 * <p>This method won't be invoked if the task wa
501 AsyncTaskResult(ModernAsyncTask task, Data... data) argument
[all...]
/frameworks/base/core/java/android/os/
H A DAsyncTask.java49 * <p>An asynchronous task is defined by a computation that runs on a background thread and
50 * whose result is published on the UI thread. An asynchronous task is defined by 3 generic
92 * <p>Once created, a task is executed very simply:</p>
98 * <p>The three types used by an asynchronous task are the following:</p>
100 * <li><code>Params</code>, the type of the parameters sent to the task upon
107 * <p>Not all types are always used by an asynchronous task. To mark a type as unused,
114 * <p>When an asynchronous task is executed, the task goes through 4 steps:</p>
116 * <li>{@link #onPreExecute()}, invoked on the UI thread before the task
117 * is executed. This step is normally used to setup the task, fo
686 AsyncTaskResult(AsyncTask task, Data... data) argument
[all...]
H A DHandler.java422 * Runs the specified task synchronously.
433 * must synchronously await completion of a task that must run on the
752 public BlockingRunnable(Runnable task) { argument
753 mTask = task;
/frameworks/base/core/java/android/view/textservice/
H A DSpellCheckerSession.java226 private static String taskToString(int task) { argument
227 switch (task) {
237 return "Unexpected task=" + task;
460 // Enqueue the task to task queue.
467 // Only one close task should be processed, while we need to remove
/frameworks/base/libs/hwui/
H A DPathCache.cpp191 // If there is a pending task we must wait for it to return
193 const sp<Task<SkBitmap*> >& task = texture->task(); local
194 if (task != nullptr) {
195 task->getResult();
198 // If there is a pending task, the path was not added
312 void PathCache::PathProcessor::onProcess(const sp<Task<SkBitmap*> >& task) { argument
313 PathTask* t = static_cast<PathTask*>(task.get());
383 const sp<Task<SkBitmap*> >& task = texture->task(); local
422 sp<PathTask> task = new PathTask(path, paint, texture); local
[all...]
H A DPathCache.h94 sp<Task<SkBitmap*> > task() const { function in struct:android::uirenderer::PathTexture
98 void setTask(const sp<Task<SkBitmap*> >& task) { argument
99 mTask = task;
282 // copied, since input path not guaranteed to survive for duration of task
295 virtual void onProcess(const sp<Task<SkBitmap*> >& task) override;
/frameworks/base/services/core/java/com/android/server/wm/
H A DTaskStack.java282 void addTask(Task task, boolean toTop) { argument
283 addTask(task, toTop, task.showForAllUsers());
288 * @param task The task to add.
290 * @param showForAllUsers Whether to show the task regardless of the current user.
292 void addTask(Task task, boolean toTop, boolean showForAllUsers) { argument
298 if (!showForAllUsers && !mService.isCurrentProfileLocked(task.mUserId)) {
299 // Place the task below all current user tasks.
307 // Put it above first non-current user task
322 moveTaskToTop(Task task) argument
329 moveTaskToBottom(Task task) argument
340 removeTask(Task task) argument
[all...]

Completed in 8941 milliseconds

123