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

123456789

/openjdk7/jdk/src/share/classes/sun/nio/ch/
H A DCancellable.java38 void onCancel(PendingFuture<?,?> task); argument
H A DAsynchronousChannelGroupImpl.java63 // task queue for when using a fixed thread pool. In that case, thread
107 private Runnable bindToGroup(final Runnable task) { argument
112 task.run();
117 private void startInternalThread(final Runnable task) { argument
123 ThreadPool.defaultThreadFactory().newThread(task).start();
129 protected final void startThreads(Runnable task) { argument
132 startInternalThread(task);
137 task = bindToGroup(task);
140 pool.executor().execute(task);
156 threadExit(Runnable task, boolean replaceMe) argument
177 executeOnHandlerTask(Runnable task) argument
184 executeOnPooledThread(Runnable task) argument
192 offerTask(Runnable task) argument
200 schedule(Runnable task, long timeout, TimeUnit unit) argument
316 execute(Runnable task) argument
[all...]
/openjdk7/jdk/test/java/util/concurrent/FutureTask/
H A DCustomized.java69 static <V> void checkReady(final FutureTask<V> task) { argument
70 check(! task.isDone());
71 check(! task.isCancelled());
74 task.get(0L, TimeUnit.SECONDS); }});
77 static <V> void checkDone(final FutureTask<V> task) { argument
79 check(task.isDone());
80 check(! task.isCancelled());
81 check(task.get() != null);
85 static <V> void checkCancelled(final FutureTask<V> task) { argument
86 check(task
95 checkThrew(final FutureTask<V> task) argument
105 cancel(FutureTask<V> task, boolean mayInterruptIfRunning) argument
110 run(FutureTask<V> task) argument
[all...]
H A DThrow.java52 MyFutureTask(Callable<Void> task) { super(task); } argument
56 MyFutureTask checkTask(final MyFutureTask task) { argument
57 check(! task.isCancelled());
58 check(! task.isDone());
59 return task;
88 final MyFutureTask task = taskFor(c, null);
89 check(task.cancel(false));
91 new F(){void f() throws Throwable { task.get(); }});
95 final MyFutureTask task
[all...]
/openjdk7/jdk/src/share/classes/java/util/concurrent/
H A DExecutorCompletionService.java116 QueueingFuture(RunnableFuture<V> task) { argument
117 super(task, null);
118 this.task = task;
120 protected void done() { completionQueue.add(task); }
121 private final Future<V> task; field in class:ExecutorCompletionService.QueueingFuture
124 private RunnableFuture<V> newTaskFor(Callable<V> task) { argument
126 return new FutureTask<V>(task);
128 return aes.newTaskFor(task);
131 private RunnableFuture<V> newTaskFor(Runnable task, argument
178 submit(Callable<V> task) argument
185 submit(Runnable task, V result) argument
[all...]
H A DCompletionService.java56 * submitting a task to a {@code CompletionService}
58 * actions taken by that task, which in turn <i>happen-before</i>
64 * Submits a value-returning task for execution and returns a Future
65 * representing the pending results of the task. Upon completion,
66 * this task may be taken or polled.
68 * @param task the task to submit
69 * @return a Future representing pending completion of the task
70 * @throws RejectedExecutionException if the task cannot be
72 * @throws NullPointerException if the task i
74 submit(Callable<V> task) argument
90 submit(Runnable task, V result) argument
[all...]
H A DExecutors.java126 * sequentially, and no more than one task will be active at any
207 * sequentially, and no more than one task will be active at any
224 * guaranteed to execute sequentially, and no more than one task
339 * any task runs in {@link ThreadPoolExecutor} subclasses using
358 * called, runs the given task and returns the given result. This
361 * @param task the task to run
364 * @throws NullPointerException if task null
366 public static <T> Callable<T> callable(Runnable task, T result) { argument
367 if (task
379 callable(Runnable task) argument
464 final Runnable task; field in class:Executors.RunnableAdapter
466 RunnableAdapter(Runnable task, T result) argument
480 private final Callable<T> task; field in class:Executors.PrivilegedCallable
483 PrivilegedCallable(Callable<T> task) argument
507 private final Callable<T> task; field in class:Executors.PrivilegedCallableUsingCurrentClassLoader
511 PrivilegedCallableUsingCurrentClassLoader(Callable<T> task) argument
637 submit(Runnable task) argument
640 submit(Callable<T> task) argument
643 submit(Runnable task, T result) argument
[all...]
/openjdk7/jdk/src/share/classes/com/sun/jmx/snmp/tasks/
H A DTaskServer.java34 * tasks. Whether the task is executed in the client thread or in another
45 * Submit a task to be executed.
46 * Once a task is submitted, it is guaranteed that either
47 * {@link com.sun.jmx.snmp.tasks.Task#run() task.run()} or
48 * {@link com.sun.jmx.snmp.tasks.Task#cancel() task.cancel()} will be called.
49 * <p>Whether the task is executed in the client thread (e.g.
50 * <code>public void submitTask(Task task) { task.run(); }</code>) or in
52 * public void submitTask(Task task) { new Thrad(task)
56 submitTask(Task task) argument
[all...]
/openjdk7/jdk/src/macosx/classes/com/apple/concurrent/
H A DLibDispatchMainQueue.java42 public void execute(final Runnable task) { argument
43 LibDispatchNative.nativeExecuteSync(ptr, task);
49 public void execute(final Runnable task) { argument
50 LibDispatchNative.nativeExecuteAsync(ptr, task);
H A DLibDispatchConcurrentQueue.java36 public void execute(final Runnable task) { argument
37 LibDispatchNative.nativeExecuteAsync(ptr, task);
H A DLibDispatchNative.java38 static native void nativeExecuteAsync(long nativeQueue, Runnable task); argument
39 static native void nativeExecuteSync(long nativeQueue, Runnable task); argument
/openjdk7/jdk/test/sun/rmi/rmic/newrmic/equivalence/
H A DComputeServer.java32 * Called by the task and passes itself as an object
34 Object compute(Task task) throws RemoteException; argument
H A DComputeServerImpl.java29 * Class accepts a task and runs it in its own space.
41 * Accepts task and runs it
43 public Object compute(Task task) { argument
44 return task.run();
/openjdk7/langtools/test/tools/javac/api/
H A DT6357331.java39 final JavacTask task = (JavacTask) (tool.getTask(out, null, null, null, null, null));
43 task.setTaskListener(new TaskListener() {
45 task.getElements();
46 task.getTypes();
51 task.call();
55 task.getElements();
63 task.getTypes();
H A DTestResolveError.java47 * of calling task.parseType with a name whose resolution depended on the setting
49 * This test has the same call, task.parseType("List<String>", clazz), but checks
63 task = (JavacTaskImpl)tool.getTask(pw, fm, null, null, null, compilationUnits);
64 elements = task.getElements();
65 types = task.getTypes();
69 toplevels = task.enter(task.parse());
91 DeclaredType type = (DeclaredType)task.parseType("List<String>", clazz);
98 JavacTaskImpl task; field in class:TestResolveError
/openjdk7/jdk/src/share/classes/sun/jvmstat/perfdata/monitor/protocol/local/
H A DLocalMonitoredVm.java57 private NotifierTask task; field in class:LocalMonitoredVm
78 * if the notifier task is running, stop it, otherwise it can
82 if (task != null) {
83 task.cancel();
84 task = null;
96 if (task == null) {
97 task = new NotifierTask();
99 timer.schedule(task, interval, interval);
110 if (listeners.isEmpty() && task != null) {
111 task
[all...]
/openjdk7/jdk/src/share/classes/java/util/
H A DTimer.java37 * Timer tasks should complete quickly. If a timer task takes excessive time
38 * to complete, it "hogs" the timer's task execution thread. This can, in
40 * execute in rapid succession when (and if) the offending task finally
44 * <i>and</i> all outstanding tasks have completed execution, the timer's task
47 * default, the task execution thread does not run as a <i>daemon thread</i>,
49 * wants to terminate a timer's task execution thread rapidly, the caller
52 * <p>If the timer's task execution thread terminates unexpectedly, for
54 * attempt to schedule a task on the timer will result in an
78 * it uses a binary heap to represent its task queue, so the cost to schedule
79 * a task i
190 schedule(TimerTask task, long delay) argument
207 schedule(TimerTask task, Date time) argument
243 schedule(TimerTask task, long delay, long period) argument
284 schedule(TimerTask task, Date firstTime, long period) argument
323 scheduleAtFixedRate(TimerTask task, long delay, long period) argument
366 scheduleAtFixedRate(TimerTask task, Date firstTime, long period) argument
386 sched(TimerTask task, long time, long period) argument
596 add(TimerTask task) argument
[all...]
/openjdk7/langtools/test/tools/javac/api/6423003/
H A DT6423003.java39 task = tool.getTask(null, fm, null, Arrays.asList("-Xlint:all"), null, null);
41 task.call();
/openjdk7/jaxp/src/com/sun/org/apache/xml/internal/utils/
H A DThreadControllerWrapper.java40 public static void waitThread(Thread worker, Runnable task) argument
43 m_tpool.waitThread(worker, task);
84 * Will get a thread from the pool, execute the task
90 * NEEDSDOC @param task
91 * @param priority if >0 the task will run with the given priority
93 * @return The thread that is running the task, can be used
96 public Thread run(Runnable task, int priority) argument
99 Thread t = new SafeThread(task);
109 * Wait until the task is completed on the worker
113 * NEEDSDOC @param task
117 waitThread(Thread worker, Runnable task) argument
[all...]
/openjdk7/jdk/test/java/util/concurrent/ThreadPoolExecutor/
H A DScheduledTickleService.java54 RunnableScheduledFuture<V> task) {
56 return new CustomRunnableScheduledFuture<V>(task) {
57 // delegate to wrapped task, except for:
59 // cancel wrapped task & remove myself from the queue
60 return (task().cancel(b)
135 private RunnableScheduledFuture<V> task; field in class:ScheduledTickleService.CustomRunnableScheduledFuture
137 public CustomRunnableScheduledFuture(RunnableScheduledFuture<V> task) { argument
139 this.task = task;
142 public RunnableScheduledFuture<V> task() { retur method in class:ScheduledTickleService.CustomRunnableScheduledFuture
[all...]
/openjdk7/langtools/test/tools/javac/
H A DT6361619.java65 JavacTask task = tool.getTask(out, fm, dl, flags, null, f);
66 MyTaskListener tl = new MyTaskListener(task);
67 task.setTaskListener(tl);
70 task.call();
79 public MyTaskListener(JavacTask task) { argument
80 this.task = task;
85 Trees t = Trees.instance(task);
89 Trees t = Trees.instance(task);
92 JavacTask task; field in class:T6361619.MyTaskListener
[all...]
/openjdk7/hotspot/src/share/vm/gc_implementation/parallelScavenge/
H A DpsCompactionManager.inline.hpp33 ObjArrayTask task(obj, index);
34 assert(task.is_valid(), "bad ObjArrayTask");
35 _objarray_stack.push(task);
/openjdk7/jdk/test/java/util/Timer/
H A DDelayOverflow.java27 * @summary java.util.Timer schedule delay Long.MAX_VALUE causes task to execute multiple times
40 void scheduleNow(Timer timer, TimerTask task, int how) { argument
43 timer.schedule(task, new Date(), Long.MAX_VALUE);
46 timer.schedule(task, 0L, Long.MAX_VALUE);
49 timer.scheduleAtFixedRate(task, new Date(), Long.MAX_VALUE);
52 timer.scheduleAtFixedRate(task, 0L, Long.MAX_VALUE);
65 void checkScheduledExecutionTime(TimerTask task) { argument
67 - task.scheduledExecutionTime();
76 final TimerTask task = new TimerTask() {
84 scheduleNow(timer, task, ho
[all...]
H A DPurge.java38 TimerTask task = new TimerTask() {
43 timer.schedule(task, i * 60*60*1000); // i hrs. hence.
45 task.cancel();
/openjdk7/jdk/test/java/util/concurrent/ScheduledThreadPoolExecutor/
H A DDecorateTask.java48 final RunnableScheduledFuture<V> task) {
52 task.run();
55 return task.isPeriodic();
58 return task.cancel(mayInterruptIfRunning);
61 return task.isCancelled();
64 return task.isDone();
68 return task.get();
72 return task.get(timeout, unit);
75 return task.getDelay(unit);
78 return task
[all...]

Completed in 68 milliseconds

123456789