/libcore/jsr166-tests/src/test/java/jsr166/ |
D | FutureTaskTest.java | 259 PublicFutureTask task = new PublicFutureTask(new NoOpCallable()); in testIsDone() local 260 assertFalse(task.isDone()); in testIsDone() 261 task.run(); in testIsDone() 262 assertTrue(task.isDone()); in testIsDone() 263 checkCompletedNormally(task, Boolean.TRUE); in testIsDone() 264 assertEquals(1, task.runCount()); in testIsDone() 271 PublicFutureTask task = new PublicFutureTask(new NoOpCallable()); in testRunAndReset() local 273 assertTrue(task.runAndReset()); in testRunAndReset() 274 checkNotDone(task); in testRunAndReset() 275 assertEquals(i + 1, task.runCount()); in testRunAndReset() [all …]
|
D | ScheduledExecutorSubclassTest.java | 53 RunnableScheduledFuture<V> task; field in ScheduledExecutorSubclassTest.CustomTask 55 CustomTask(RunnableScheduledFuture<V> t) { task = t; } in CustomTask() 56 public boolean isPeriodic() { return task.isPeriodic(); } in isPeriodic() 59 task.run(); in run() 61 public long getDelay(TimeUnit unit) { return task.getDelay(unit); } in getDelay() 63 return task.compareTo(((CustomTask)t).task); in compareTo() 66 return task.cancel(mayInterruptIfRunning); in cancel() 68 public boolean isCancelled() { return task.isCancelled(); } in isCancelled() 69 public boolean isDone() { return task.isDone(); } in isDone() 71 V v = task.get(); in get() [all …]
|
D | ScheduledExecutorTest.java | 56 final Runnable task = new CheckedRunnable() { in testExecute() local 58 p.execute(task); in testExecute() 71 Callable task = new CheckedCallable<Boolean>() { in testSchedule1() local 77 Future f = p.schedule(task, timeoutMillis(), MILLISECONDS); in testSchedule1() 92 Runnable task = new CheckedRunnable() { in testSchedule3() local 97 Future f = p.schedule(task, timeoutMillis(), MILLISECONDS); in testSchedule3() 112 Runnable task = new CheckedRunnable() { in testSchedule4() local 118 p.scheduleAtFixedRate(task, timeoutMillis(), in testSchedule4() 134 Runnable task = new CheckedRunnable() { in testSchedule5() local 140 p.scheduleWithFixedDelay(task, timeoutMillis(), in testSchedule5() [all …]
|
D | ExecutorsTest.java | 206 final Runnable task = new CheckedRunnable() { in testNewSingleThreadScheduledExecutor() local 211 Future f = p.schedule(Executors.callable(task, Boolean.TRUE), in testNewSingleThreadScheduledExecutor() 230 final Runnable task = new CheckedRunnable() { in testNewScheduledThreadPool() local 235 Future f = p.schedule(Executors.callable(task, Boolean.TRUE), in testNewScheduledThreadPool() 256 final Runnable task = new CheckedRunnable() { in testUnconfigurableScheduledExecutorService() local 261 Future f = p.schedule(Executors.callable(task, Boolean.TRUE), in testUnconfigurableScheduledExecutorService() 453 Callable task = Executors.privilegedCallable(new CheckCCL()); in testPrivilegedCallableWithNoPrivs() 455 task.call(); in testPrivilegedCallableWithNoPrivs()
|
/libcore/ojluni/src/main/java/java/util/concurrent/ |
D | ExecutorCompletionService.java | 115 QueueingFuture(RunnableFuture<V> task, in QueueingFuture() argument 117 super(task, null); in QueueingFuture() 118 this.task = task; in QueueingFuture() 121 private final Future<V> task; field in ExecutorCompletionService.QueueingFuture 123 protected void done() { completionQueue.add(task); } in done() 126 private RunnableFuture<V> newTaskFor(Callable<V> task) { in newTaskFor() argument 128 return new FutureTask<V>(task); in newTaskFor() 130 return aes.newTaskFor(task); in newTaskFor() 133 private RunnableFuture<V> newTaskFor(Runnable task, V result) { in newTaskFor() argument 135 return new FutureTask<V>(task, result); in newTaskFor() [all …]
|
D | Executors.java | 378 public static <T> Callable<T> callable(Runnable task, T result) { in callable() argument 379 if (task == null) in callable() 381 return new RunnableAdapter<T>(task, result); in callable() 391 public static Callable<Object> callable(Runnable task) { in callable() argument 392 if (task == null) in callable() 394 return new RunnableAdapter<Object>(task, null); in callable() 450 private final Runnable task; 452 RunnableAdapter(Runnable task, T result) { 453 this.task = task; 457 task.run(); [all …]
|
D | ForkJoinPool.java | 867 final void push(ForkJoinTask<?> task) { in push() argument 871 a[(al - 1) & s] = task; // relaxed writes OK in push() 1001 final boolean tryUnpush(ForkJoinTask<?> task) { in tryUnpush() argument 1006 if (U.compareAndSwapObject(a, offset, task, null)) { in tryUnpush() 1019 final int sharedPush(ForkJoinTask<?> task) { in sharedPush() argument 1025 a[(al - 1) & s] = task; in sharedPush() 1031 growAndSharedPush(task); in sharedPush() 1044 private void growAndSharedPush(ForkJoinTask<?> task) { in growAndSharedPush() argument 1049 a[(al - 1) & s] = task; in growAndSharedPush() 1060 final boolean trySharedUnpush(ForkJoinTask<?> task) { in trySharedUnpush() argument [all …]
|
D | AbstractExecutorService.java | 115 public Future<?> submit(Runnable task) { in submit() argument 116 if (task == null) throw new NullPointerException(); in submit() 117 RunnableFuture<Void> ftask = newTaskFor(task, null); in submit() 126 public <T> Future<T> submit(Runnable task, T result) { in submit() argument 127 if (task == null) throw new NullPointerException(); in submit() 128 RunnableFuture<T> ftask = newTaskFor(task, result); in submit() 137 public <T> Future<T> submit(Callable<T> task) { in submit() argument 138 if (task == null) throw new NullPointerException(); in submit() 139 RunnableFuture<T> ftask = newTaskFor(task); in submit()
|
D | ScheduledThreadPoolExecutor.java | 332 private void delayedExecute(RunnableScheduledFuture<?> task) { in delayedExecute() argument 334 reject(task); in delayedExecute() 336 super.getQueue().add(task); in delayedExecute() 338 !canRunInCurrentRunState(task.isPeriodic()) && in delayedExecute() 339 remove(task)) in delayedExecute() 340 task.cancel(false); in delayedExecute() 352 void reExecutePeriodic(RunnableScheduledFuture<?> task) { in reExecutePeriodic() argument 354 super.getQueue().add(task); in reExecutePeriodic() 355 if (!canRunInCurrentRunState(true) && remove(task)) in reExecutePeriodic() 356 task.cancel(false); in reExecutePeriodic() [all …]
|
D | ExecutorService.java | 226 <T> Future<T> submit(Callable<T> task); in submit() argument 241 <T> Future<T> submit(Runnable task, T result); in submit() argument 254 Future<?> submit(Runnable task); in submit() argument
|
D | CompletionService.java | 73 Future<V> submit(Callable<V> task); in submit() argument 89 Future<V> submit(Runnable task, V result); in submit() argument
|
D | ThreadPoolExecutor.java | 1142 Runnable task = w.firstTask; in runWorker() local 1147 while (task != null || (task = getTask()) != null) { in runWorker() 1159 beforeExecute(wt, task); in runWorker() 1162 task.run(); in runWorker() 1170 afterExecute(task, thrown); in runWorker() 1173 task = null; in runWorker() 1778 public boolean remove(Runnable task) { in remove() argument 1779 boolean removed = workQueue.remove(task); in remove()
|
/libcore/ojluni/src/main/java/java/util/ |
D | Timer.java | 190 public void schedule(TimerTask task, long delay) { in schedule() argument 193 sched(task, System.currentTimeMillis()+delay, 0); in schedule() 207 public void schedule(TimerTask task, Date time) { in schedule() argument 208 sched(task, time.getTime(), 0); in schedule() 243 public void schedule(TimerTask task, long delay, long period) { in schedule() argument 248 sched(task, System.currentTimeMillis()+delay, -period); in schedule() 284 public void schedule(TimerTask task, Date firstTime, long period) { in schedule() argument 287 sched(task, firstTime.getTime(), -period); in schedule() 323 public void scheduleAtFixedRate(TimerTask task, long delay, long period) { in scheduleAtFixedRate() argument 328 sched(task, System.currentTimeMillis()+delay, period); in scheduleAtFixedRate() [all …]
|
/libcore/ojluni/src/main/java/sun/nio/ch/ |
D | AsynchronousChannelGroupImpl.java | 107 private Runnable bindToGroup(final Runnable task) { in bindToGroup() argument 112 task.run(); in bindToGroup() 117 private void startInternalThread(final Runnable task) { 123 ThreadPool.defaultThreadFactory().newThread(task).start(); 129 protected final void startThreads(Runnable task) { 132 startInternalThread(task); 137 task = bindToGroup(task); 140 pool.executor().execute(task); 156 final int threadExit(Runnable task, boolean replaceMe) { 161 pool.executor().execute(bindToGroup(task)); [all …]
|
D | EPollPort.java | 144 void executeOnHandlerTask(Runnable task) { in executeOnHandlerTask() argument 148 offerTask(task); in executeOnHandlerTask() 280 Runnable task = pollTask(); in run() local 281 if (task == null) { in run() 287 task.run(); in run()
|
D | SimpleAsynchronousFileChannelImpl.java | 196 Runnable task = new Runnable() { in implLock() local 231 executor.execute(task); in implLock() 311 Runnable task = new Runnable() { in implRead() local 339 executor.execute(task); in implRead() 365 Runnable task = new Runnable() { in implWrite() local 393 executor.execute(task); in implWrite()
|
D | PendingFuture.java | 107 void setTimeoutTask(Future<?> task) { in setTimeoutTask() argument 110 task.cancel(false); in setTimeoutTask() 112 this.timeoutTask = task; in setTimeoutTask()
|
D | Cancellable.java | 38 void onCancel(PendingFuture<?,?> task); in onCancel() argument
|
D | Invoker.java | 253 Runnable task) in invokeOnThreadInThreadPool() argument 265 task.run(); in invokeOnThreadInThreadPool() 267 targetGroup.executeOnPooledThread(task); in invokeOnThreadInThreadPool()
|
/libcore/ojluni/src/main/java/java/util/stream/ |
D | ForEachOps.java | 287 ForEachTask<S, T> task = this; in compute() local 291 task.helper.copyInto(taskSink, rightSplit); in compute() 294 ForEachTask<S, T> leftTask = new ForEachTask<>(task, leftSplit); in compute() 295 task.addToPendingCount(1); in compute() 300 taskToFork = task; in compute() 301 task = leftTask; in compute() 310 task.spliterator = null; in compute() 311 task.propagateCompletion(); in compute() 403 private static <S, T> void doCompute(ForEachOrderedTask<S, T> task) { in doCompute() argument 404 Spliterator<S> rightSplit = task.spliterator, leftSplit; in doCompute() [all …]
|
D | AbstractShortCircuitTask.java | 106 @SuppressWarnings("unchecked") K task = (K) this; in compute() local 110 if (task.taskCanceled()) { in compute() 111 result = task.getEmptyResult(); in compute() 115 result = task.doLeaf(); in compute() 119 task.leftChild = leftChild = task.makeChild(ls); in compute() 120 task.rightChild = rightChild = task.makeChild(rs); in compute() 121 task.setPendingCount(1); in compute() 125 task = leftChild; in compute() 130 task = rightChild; in compute() 136 task.setLocalResult(result); in compute() [all …]
|
D | AbstractTask.java | 296 @SuppressWarnings("unchecked") K task = (K) this; in compute() local 299 task.leftChild = leftChild = task.makeChild(ls); in compute() 300 task.rightChild = rightChild = task.makeChild(rs); in compute() 301 task.setPendingCount(1); in compute() 305 task = leftChild; in compute() 310 task = rightChild; in compute() 316 task.setLocalResult(task.doLeaf()); in compute() 317 task.tryComplete(); in compute()
|
D | Nodes.java | 1864 SizedCollectorTask<P_IN, P_OUT, T_SINK, K> task = this; 1866 while (rightSplit.estimateSize() > task.targetSize && 1868 task.setPendingCount(1); 1870 task.makeChild(leftSplit, task.offset, leftSplitSize).fork(); 1871 task = task.makeChild(rightSplit, task.offset + leftSplitSize, 1872 task.length - leftSplitSize); 1875 assert task.offset + task.length < MAX_ARRAY_SIZE; 1877 T_SINK sink = (T_SINK) task; 1878 task.helper.wrapAndCopyInto(sink, rightSplit); 1879 task.propagateCompletion(); [all …]
|
/libcore/luni/src/test/java/tests/support/ |
D | ThreadPool.java | 44 public synchronized void runTask(Runnable task) { in runTask() argument 48 if (task != null) { in runTask() 49 taskQueue.add(task); in runTask() 99 Runnable task = null; in run() local 101 task = getTask(); in run() 106 if (task == null) { in run() 112 task.run(); in run()
|
/libcore/ojluni/src/main/java/sun/nio/fs/ |
D | Cancellable.java | 119 static void runInterruptibly(Cancellable task) throws ExecutionException { in runInterruptibly() argument 120 Thread t = new Thread(task); in runInterruptibly() 128 task.cancel(); in runInterruptibly() 133 Throwable exc = task.exception(); in runInterruptibly()
|