Searched refs:executor (Results 1 - 25 of 86) sorted by relevance

1234

/external/glide/library/src/main/java/com/bumptech/glide/load/engine/executor/
H A DPrioritized.java1 package com.bumptech.glide.load.engine.executor;
/external/guava/guava/src/com/google/common/eventbus/
H A DAsyncEventBus.java32 private final Executor executor; field in class:AsyncEventBus
39 * Creates a new AsyncEventBus that will use {@code executor} to dispatch
43 * @param executor Executor to use to dispatch events. It is the caller's
44 * responsibility to shut down the executor after the last event has
47 public AsyncEventBus(String identifier, Executor executor) { argument
49 this.executor = executor;
53 * Creates a new AsyncEventBus that will use {@code executor} to dispatch
56 * @param executor Executor to use to dispatch events. It is the caller's
57 * responsibility to shut down the executor afte
60 AsyncEventBus(Executor executor) argument
[all...]
/external/guava/guava/src/com/google/common/util/concurrent/
H A DExecutionList.java35 * <p>Exceptions thrown by a listener will be propagated up to the executor.
51 // The runnable,executor pairs to execute.
80 public void add(Runnable runnable, Executor executor) { argument
85 Preconditions.checkNotNull(executor, "Executor was null.");
94 runnables.add(new RunnableExecutorPair(runnable, executor));
105 new RunnableExecutorPair(runnable, executor).execute();
140 final Executor executor; field in class:ExecutionList.RunnableExecutorPair
142 RunnableExecutorPair(Runnable runnable, Executor executor) { argument
144 this.executor = executor;
[all...]
H A DAbstractScheduledService.java39 * <p>This class uses the {@link ScheduledExecutorService} returned from {@link #executor} to run
120 public Future<?> schedule(AbstractService service, ScheduledExecutorService executor,
122 return executor.scheduleWithFixedDelay(task, initialDelay, delay, unit);
139 public Future<?> schedule(AbstractService service, ScheduledExecutorService executor,
141 return executor.scheduleAtFixedRate(task, initialDelay, period, unit);
146 /** Schedules the task to run on the provided executor on behalf of the service. */
147 abstract Future<?> schedule(AbstractService service, ScheduledExecutorService executor, argument
186 executorService = executor();
253 * {@link #runOneIteration} and {@link #shutDown} methods. The executor will not be
260 protected ScheduledExecutorService executor() { method in class:AbstractScheduledService
314 private final ScheduledExecutorService executor; field in class:AbstractScheduledService.CustomScheduler.ReschedulableCallable
333 ReschedulableCallable(AbstractService service, ScheduledExecutorService executor, Runnable runnable) argument
393 schedule(AbstractService service, ScheduledExecutorService executor, Runnable runnable) argument
[all...]
H A DListenableFuture.java27 * associated executor, and it is invoked using this executor once the future's
54 * }, executor);}</pre>
85 * the given executor. The listener will run when the {@code Future}'s
93 * <p>Exceptions thrown by a listener will be propagated up to the executor.
117 * @param executor the executor to run the listener in
118 * @throws NullPointerException if the executor or listener was null
120 * immediately but the executor rejected it.
122 void addListener(Runnable listener, Executor executor); argument
[all...]
H A DAbstractIdleService.java28 * which run in a executor which by default uses a separate thread
40 executor(State.STARTING).execute(new Runnable() {
54 executor(State.STOPPING).execute(new Runnable() {
78 * priority. The returned executor's {@link Executor#execute(Runnable)
86 protected Executor executor(final State state) { method in class:AbstractIdleService
H A DMoreExecutors.java60 * @param executor the executor to modify to make sure it exits when the
62 * @param terminationTimeout how long to wait for the executor to
69 ThreadPoolExecutor executor, long terminationTimeout, TimeUnit timeUnit) {
70 executor.setThreadFactory(new ThreadFactoryBuilder()
72 .setThreadFactory(executor.getThreadFactory())
75 ExecutorService service = Executors.unconfigurableExecutorService(executor);
91 * @param executor the executor to modify to make sure it exits when the
93 * @param terminationTimeout how long to wait for the executor t
68 getExitingExecutorService( ThreadPoolExecutor executor, long terminationTimeout, TimeUnit timeUnit) argument
99 getExitingScheduledExecutorService( ScheduledThreadPoolExecutor executor, long terminationTimeout, TimeUnit timeUnit) argument
164 getExitingExecutorService( ThreadPoolExecutor executor) argument
185 getExitingScheduledExecutorService( ScheduledThreadPoolExecutor executor) argument
[all...]
H A DSimpleTimeLimiter.java50 private final ExecutorService executor; field in class:SimpleTimeLimiter
53 * Constructs a TimeLimiter instance using the given executor service to
56 * <b>Warning:</b> using a bounded executor
62 * @param executor the ExecutorService that will execute the method calls on
66 public SimpleTimeLimiter(ExecutorService executor) { argument
67 this.executor = checkNotNull(executor);
74 * <p><b>Warning:</b> using a bounded executor may be counterproductive! If
126 Future<T> future = executor.submit(callable);
/external/chromium_org/components/cronet/android/java/src/org/chromium/net/
H A DCronetUrlRequestFactory.java15 Executor executor) {
14 createRequest(String url, UrlRequestListener listener, Executor executor) argument
H A DUrlRequestFactory.java21 * @param executor Executor on which all callbacks will be called.
25 UrlRequestListener listener, Executor executor);
24 createRequest(String url, UrlRequestListener listener, Executor executor) argument
/external/okhttp/benchmarks/src/main/java/com/squareup/okhttp/benchmarks/
H A DSynchronousHttpClient.java27 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;
/external/guava/guava-tests/test/com/google/common/util/concurrent/
H A DMoreExecutorsTest.java49 final ListeningExecutorService executor =
72 Future<?> future = executor.submit(incrementTask);
83 ListenableFuture<?> future = executor.submit(incrementTask);
96 final ExecutorService executor = MoreExecutors.sameThreadExecutor();
114 executor.invokeAll(Collections.nCopies(10, incrementTask));
127 final ExecutorService executor = MoreExecutors.sameThreadExecutor();
139 Future<?> future = executor.submit(new Callable<Void>() {
147 assertTrue(executor.isShutdown());
148 assertFalse(executor.isTerminated());
156 assertTrue(executor
[all...]
H A DAbstractIdleServiceTest.java36 private final Executor executor = new Executor() { field in class:AbstractIdleServiceTest
76 // Create a service whose executor will never run its commands
78 @Override protected Executor executor(Service.State state) {
113 @Override protected Executor executor(Service.State state) { method in class:AbstractIdleServiceTest.NullService
117 return executor;
121 return executor;
H A DAbstractExecutionThreadServiceTest.java43 private final Executor executor = new Executor() { field in class:AbstractExecutionThreadServiceTest
163 @Override protected Executor executor() { method in class:AbstractExecutionThreadServiceTest.WaitOnRunService
164 return executor;
198 @Override protected Executor executor() { method in class:AbstractExecutionThreadServiceTest.ThrowOnStartUpService
199 return executor;
241 @Override protected Executor executor() { method in class:AbstractExecutionThreadServiceTest.ThrowOnRunService
242 return executor;
273 @Override protected Executor executor() { method in class:AbstractExecutionThreadServiceTest.ThrowOnShutDown
274 return executor;
290 @Override protected Executor executor() { method in class:AbstractExecutionThreadServiceTest.TimeoutOnStartUp
[all...]
H A DAbstractFutureTest.java94 ExecutorService executor = Executors.newFixedThreadPool(10);
98 executor.execute(new Runnable() {
107 executor.execute(new Runnable() {
116 executor.execute(new Runnable() {
133 executor.shutdown();
/external/guava/guava/src/com/google/common/cache/
H A DRemovalListeners.java36 * notifications using {@code executor}.
39 * @param executor the executor with which removal notifications are
43 final RemovalListener<K, V> listener, final Executor executor) {
47 executor.execute(new Runnable() {
42 asynchronous( final RemovalListener<K, V> listener, final Executor executor) argument
/external/okhttp/okhttp-tests/src/test/java/com/squareup/okhttp/
H A DDispatcherTest.java16 RecordingExecutor executor = new RecordingExecutor(); field in class:DispatcherTest
18 Dispatcher dispatcher = new Dispatcher(executor);
44 executor.assertJobs("http://a/1");
53 executor.assertJobs("http://a/1", "http://a/2", "http://b/1");
61 executor.assertJobs("http://a/1", "http://a/2");
72 executor.assertJobs("http://a/1", "http://b/1", "http://c/1", "http://a/2");
83 executor.assertJobs("http://a/1", "http://a/2", "http://a/3", "http://a/4");
90 executor.finishJob("http://a/1");
91 executor.assertJobs("http://b/1");
101 executor
[all...]
/external/deqp/modules/glshared/
H A DglsShaderExecUtil.hpp69 //! Base class for shader executor.
75 //! Check if executor can be used.
78 //! Log executor details (program etc.).
99 inline tcu::TestLog& operator<< (tcu::TestLog& log, const ShaderExecutor* executor) { executor->log(log); return log; } argument
100 inline tcu::TestLog& operator<< (tcu::TestLog& log, const ShaderExecutor& executor) { executor.log(log); return log; } argument
/external/guava/guava-tests/test/com/google/common/eventbus/
H A DAsyncEventBusTest.java32 /** The executor we use to fake asynchronicity. */
33 private FakeExecutor executor; field in class:AsyncEventBusTest
38 executor = new FakeExecutor();
39 bus = new AsyncEventBus(executor);
54 List<Runnable> tasks = executor.getTasks();
/external/chromium_org/net/proxy/
H A Dmulti_threaded_proxy_resolver.cc24 // An "executor" is a job-runner for PAC requests. It encapsulates a worker
31 // signal when the executor is ready to receive work by calling
39 // Submit a job to this executor.
42 // Callback for when a job has completed running on the executor's thread.
45 // Cleanup the executor. Cancels all outstanding work, and frees the thread
63 // The currently active job for this executor (either a SetPacScript or
96 void set_executor(Executor* executor) { argument
97 executor_ = executor;
100 // The "executor" is the job runner that is scheduling this job. If
101 // this job has not been submitted to an executor ye
103 Executor* executor() { function in class:net::MultiThreadedProxyResolver::Job
389 Executor* executor = FindIdleExecutor(); local
470 Executor* executor = AddNewExecutor(); local
481 const Executor* executor = it->get(); local
497 Executor* executor = it->get(); local
508 Executor* executor = it->get(); local
522 Executor* executor = new Executor( local
528 OnExecutorReady(Executor* executor) argument
[all...]
/external/deqp/executor/
H A DxeBatchExecutor.cpp21 * \brief Test batch executor.
346 BatchExecutor* executor = static_cast<BatchExecutor*>(userPtr); local
347 CallWriter writer (&executor->m_dispatcher, BatchExecutor::dispatchStateChanged);
349 writer << executor
358 BatchExecutor* executor = static_cast<BatchExecutor*>(userPtr); local
359 CallWriter writer (&executor->m_dispatcher, BatchExecutor::dispatchTestLogData);
361 writer << executor
370 BatchExecutor* executor = static_cast<BatchExecutor*>(userPtr); local
371 CallWriter writer (&executor->m_dispatcher, BatchExecutor::dispatchInfoLogData);
373 writer << executor
382 BatchExecutor* executor = DE_NULL; local
395 BatchExecutor* executor = DE_NULL; local
406 BatchExecutor* executor = DE_NULL; local
[all...]
/external/chromium_org/tools/gyp/pylib/gyp/
H A Dflock_tool.py17 executor = FlockTool()
18 executor.Dispatch(args)
/external/chromium_org/mojo/public/java/bindings/src/org/chromium/mojo/bindings/
H A DExecutorFactory.java34 * Implementation of the executor which uses a pair of {@link MessagePipeHandle} for signaling.
35 * The executor will wait asynchronously on one end of a {@link MessagePipeHandle} on the thread
37 * executor will queue the {@link Runnable} and write a message on the other end of the handle.
38 * This will wake up the executor which is waiting on the handle, which will then dequeue the
81 * executor thread.
109 * Close the handles. Should only be called on the executor thread.
149 * Execute the given |command| in the executor thread. This can be called on any thread.
156 // from the executor's thread.
160 "Trying to execute an action on a closed executor.");
169 * Keep one executor pe
[all...]
/external/deqp/framework/randomshaders/
H A DrsgTest.cpp68 rsg::ProgramExecutor executor(surface.getAccess(), 3, 5);
70 executor.execute(vertexShader, fragmentShader, uniformValues);
/external/chromium_org/third_party/WebKit/Source/devtools/scripts/jsdoc-validator/src/org/chromium/devtools/jsdoc/
H A DJsDocValidator.java22 ExecutorService executor = Executors.newFixedThreadPool(threadCount);
24 runWithExecutor(args, executor);
26 executor.shutdown();
30 private void runWithExecutor(String[] args, ExecutorService executor) { argument
34 Future<ValidatorContext> future = executor.submit(new FileCheckerCallable(fileName));

Completed in 1268 milliseconds

1234