Home
last modified time | relevance | path

Searched refs:tasks (Results 1 – 25 of 402) sorted by relevance

12345678910>>...17

/external/libchrome/base/
Dtracked_objects_unittest.cc80 ASSERT_EQ(1u, process_data_phase.tasks.size()); in ExpectSimpleProcessData()
82 EXPECT_EQ(kFile, process_data_phase.tasks[0].birth.location.file_name); in ExpectSimpleProcessData()
84 process_data_phase.tasks[0].birth.location.function_name); in ExpectSimpleProcessData()
86 process_data_phase.tasks[0].birth.location.line_number); in ExpectSimpleProcessData()
88 EXPECT_EQ(birth_thread, process_data_phase.tasks[0].birth.thread_name); in ExpectSimpleProcessData()
90 EXPECT_EQ(count, process_data_phase.tasks[0].death_data.count); in ExpectSimpleProcessData()
92 process_data_phase.tasks[0].death_data.run_duration_sum); in ExpectSimpleProcessData()
93 EXPECT_EQ(run_ms, process_data_phase.tasks[0].death_data.run_duration_max); in ExpectSimpleProcessData()
95 process_data_phase.tasks[0].death_data.run_duration_sample); in ExpectSimpleProcessData()
97 process_data_phase.tasks[0].death_data.queue_duration_sum); in ExpectSimpleProcessData()
[all …]
/external/lisa/tests/eas/
Dgeneric.py167 tasks = experiment.wload.tasks.keys()
171 df = df[df['next_comm'].isin(tasks)]
204 tasks = experiment.wload.tasks.keys()
221 for task in tasks:
258 def _test_slack(self, experiment, tasks): argument
274 for task in tasks:
282 def _test_task_placement(self, experiment, tasks): argument
322 def test_slack(self, experiment, tasks): argument
323 self._test_slack(experiment, tasks)
325 def test_task_placement(self, experiment, tasks): argument
[all …]
Dload_tracking.py79 [task] = experiment.wload.tasks.keys()
111 [task] = experiment.wload.tasks.keys()
209 def _test_signal(self, experiment, tasks, signal_name): argument
210 [task] = tasks
223 def test_task_util_avg(self, experiment, tasks): argument
227 return self._test_signal(experiment, tasks, 'util_avg')
230 def test_task_load_avg(self, experiment, tasks): argument
239 return self._test_signal(experiment, tasks, 'load_avg')
285 def _test_signal(self, experiment, tasks, signal_name): argument
286 [task] = tasks
[all …]
/external/lisa/tests/sfreq/
Dsmoke_test.config49 "tasks" : 1,
63 "tasks" : 1,
77 "tasks" : 1,
91 "tasks" : 1,
105 "tasks" : 1,
119 "tasks" : 1,
133 "tasks" : 1,
147 "tasks" : 1,
161 "tasks" : 1,
175 "tasks" : 1,
[all …]
/external/autotest/site_utils/suite_scheduler/
Dbase_event_unittest.py86 tasks = [FakeTask(*task, pymox=self.mox) for task in self._TASKS]
87 tasks.append(FakeTask(*self._TASKS[0], pymox=self.mox))
91 event.tasks = tasks
92 self.assertEquals(len(event.tasks), len(self._TASKS))
97 tasks = [FakeTask(*task, pymox=self.mox) for task in self._TASKS]
98 for task in tasks:
104 event.tasks = tasks
110 for task in tasks:
119 tasks = [FakeTask(*task, pymox=self.mox) for task in self._TASKS]
120 all_tasks = tasks + [FakeOneShot(*self._TASKS[0], pymox=self.mox)]
[all …]
Dbase_event.py117 def tasks(self): member in BaseEvent
137 @tasks.setter
138 def tasks(self, iterable_of_tasks): member in BaseEvent
156 self.tasks = to_merge.tasks
219 return list(self.tasks)
240 tasks = list(self.tasks) if force else self.FilterTasks()
241 for task in tasks:
/external/guava/guava-bootstrap/src/java/util/concurrent/
DAbstractExecutorService.java38 private <T> T doInvokeAny(Collection<? extends Callable<T>> tasks, in doInvokeAny() argument
41 if (tasks == null) in doInvokeAny()
43 int ntasks = tasks.size(); in doInvokeAny()
53 Iterator<? extends Callable<T>> it = tasks.iterator(); in doInvokeAny()
104 public <T> T invokeAny(Collection<? extends Callable<T>> tasks) in invokeAny() argument
107 return doInvokeAny(tasks, false, 0); in invokeAny()
114 public <T> T invokeAny(Collection<? extends Callable<T>> tasks, in invokeAny() argument
117 return doInvokeAny(tasks, true, unit.toNanos(timeout)); in invokeAny()
120 public <T> List<Future<T>> invokeAll(Collection<? extends Callable<T>> tasks) in invokeAll() argument
122 if (tasks == null) in invokeAll()
[all …]
/external/ltp/testcases/kernel/controllers/cpuctl_fj/
Drun_cpuctl_test_fj.sh70 echo $tmppid > $CPUCTL/tasks
71 done < $tmpdir/tasks
140 task=`cat $CPUCTL/tasks | grep "\b$pid\b"`
168 task=`cat $CPUCTL/tmp/tasks`
200 task=`cat $CPUCTL/tmp/tmp1/tasks`
216 echo 1 > $CPUCTL/tmp/tasks
222 tasks=`cat $CPUCTL/tmp/tasks`
223 if [ $tasks -ne 1 ]
238 ./cpuctl_fj_simple_echo 3 $CPUCTL/tmp/tasks
244 tasks=`cat $CPUCTL/tmp/tasks`
[all …]
/external/toolchain-utils/bestflags/
Dsteering_test.py40 def __init__(self, tasks, next_generations): argument
48 Generation.__init__(self, tasks, None)
91 tasks = [IdentifierMockTask(STEERING_TEST_STAGE, t) for t in test_ranges]
92 steering_tasks = set(tasks)
120 tasks = [task for task in generation.Pool()]
123 while tasks:
126 assert task in tasks
127 tasks.remove(task)
148 tasks = [IdentifierMockTask(STEERING_TEST_STAGE, t) for t in test_ranges]
149 steering_tasks = set(tasks)
/external/ltp/testcases/kernel/controllers/io-throttle/
Drun_io_throttle_test.sh51 for tasks in 1 2 4; do
76 if [ $tasks -eq 1 ]; then
81 echo -n ">> testing $tasks parallel $stream per cgroup "
89 /bin/echo $$ > /dev/blockioctl/$MYGROUP/tasks
96 ./iobw -direct $tasks $BUFSIZE $DATASIZE > /tmp/$MYGROUP.out &
99 /bin/echo $$ > /dev/blockioctl/tasks
107 echo "ERROR: error code $ret during test $tasks.$strategy.$i. Exiting test."
115 echo "TPASS Block device I/O bandwidth controller: test $tasks.$strategy.$i PASSED";
117 echo "TFAIL Block device I/O bandwidth controller: test $tasks.$strategy.$i FAILED";
/external/guava/guava-tests/test/com/google/common/util/concurrent/
DWrappingExecutorServiceTest.java96 List<Callable<String>> tasks = createTasks(3); in testInvokeAll() local
100 List<Future<String>> futures = testExecutor.invokeAll(tasks); in testInvokeAll()
109 List<Future<String>> futures = testExecutor.invokeAll(tasks, timeout, unit); in testInvokeAll()
116 List<Callable<String>> tasks = createTasks(3); in testInvokeAny() local
120 String s = testExecutor.invokeAny(tasks); in testInvokeAny()
129 String s = testExecutor.invokeAny(tasks, timeout, unit); in testInvokeAny()
213 public <T> List<Future<T>> invokeAll(Collection<? extends Callable<T>> tasks) in invokeAll() argument
216 assertTaskWrapped(tasks); in invokeAll()
217 return inline.invokeAll(tasks); in invokeAll()
222 Collection<? extends Callable<T>> tasks, long timeout, TimeUnit unit) in invokeAll() argument
[all …]
/external/autotest/scheduler/
Dmonitor_db_cleanup_test.py43 tasks = models.SpecialTask.objects.all()
44 self.assertEquals(len(tasks), 1)
45 self.assertEquals(tasks[0].host.id, 1)
46 self.assertEquals(tasks[0].task, models.SpecialTask.Task.VERIFY)
69 tasks = models.SpecialTask.objects.all()
71 self.assertEquals(len(tasks), 2)
72 self.assertTrue(tasks[0].host.id in (1, 4, 5, 6))
73 self.assertTrue(tasks[1].host.id in (1, 4, 5, 6))
74 self.assertEquals(tasks[0].task, models.SpecialTask.Task.VERIFY)
75 self.assertEquals(tasks[1].task, models.SpecialTask.Task.VERIFY)
Dscheduler_models_unittest.py346 def _check_special_tasks(self, tasks, task_types): argument
347 self.assertEquals(len(tasks), len(task_types))
348 for task, (task_type, queue_entry_id) in zip(tasks, task_types):
358 tasks = self._test_pre_job_tasks_helper()
360 self._check_special_tasks(tasks, [(models.SpecialTask.Task.RESET, 1)])
368 tasks = self._test_pre_job_tasks_helper()
370 self._check_special_tasks(tasks, [(models.SpecialTask.Task.RESET, 1)])
376 tasks = self._test_pre_job_tasks_helper()
378 self._check_special_tasks(tasks, [(models.SpecialTask.Task.RESET, 1)])
386 tasks = self._test_pre_job_tasks_helper()
[all …]
/external/guava/guava-testlib/src/com/google/common/util/concurrent/testing/
DSameThreadScheduledExecutorService.java101 Collection<? extends Callable<T>> tasks) throws InterruptedException { in invokeAll() argument
102 Preconditions.checkNotNull(tasks, "tasks must not be null!"); in invokeAll()
103 return delegate.invokeAll(tasks); in invokeAll()
108 Collection<? extends Callable<T>> tasks, long timeout, TimeUnit unit) in invokeAll() argument
110 Preconditions.checkNotNull(tasks, "tasks must not be null!"); in invokeAll()
112 return delegate.invokeAll(tasks, timeout, unit); in invokeAll()
116 public <T> T invokeAny(Collection<? extends Callable<T>> tasks) in invokeAny() argument
118 Preconditions.checkNotNull(tasks, "tasks must not be null!"); in invokeAny()
119 return delegate.invokeAny(tasks); in invokeAny()
123 public <T> T invokeAny(Collection<? extends Callable<T>> tasks, in invokeAny() argument
[all …]
/external/guava/guava/src/com/google/common/util/concurrent/
DWrappingExecutorService.java84 Collection<? extends Callable<T>> tasks) {
86 for (Callable<T> task : tasks) {
115 Collection<? extends Callable<T>> tasks) throws InterruptedException {
116 return delegate.invokeAll(wrapTasks(tasks));
121 Collection<? extends Callable<T>> tasks, long timeout, TimeUnit unit)
123 return delegate.invokeAll(wrapTasks(tasks), timeout, unit);
127 public final <T> T invokeAny(Collection<? extends Callable<T>> tasks)
129 return delegate.invokeAny(wrapTasks(tasks));
134 Collection<? extends Callable<T>> tasks, long timeout, TimeUnit unit)
136 return delegate.invokeAny(wrapTasks(tasks), timeout, unit);
DForwardingExecutorService.java55 Collection<? extends Callable<T>> tasks) throws InterruptedException { in invokeAll() argument
56 return delegate().invokeAll(tasks); in invokeAll()
61 Collection<? extends Callable<T>> tasks, long timeout, TimeUnit unit) in invokeAll() argument
63 return delegate().invokeAll(tasks, timeout, unit); in invokeAll()
67 public <T> T invokeAny(Collection<? extends Callable<T>> tasks) in invokeAny() argument
69 return delegate().invokeAny(tasks); in invokeAny()
74 Collection<? extends Callable<T>> tasks, long timeout, TimeUnit unit) in invokeAny() argument
76 return delegate().invokeAny(tasks, timeout, unit); in invokeAny()
/external/autotest/contrib/
Dcompare_suite.py151 tasks = tasks_cache.get(self.hostname, None)
152 if not tasks:
153 tasks = models.SpecialTask.objects.filter(
157 tasks_cache[self.hostname] = tasks
158 for task in tasks:
228 tasks = []
230 tasks += [task for task in job.get_all_tasks()
232 if not tasks:
235 task_min = tasks[0]
236 task_max = tasks[0]
[all …]
/external/guava/guava-tests/test/com/google/common/eventbus/
DAsyncEventBusTest.java56 List<Runnable> tasks = executor.getTasks(); in testBasicDistribution() local
57 assertEquals("One event dispatch task should be queued.", 1, tasks.size()); in testBasicDistribution()
59 tasks.get(0).run(); in testBasicDistribution()
73 List<Runnable> tasks = Lists.newArrayList(); field in AsyncEventBusTest.FakeExecutor
77 tasks.add(task); in execute()
81 return tasks; in getTasks()
/external/guice/extensions/service/src/com/google/inject/service/
DCompositeService.java81 final List<Future<State>> tasks = Lists.newArrayList(); in compose()
83 tasks.add(injector.getInstance(service).start()); in compose()
86 return futureGet(tasks, State.STARTED); in compose()
90 final List<Future<State>> tasks = Lists.newArrayList(); in compose() local
92 tasks.add(injector.getInstance(service).stop()); in compose()
95 return futureGet(tasks, State.STOPPED); in compose()
104 private FutureTask<Service.State> futureGet(final List<Future<Service.State>> tasks,
109 for (Future<Service.State> task : tasks) {
/external/lisa/libs/utils/
Dtest.py139 tasks = experiment.wload.tasks.keys()
142 [t for t in tasks if task_filter in t])
157 tasks = experiment.wload.tasks.keys()
158 trace = Trace(self.te.platform, experiment.out_dir, events, tasks)
189 for task in experiment.wload.tasks.keys():
217 tasks = experiment.wload.tasks.keys()
219 wrapped_test(experiment, tasks, *args, **kwargs)
/external/vogar/src/vogar/tasks/
DTaskQueue.java17 package vogar.tasks;
39 private final LinkedList<Task> tasks = new LinkedList<Task>(); field in TaskQueue
53 tasks.add(task); in enqueue()
56 public void enqueueAll(Collection<Task> tasks) { in enqueueAll() argument
57 this.tasks.addAll(tasks); in enqueueAll()
61 return new ArrayList<Task>(tasks); in getTasks()
91 for (Task task : tasks) { in printTasks()
120 for (Task task : tasks) { in printProblemTasks()
200 for (Iterator<Task> it = tasks.iterator(); it.hasNext(); ) { in promoteBlockedTasks()
/external/skia/infra/bots/
DREADME.md10 Files in this directory define a DAG of tasks which run at every Skia commit. A
15 Jobs are collections of related tasks which help define sub-sections of the DAG,
19 The tasks.json file in this directory is the master list of tasks and jobs for
20 the repo. Note that tasks.json is NEVER edited by hand but generated via
23 reads the tasks.json file at each commit to determine which jobs to run. For
24 convenience, gen_tasks.go is provided to generate tasks.json and also to test it
25 for correct syntax and detecting cycles and orphaned tasks. Always edit
26 gen_tasks.go or one of the following input JSON files, rather than tasks.json
40 need to run gen_tasks.go to regenerate tasks.json:
49 tasks.json is unchanged:
[all …]
/external/skia/site/dev/testing/
Dautomated_testing.md8 to do the heavy lifting for our automated testing. It farms out tasks, which may
13 The [Skia Task Scheduler](http://go/skia-task-scheduler) determines what tasks
17 *tasks*. The job is complete when all of its component tasks have succeeded
18 or is considered a failure when any of its component tasks fails. The scheduler
19 may automatically retry tasks within its set limits. Jobs are not retried.
23 Each Skia repository has an infra/bots/tasks.json file which defines the jobs
24 and tasks for the repo. Most jobs will run at every commit, but it is possible
26 have a gen_tasks.go which will generate tasks.json. You will need to
34 has changed. There is also a test mode which simply verifies that the tasks.json
46 trigger a try job for any job listed in tasks.json:
[all …]
/external/gemmlowp/meta/
Dlegacy_multi_thread_common.h84 std::int32_t k, std::vector<internal::TaskRect>* tasks) { in PrepareTasks() argument
94 tasks->push_back(TaskRect(0, m, 0, n)); in PrepareTasks()
101 tasks->push_back(TaskRect(i * m_chunk, m_chunk, 0, n)); in PrepareTasks()
104 tasks->push_back(TaskRect(last_m_offset, m - last_m_offset, 0, n)); in PrepareTasks()
108 tasks->push_back(TaskRect(0, m, i * n_chunk, n_chunk)); in PrepareTasks()
111 tasks->push_back(TaskRect(0, m, last_n_offset, n - last_n_offset)); in PrepareTasks()
135 std::vector<Task*> tasks; in MultiThreadedMatrixMatrix() local
138 [&tasks, &task_scratch, lhs, rhs, k, result, result_stride, operation, in MultiThreadedMatrixMatrix()
140 tasks.push_back(new internal::MetaTask<IN_TYPE, OUT_TYPE, F>( in MultiThreadedMatrixMatrix()
144 pool->Execute(tasks); in MultiThreadedMatrixMatrix()
/external/autotest/site_utils/
Djob_history.py150 tasks = models.SpecialTask.objects.filter(
154 self[host_id] = TaskCache(tasks, search_start_time, search_end_time)
161 def __init__(self, tasks=[], start_time=None, end_time=None): argument
164 self.tasks = tasks
180 return [task for task in self.tasks if task.queue_entry and
266 tasks = task_caches.try_get(self.host.id, self.id,
268 if tasks is None:
271 tasks = task_caches.try_get(self.host.id, self.id,
274 tasks = models.SpecialTask.objects.filter(
278 tasks = [task for task in tasks if task.queue_entry and
[all …]

12345678910>>...17