| /external/guava/guava/src/com/google/common/util/concurrent/ |
| ListenerCallQueue.java | 25 import java.util.concurrent.Executor; 32 * A special purpose queue/executor that executes listener callbacks serially on a configured 33 * executor. Each callback task can be enqueued and executed as separate phases. 60 private final Executor executor; field in class:ListenerCallQueue 65 ListenerCallQueue(L listener, Executor executor) { 67 this.executor = checkNotNull(executor); 86 executor.execute(this) [all...] |
| AbstractExecutionThreadService.java | 23 import java.util.concurrent.Executor; 46 Executor executor = MoreExecutors.renamingDecorator(executor(), new Supplier<String>() { 51 executor.execute(new Runnable() { 132 * Returns the {@link Executor} that will be used to run this service. 133 * Subclasses may override this method to use a custom {@link Executor}, which 135 * priority. The returned executor's {@link Executor#execute(Runnable) 139 * <p>The default implementation returns a new {@link Executor} that sets the 142 protected Executor executor() { method in class:AbstractExecutionThreadService [all...] |
| AbstractIdleService.java | 23 import java.util.concurrent.Executor; 31 * which run in a executor which by default uses a separate thread 50 MoreExecutors.renamingDecorator(executor(), threadNameSupplier) 65 MoreExecutors.renamingDecorator(executor(), threadNameSupplier) 90 * Returns the {@link Executor} that will be used to run this service. 91 * Subclasses may override this method to use a custom {@link Executor}, which 93 * priority. The returned executor's {@link Executor#execute(Runnable) 97 protected Executor executor() { method in class:AbstractIdleService [all...] |
| /external/guava/guava-tests/test/com/google/common/cache/ |
| CacheLoaderTest.java | 29 import java.util.concurrent.Executor; 39 private static class QueuingExecutor implements Executor { 88 QueuingExecutor executor = new QueuingExecutor(); local 90 CacheLoader.asyncReloading(baseLoader, executor); 99 executor.runNext();
|
| /libcore/luni/src/test/java/tests/security/ |
| SecureRandomTest.java | 79 ExecutorService executor = Executors.newFixedThreadPool(threads); local 80 ExecutorCompletionService ecs = new ExecutorCompletionService(executor); 91 executor.shutdown();
|
| /libcore/support/src/test/java/libcore/javax/net/ssl/ |
| TestSSLSocketPair.java | 79 ExecutorService executor = Executors.newFixedThreadPool(2); local 80 Future s = executor.submit(new Callable<Void>() { 89 Future c = executor.submit(new Callable<Void>() { 98 executor.shutdown();
|
| /packages/providers/CalendarProvider/src/com/android/providers/calendar/ |
| CalendarReceiver.java | 39 private final ExecutorService executor = Executors.newCachedThreadPool(); field in class:CalendarReceiver 54 executor.submit(new Runnable() {
|
| /external/guava/guava-tests/benchmark/com/google/common/util/concurrent/ |
| FuturesCombineBenchmark.java | 29 import java.util.concurrent.Executor; 39 @Override <V> ListenableFuture<V> combine(final Callable<V> combiner, Executor executor, 54 }, executor); field in class:FuturesCombineBenchmark 59 <V> ListenableFuture<V> combine(Callable<V> combiner, final Executor executor, 61 return Futures.combine(combiner, executor, futures); 66 Callable<V> combiner, Executor executor, 70 private static final Executor INLINE_EXECUTOR = new Executor() [all...] |
| /external/mockito/src/test/java/org/mockitousage/bugs/ |
| MultithreadedStubbingHalfManualTest.java | 13 import java.util.concurrent.Executor; 37 private Executor executor; field in class:MultithreadedStubbingHalfManualTest 43 this.executor = Executors.newSingleThreadExecutor(); 85 this.executor.execute(getConflictingRunnable(toMock));
|
| /external/okhttp/benchmarks/src/main/java/com/squareup/okhttp/benchmarks/ |
| SynchronousHttpClient.java | 27 ThreadPoolExecutor executor; field in class:SynchronousHttpClient 32 executor = new ThreadPoolExecutor(benchmark.concurrencyLevel, benchmark.concurrencyLevel, 37 executor.execute(request(url)); 41 return executor.getQueue().size() < targetBacklog;
|
| /libcore/harmony-tests/src/test/java/org/apache/harmony/tests/java/io/ |
| OutputStreamTesterTest.java | 116 private ExecutorService executor; field in class:OutputStreamTesterTest.PipedOutputStreamSinkTester 123 executor = Executors.newSingleThreadExecutor(); 124 future = executor.submit(new Callable<byte[]>() { 141 executor.shutdown();
|
| WriterTesterTest.java | 109 private ExecutorService executor; field in class:WriterTesterTest.PipedWriterCharSinkTester 116 executor = Executors.newSingleThreadExecutor(); 117 future = executor.submit(new Callable<char[]>() { 135 executor.shutdown();
|
| /packages/apps/DocumentsUI/src/com/android/documentsui/ |
| ProviderExecutor.java | 26 import java.util.concurrent.Executor; 29 public class ProviderExecutor extends Thread implements Executor { 36 ProviderExecutor executor = sExecutors.get(authority); local 37 if (executor == null) { 38 executor = new ProviderExecutor(); 39 executor.setName("ProviderExecutor: " + authority); 40 executor.start(); 41 sExecutors.put(authority, executor); 43 return executor; 84 private Executor mNonPreemptingExecutor = new Executor() [all...] |
| /external/guava/guava-tests/test/com/google/common/eventbus/ |
| AsyncEventBusTest.java | 24 import java.util.concurrent.Executor; 34 /** The executor we use to fake asynchronicity. */ 35 private FakeExecutor executor; field in class:AsyncEventBusTest 40 executor = new FakeExecutor(); 41 bus = new AsyncEventBus(executor); 48 // We post the event, but our Executor will not deliver it until instructed. 55 // Now we find the task in our Executor and explicitly activate it. 56 List<Runnable> tasks = executor.getTasks(); 66 * An {@link Executor} wanna-be that simply records the tasks it's given. 67 * Arguably the Worst Executor Ever [all...] |
| /external/webrtc/webrtc/examples/androidapp/src/org/appspot/apprtc/ |
| WebSocketRTCClient.java | 50 private final LooperExecutor executor; field in class:WebSocketRTCClient 59 public WebSocketRTCClient(SignalingEvents events, LooperExecutor executor) { 61 this.executor = executor; 63 executor.requestStart(); 73 executor.execute(new Runnable() { 83 executor.execute(new Runnable() { 89 executor.requestStop(); 97 wsClient = new WebSocketChannelClient(executor, this); 103 WebSocketRTCClient.this.executor.execute(new Runnable() [all...] |
| /libcore/ojluni/src/main/java/sun/nio/ch/ |
| AsynchronousChannelGroupImpl.java | 47 extends AsynchronousChannelGroup implements Executor 60 // associated Executor for timeouts 91 final ExecutorService executor() { method in class:AsynchronousChannelGroupImpl 92 return pool.executor(); 140 pool.executor().execute(task); 161 pool.executor().execute(bindToGroup(task)); 188 pool.executor().execute(bindToGroup(task)); 219 return pool.executor().isTerminated(); 251 pool.executor().shutdown(); 309 return pool.executor().awaitTermination(timeout, unit) [all...] |
| /external/conscrypt/openjdk-benchmarks/src/jmh/java/org/conscrypt/benchmarks/ |
| ClientSocketThroughputBenchmark.java | 137 private ExecutorService executor; field in class:ClientSocketThroughputBenchmark 167 executor = Executors.newSingleThreadExecutor(); 168 executor.submit(new Runnable() { 184 executor.shutdown(); 185 executor.awaitTermination(5, TimeUnit.SECONDS);
|
| ServerSocketThroughputBenchmark.java | 112 private ExecutorService executor; field in class:ServerSocketThroughputBenchmark 159 executor = Executors.newSingleThreadExecutor(); 160 executor.submit(new Runnable() { 183 executor.shutdown(); 184 executor.awaitTermination(5, TimeUnit.SECONDS);
|
| /external/conscrypt/testing/src/main/java/org/conscrypt/testing/ |
| TestServer.java | 57 private ExecutorService executor; field in class:TestServer 74 executor = Executors.newSingleThreadExecutor(); 75 return executor.submit(new AcceptTask()); 88 if (executor != null) { 89 executor.shutdown(); 90 executor.awaitTermination(5, TimeUnit.SECONDS); 91 executor = null; 116 executor.execute(new ProcessTask());
|
| /external/guava/guava-tests/test/com/google/common/util/concurrent/ |
| AbstractFutureTest.java | 109 ExecutorService executor = Executors.newFixedThreadPool(10); local 113 executor.execute(new Runnable() { 122 executor.execute(new Runnable() { 131 executor.execute(new Runnable() { 148 executor.shutdown();
|
| /external/okhttp/okhttp-tests/src/test/java/com/squareup/okhttp/ |
| SocksProxy.java | 56 private final ExecutorService executor = Executors.newCachedThreadPool( field in class:SocksProxy 64 executor.execute(new NamedRunnable("SocksProxy %s", serverSocket.getLocalPort()) { 92 executor.shutdown(); 93 if (!executor.awaitTermination(5, TimeUnit.SECONDS)) { 94 throw new IOException("Gave up waiting for executor to shut down"); 99 executor.execute(new NamedRunnable("SocksProxy %s", from.getRemoteSocketAddress()) { 206 executor.execute(new NamedRunnable("SocksProxy %s to %s", fromAddress, toAddress) {
|
| /external/smali/baksmali/src/main/java/org/jf/baksmali/ |
| baksmali.java | 143 ExecutorService executor = Executors.newFixedThreadPool(options.jobs); local 147 tasks.add(executor.submit(new Callable<Boolean>() { 171 executor.shutdown();
|
| /external/caliper/caliper/src/main/java/com/google/caliper/runner/ |
| ExperimentingCaliperRun.java | 155 final ListeningExecutorService executor = executorProvider.get(); local 156 List<ListenableFuture<TrialResult>> pendingTrials = scheduleTrials(trials, executor); 186 executor.shutdown(); 203 * scheduling criteria. The executor instance is responsible for enforcing max parallelism. 206 final ListeningExecutorService executor) { 211 pendingTrials.add(executor.submit(scheduledTrial.trialTask())); 227 return executor.submit(scheduledTrial.trialTask());
|
| /external/dagger2/core/src/test/java/dagger/internal/ |
| DoubleCheckLazyTest.java | 43 ExecutorService executor = Executors.newFixedThreadPool(numThreads); local 59 List<Future<Object>> futures = executor.invokeAll(tasks);
|
| /external/glide/library/src/main/java/com/bumptech/glide/load/engine/executor/ |
| FifoPriorityThreadPoolExecutor.java | 1 package com.bumptech.glide.load.engine.executor; 22 * {@link com.bumptech.glide.load.engine.executor.FifoPriorityThreadPoolExecutor.DefaultThreadFactory}.
|