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

1234567891011>>

/openjdk10/jdk/src/java.base/share/classes/sun/nio/ch/
H A DCancellable.java38 void onCancel(PendingFuture<?,?> task); argument
/openjdk10/nashorn/test/script/basic/
H A DNASHORN-34.js31 var task = new java.util.TimerTask({
38 task.run();
/openjdk10/jdk/test/java/util/concurrent/FutureTask/
H A DCustomized.java72 static <V> void checkReady(final FutureTask<V> task) { argument
73 check(! task.isDone());
74 check(! task.isCancelled());
76 () -> task.get(0L, TimeUnit.SECONDS));
79 static <V> void checkDone(final FutureTask<V> task) { argument
81 check(task.isDone());
82 check(! task.isCancelled());
83 check(task.get() != null);
87 static <V> void checkCancelled(final FutureTask<V> task) { argument
88 check(task
95 checkThrew(final FutureTask<V> task) argument
103 cancel(FutureTask<V> task, boolean mayInterruptIfRunning) argument
108 run(FutureTask<V> task) argument
[all...]
H A DNegativeTimeout.java41 FutureTask<Void> task = new FutureTask<>( () -> { return null; } );
43 task.get(Long.MIN_VALUE, TimeUnit.NANOSECONDS);
/openjdk10/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
/openjdk10/jdk/test/java/util/concurrent/tck/
H A DFutureTaskTest.java275 * isDone is true when a task completes
278 PublicFutureTask task = new PublicFutureTask(new NoOpCallable());
279 assertFalse(task.isDone());
280 task.run();
281 assertTrue(task.isDone());
282 checkCompletedNormally(task, Boolean.TRUE);
283 assertEquals(1, task.runCount());
287 * runAndReset of a non-cancelled task succeeds
290 PublicFutureTask task = new PublicFutureTask(new NoOpCallable());
292 assertTrue(task
[all...]
/openjdk10/jaxp/src/java.xml/share/classes/com/sun/org/apache/xml/internal/utils/
H A DThreadControllerWrapper.java38 public static void waitThread(Thread worker, Runnable task) argument
40 m_tpool.waitThread(worker, task);
52 * Will get a thread from the pool, execute the task and return the
58 * @param task the Runnable
60 * @param priority if >0 the task will run with the given priority (
62 * @return The thread that is running the task, can be used to wait for
65 public Thread run(Runnable task, int priority) { argument
67 Thread t = new SafeThread(task);
76 * Wait until the task is completed on the worker thread.
79 * @param task th
83 waitThread(Thread worker, Runnable task) argument
[all...]
/openjdk10/jdk/src/java.base/share/classes/java/util/concurrent/
H A DExecutorCompletionService.java112 QueueingFuture(RunnableFuture<V> task, argument
114 super(task, null);
115 this.task = task;
118 private final Future<V> task; field in class:ExecutorCompletionService.QueueingFuture
120 protected void done() { completionQueue.add(task); }
123 private RunnableFuture<V> newTaskFor(Callable<V> task) { argument
125 return new FutureTask<V>(task);
127 return aes.newTaskFor(task);
130 private RunnableFuture<V> newTaskFor(Runnable task, argument
177 submit(Callable<V> task) argument
184 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>
65 * Submits a value-returning task for execution and returns a Future
66 * representing the pending results of the task. Upon completion,
67 * this task may be taken or polled.
69 * @param task the task to submit
70 * @return a Future representing pending completion of the task
71 * @throws RejectedExecutionException if the task cannot be
73 * @throws NullPointerException if the task i
75 submit(Callable<V> task) argument
91 submit(Runnable task, V result) argument
[all...]
/openjdk10/jdk/src/jdk.internal.le/share/classes/jdk/internal/jline/internal/
H A DShutdownHooks.java32 public static synchronized <T extends Task> T add(final T task) { argument
33 checkNotNull(task);
37 Log.debug("Shutdown-hook is disabled; not installing: ", task);
38 return task;
52 // Track the task
53 Log.debug("Adding shutdown-hook task: ", task);
54 tasks.add(task);
56 return task;
63 for (Task task
88 remove(final Task task) argument
[all...]
/openjdk10/hotspot/src/jdk.aot/share/classes/jdk.tools.jaotc/src/jdk/tools/jaotc/
H A DOptions.java138 abstract void process(Main task, String opt, String arg) throws BadArgs; argument
143 void process(Main task, String opt, String arg) {
145 task.options.outputName = name;
149 void process(Main task, String opt, String arg) {
150 task.options.files.addAll(ClassSearch.makeList(ClassNameSourceProvider.TYPE, arg));
154 void process(Main task, String opt, String arg) {
155 task.options.files.addAll(ClassSearch.makeList(JarSourceProvider.TYPE, arg));
159 void process(Main task, String opt, String arg) {
160 task.options.files.addAll(ClassSearch.makeList(ModuleSourceProvider.TYPE, arg));
164 void process(Main task, Strin
251 handleOptions(Main task, String[] args) argument
[all...]
/openjdk10/jdk/src/jdk.internal.jvmstat/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...]
/openjdk10/jdk/src/java.base/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
191 schedule(TimerTask task, long delay) argument
208 schedule(TimerTask task, Date time) argument
244 schedule(TimerTask task, long delay, long period) argument
285 schedule(TimerTask task, Date firstTime, long period) argument
324 scheduleAtFixedRate(TimerTask task, long delay, long period) argument
367 scheduleAtFixedRate(TimerTask task, Date firstTime, long period) argument
387 sched(TimerTask task, long time, long period) argument
597 add(TimerTask task) argument
[all...]
/openjdk10/jdk/test/java/util/concurrent/ThreadPoolExecutor/
H A DScheduledTickleService.java63 RunnableScheduledFuture<V> task) {
65 return new CustomRunnableScheduledFuture<V>(task) {
66 // delegate to wrapped task, except for:
68 // cancel wrapped task & remove myself from the queue
69 return (task().cancel(b)
144 private RunnableScheduledFuture<V> task; field in class:ScheduledTickleService.CustomRunnableScheduledFuture
146 public CustomRunnableScheduledFuture(RunnableScheduledFuture<V> task) { argument
148 this.task = task;
151 public RunnableScheduledFuture<V> task() { retur method in class:ScheduledTickleService.CustomRunnableScheduledFuture
[all...]
/openjdk10/langtools/test/tools/javac/
H A DT6361619.java67 JavacTask task = tool.getTask(out, fm, dl, flags, null, f);
68 MyTaskListener tl = new MyTaskListener(task);
69 task.setTaskListener(tl);
72 task.call();
82 public MyTaskListener(JavacTask task) { argument
83 this.task = task;
88 Trees t = Trees.instance(task);
92 Trees t = Trees.instance(task);
95 JavacTask task; field in class:T6361619.MyTaskListener
[all...]
/openjdk10/hotspot/src/share/vm/gc/parallel/
H A DgcTaskThread.cpp65 log_warning(gc, task, time)("GC-thread %u: Too many timestamps, ignoring future ones. "
90 assert(log_is_enabled(Debug, gc, task, time), "Sanity");
95 log_debug(gc, task, time)("GC-Thread %u entries: %d%s", id(),
101 log_debug(gc, task, time)("\t[ %s " JLONG_FORMAT " " JLONG_FORMAT " ]",
123 log_trace(gc, task, thread)("GCTaskThread::run: binding to processor %u", processor_id());
143 // This will block until there is a task to be gotten.
144 GCTask* task = manager()->get_task(which());
145 GCIdMark gc_id_mark(task->gc_id());
146 // Record if this is an idle task for later use.
147 bool is_idle_task = task
[all...]
/openjdk10/jdk/src/java.base/share/classes/java/util/stream/
H A DAbstractShortCircuitTask.java53 * Indicates whether this task has been canceled. Tasks may cancel other
55 * find-first operation, a task that finds a value will cancel all tasks
77 * @param parent parent task in the computation tree
79 * computation tree described by this task
88 * Returns the value indicating the computation completed with no task
92 * @return the result to return when no task finds a result
106 @SuppressWarnings("unchecked") K task = (K) this;
110 if (task.taskCanceled()) {
111 result = task.getEmptyResult();
115 result = task
[all...]
/openjdk10/langtools/test/tools/javac/api/
H A DT6357331.java44 final JavacTask task = (JavacTask) (tool.getTask(out, fm, null, opts, null, files));
48 task.setTaskListener(new TaskListener() {
50 task.getElements();
51 task.getTypes();
56 task.call();
60 task.getElements();
68 task.getTypes();
H A DTestResolveIdent.java52 JavacTaskImpl task = (JavacTaskImpl)tool.getTask(null, null, null, null, null, null);
53 JavaCompiler compiler = JavaCompiler.instance(task.getContext());
54 Symtab syms = Symtab.instance(task.getContext());
55 task.ensureEntered();
/openjdk10/hotspot/src/share/vm/runtime/
H A DrtmLocking.cpp31 #include "runtime/task.hpp"
42 virtual void task() { function in class:RTMLockingCalculationTask
51 RTMLockingCalculationTask* task = new RTMLockingCalculationTask(RTMLockingCalculationDelay); local
52 task->enroll();
/openjdk10/jdk/test/java/util/Timer/
H A DDelayOverflow.java27 * @summary java.util.Timer schedule delay Long.MAX_VALUE causes task to execute multiple times
41 void scheduleNow(Timer timer, TimerTask task, int how) { argument
44 timer.schedule(task, new Date(), Long.MAX_VALUE);
47 timer.schedule(task, 0L, Long.MAX_VALUE);
50 timer.scheduleAtFixedRate(task, new Date(), Long.MAX_VALUE);
53 timer.scheduleAtFixedRate(task, 0L, Long.MAX_VALUE);
66 void checkScheduledExecutionTime(TimerTask task) { argument
68 - task.scheduledExecutionTime();
77 final TimerTask task = new TimerTask() {
85 scheduleNow(timer, task, ho
[all...]
H A DPurge.java39 TimerTask task = new TimerTask() {
44 timer.schedule(task, i * 60*60*1000); // i hrs. hence.
46 task.cancel();
/openjdk10/langtools/src/jdk.compiler/share/classes/com/sun/source/util/
H A DPlugin.java48 * by the task listener.
60 * Initializes the plug-in for a given compilation task.
61 * @param task The compilation task that has just been started
64 void init(JavacTask task, String... args); argument
/openjdk10/langtools/test/tools/javac/api/6400303/
H A DT6400303.java49 JavacTaskImpl task = (JavacTaskImpl)tool.getTask(null, null, null, null, null, null);
50 Symtab syms = Symtab.instance(task.getContext());
51 task.ensureEntered();
52 JavaCompiler compiler = JavaCompiler.instance(task.getContext());
/openjdk10/langtools/test/tools/javac/T6435291/
H A DT6435291.java47 JavacTaskImpl task = (JavacTaskImpl)tool.getTask(null, null, null, null, null, null);
48 Symtab syms = Symtab.instance(task.getContext());
49 task.ensureEntered();
50 JavaCompiler compiler = JavaCompiler.instance(task.getContext());

Completed in 226 milliseconds

1234567891011>>