HomeSort by relevance Sort by last modified time
    Searched refs:Job (Results 76 - 100 of 272) sorted by null

1 2 34 5 6 7 8 91011

  /sdk/eclipse/plugins/com.android.ide.eclipse.adt/src/com/android/ide/eclipse/adt/internal/actions/
DexDumpAction.java 39 import org.eclipse.core.runtime.jobs.Job;
94 * Calls {@link #runDexDump(IProject, IProgressMonitor)} inside a job.
99 new Job("Dexdump") {
113 * @param monitor The job's monitor.
AddSupportJarAction.java 54 import org.eclipse.core.runtime.jobs.Job;
508 * @param waitForFinish whether this method should wait for the job to
519 // Run an Eclipse asynchronous job to update the project
520 Job job = new Job("Add Support Library Dependency to Project") { local
565 Job fix = FixProjectAction.createFixProjectJob(libraryProject);
582 job.schedule();
586 job.join();
587 return job.getState() == IStatus.OK
    [all...]
  /sdk/eclipse/plugins/com.android.ide.eclipse.adt/src/com/android/ide/eclipse/adt/internal/lint/
LintViewPart.java 36 import org.eclipse.core.runtime.jobs.Job;
294 Job[] currentJobs = LintJob.getCurrentJobs();
299 for (Job job : currentJobs) {
300 job.addJobChangeListener(this);
469 Job[] jobs = LintJob.getCurrentJobs();
477 Job job = EclipseLintRunner.startLint(resources, null, null, local
479 if (job != null && workbench != null) {
480 job.addJobChangeListener(LintViewPart.this)
    [all...]
  /external/emma/core/java12/com/vladium/emma/instr/
InstrProcessorST.java 234 // class def modified: write it to an array and submit a write job
262 // clone the array and submit an entry write job
486 // class def modified: write it to an array and submit a write job
499 // clone the array and submit a file write job
577 // in overwrite mode, flush the job queue before going to the next directory:
702 // reset job queue position:
939 final Job job = m_jobs [j]; local
    [all...]
  /packages/apps/Gallery2/src/com/android/gallery3d/app/
ManageCachePage.java 49 import com.android.gallery3d.util.ThreadPool.Job;
247 private Job<Void> mUpdateStorageInfoJob = new Job<Void>() {
  /sdk/eclipse/plugins/com.android.ide.eclipse.adt/src/com/android/ide/eclipse/adt/internal/build/builders/
BaseBuilder.java 51 import org.eclipse.core.runtime.jobs.Job;
478 protected void launchJob(Job newJob) {
479 newJob.setPriority(Job.BUILD);
  /external/autotest/contrib/
always_failing_tests.py 48 tests = tko_models.Test.objects.select_related('job'
85 afe_job_ids = set(map(lambda t: t.job.afe_job_id, all_fail))
86 afe_jobs = afe_models.Job.objects.select_related('parent_job')\
91 for job in afe_jobs:
92 job_to_hash[job.id] = md5(job.control_file)
97 for job in afe_jobs:
98 job_id = job.parent_job
100 job_id = job
105 job_to_suite[job.id] = x.groups(1)[0
    [all...]
compare_suite.py 29 LOG_BASE_URL = 'http://%s/tko/retrieve_logs.cgi?job=/results/' % AUTOTEST_SERVER
44 @param autoserv_log_url: Url to the repair job's autoserv.DEBUG log.
108 """Details about the job run time, including time spent on special tasks.
110 def __init__(self, job, suite_start_time=None, suite_end_time=None):
113 # AFE job ID
114 self.id = job.id
115 # AFE job model
116 self.job = job
117 # Name of the job, strip all build and suite info
    [all...]
  /external/autotest/frontend/health/
complete_failures_functional_test.py 99 job = models.Job(job_idx=1)
105 old_passing_test = models.Test(job=job, status=success_status,
110 failing_test = models.Test(job=job, status=fail_status,
115 good_test = models.Test(job=job, status=success_status,
passing_experimental_functional_test.py 84 job = tko_models.Job(job_idx=1)
90 tko_test1 = tko_models.Test(job=job, status=success_status,
95 tko_test2 = tko_models.Test(job=job, status=success_status,
  /external/autotest/scheduler/
rdb_testing_utils.py 164 def add_deps_to_job(cls, job, dep_names=set([])):
168 job.dependency_labels.add(*label_objects)
173 """Assign a job to a shard.
175 @param job: A job object without a shard.
176 @param shard_hostname: The hostname of a shard to assign the job.
178 @raises ValueError: If the job already has a shard.
180 job_filter = models.Job.objects.filter(id=job_id, shard__isnull=True)
182 raise ValueError('Failed to assign job %s to shard %s' %
212 deps: The labels on the host that match job deps
    [all...]
scheduler_models_unittest.py 152 # Dummy Job to avoid creating a one in the HostQueueEntry __init__.
158 self.god.stub_with(scheduler_models, 'Job', MockJob)
222 job = self._create_job(**create_job_kwargs)
224 job.dependency_labels.add(label)
225 hqes = list(scheduler_models.HostQueueEntry.fetch(where='job_id=%d' % job.id))
302 hqe.job.update_field('shard_id', 3)
307 self.assertIsNone(hqe.job.shard_id)
310 self.assertEquals(hqe.job.shard_id, 3)
332 queue_entry.job.reboot_before = reboot_before
339 job = scheduler_models.Job(django_job.id
    [all...]
  /external/autotest/scheduler/shard/
simple_heartbeat_server.py 78 jobs = models.Job.objects.filter(
shard_client_unittest.py 178 job, hqe = jobs[0], hqes[0]
207 job = models.Job.objects.all()[0]
208 job.shard = None
209 job.save()
210 hqe = job.hostqueueentry_set.all()[0]
249 job2 = models.Job.objects.get(pk=job1_serialized['id'])
  /external/chromium-trace/catapult/trace_processor/trace_processor/
process_traces.py 14 from tracing.mre import job as job_module
54 job = job_module.Job(map_handle)
60 trace_handles, job,
  /external/chromium-trace/catapult/tracing/tracing/mre/
map_single_trace_unittest.py 11 from tracing.mre import job as job_module
18 return job_module.Job(map_handle, None)
  /external/autotest/frontend/afe/
models.py 27 # job options and user preferences
43 scheduled for a job at the same time as other hosts sharing that label.
49 The job.synch_count is considered the minimum.
72 def enqueue_job(self, job, is_template=False):
73 """Enqueue a job on an associated atomic group of hosts.
75 @param job: A job to enqueue.
78 queue_entry = HostQueueEntry.create(atomic_group=self, job=job,
105 label is requested by the job/test (either as the meta_host o
1112 def job(self): member in class:ParameterizedJob
1690 job = dbmodels.ForeignKey(Job) variable in class:JobKeyval
1733 job = dbmodels.ForeignKey(Job) variable in class:IneligibleHostQueue
1768 job = dbmodels.ForeignKey(Job) variable in class:HostQueueEntry
1988 job = dbmodels.ForeignKey(Job) variable in class:RecurringRun
    [all...]
site_rpc_interface_unittest.py 199 """Ensure that failure to schedule the suite job fails the RPC."""
507 known_job_ids = [job.id for job in known_jobs]
529 (job.id, job.name, shard_hostname) for job in jobs]
530 returned_jobs = [(job['id'], job['name'], job['shard']['hostname'])
531 for job in retval_jobs
    [all...]
resources_test.py 200 self.check_collection(entries, ['job', 'id'], [1])
320 job = models.Job.objects.get(id=1)
321 job.control_file = self.CONTROL_FILE_CONTENTS
322 job.save()
324 models.JobKeyval.objects.create(job=job, key='mykey', value='myvalue')
353 job = self.request('get', 'jobs/1')
354 entries = self.request('get', job['queue_entries']['href'])
369 job = models.Job.objects.get(id=3
    [all...]
  /external/autotest/tko/
job_serializer.py 3 """A script that provides convertion between models.job and a protocol
6 This script contains only one class that takes an job instance and
8 responsible for serializing the job instance via protocol buffers.
30 """A class that takes a job object of the tko module and package
33 This class will take a model.job object as input and create a
34 protocol buffer to include all the content of the job object. This
65 """Takes in a binary file name and returns a tko job object.
68 job object and then converts the job object into a tko job
    [all...]
job_serializer_unittest.py 26 """Base class as a job serializer unittest"""
36 tko_job = models.job('/tmp/', 'autotest', 'test', 'My Computer',
56 self.pb_job = tko_pb2.Job()
231 """Check if convert between models.job and pb job is correct even
245 self.pb_job = tko_pb2.Job()
254 """Check if convert between models.job and pb job is correct after
  /sdk/eclipse/plugins/com.android.ide.eclipse.tests/src/com/android/ide/eclipse/adt/internal/wizards/templates/
TemplateHandlerTest.java 69 import org.eclipse.core.runtime.jobs.Job;
715 Job job = new Job("Validate project") { local
727 job.schedule(1000);
728 job.join();
729 Object property = job.getProperty(ERROR_KEY);
749 private void ensureValidProject(@NonNull Job job, @NonNull IProject project) throws Exception {
751 ensureNoBuildErrors(job, project)
    [all...]
  /sdk/eclipse/plugins/com.android.ide.eclipse.adt/src/com/android/ide/eclipse/adt/
AdtPlugin.java 71 import org.eclipse.core.runtime.jobs.Job;
168 * This variable indicates that the job inside parseSdkContent() is currently
302 // Wait 2 seconds before starting the job. This leaves some time to the
    [all...]
  /external/autotest/site_utils/
job_history.py 6 # This module provides functions for caller to retrieve a job's history,
7 # including special tasks executed before and after the job, and each steps
22 LOG_BASE_URL = 'http://%s/tko/retrieve_logs.cgi?job=/results/' % AUTOTEST_SERVER
28 # Add some buffer before and after job start/end time when searching for special
29 # tasks. This is to guarantee to include reset before the job starts and repair
30 # and cleanup after the job finishes.
45 @return: A dictionary as the history entry of given job/task.
60 """Return a list of dictionaries of select job/task's history.
129 @param job_id: ID of the test job that's related to the special task.
133 Job id. Note that, None means the cache is not available
    [all...]
  /external/v8/tools/testrunner/local/
execution.py 117 class Job(object):
124 """Executes the job.
143 class TestJob(Job):
182 def RunTest(job, process_context):
183 return job.Run(process_context)

Completed in 1929 milliseconds

1 2 34 5 6 7 8 91011