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

12345678910

/external/tensorflow/tensorflow/core/kernels/hexagon/
H A Dhexagon_remote_fused_graph_executor_build_test.cc25 std::unique_ptr<IRemoteFusedGraphExecutor>* executor);
30 std::unique_ptr<IRemoteFusedGraphExecutor> executor; local
31 ASSERT_FALSE(static_cast<bool>(executor));
32 TF_ASSERT_OK(BuildRemoteFusedGraphExecutor(&executor));
33 ASSERT_TRUE(static_cast<bool>(executor));
H A Dhexagon_remote_fused_graph_executor_build.cc23 std::unique_ptr<IRemoteFusedGraphExecutor>* executor) {
24 executor->reset(new HexagonControlWrapper());
22 BuildRemoteFusedGraphExecutor( std::unique_ptr<IRemoteFusedGraphExecutor>* executor) argument
/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.java35 private final Executor executor; field in class:AsyncEventBus
42 * Creates a new AsyncEventBus that will use {@code executor} to dispatch
46 * @param executor Executor to use to dispatch events. It is the caller's
47 * responsibility to shut down the executor after the last event has
50 public AsyncEventBus(String identifier, Executor executor) { argument
52 this.executor = checkNotNull(executor);
56 * Creates a new AsyncEventBus that will use {@code executor} to dispatch
59 * @param executor Executor to use to dispatch events. It is the caller's
60 * responsibility to shut down the executor afte
66 AsyncEventBus(Executor executor, SubscriberExceptionHandler subscriberExceptionHandler) argument
79 AsyncEventBus(Executor executor) argument
[all...]
/external/guava/guava/src/com/google/common/util/concurrent/
H A DExecutionList.java37 * <p>Exceptions thrown by a listener will be propagated up to the executor.
52 * The runnable, executor pairs to execute. This acts as a stack threaded through the
81 public void add(Runnable runnable, Executor executor) { argument
86 Preconditions.checkNotNull(executor, "Executor was null.");
93 runnables = new RunnableExecutorPair(runnable, executor, runnables);
101 executeListener(runnable, executor);
145 executeListener(reversedList.runnable, reversedList.executor);
152 * {@linkplain RuntimeException runtime exceptions} thrown by the executor.
154 private static void executeListener(Runnable runnable, Executor executor) { argument
156 executor
168 final Executor executor; field in class:ExecutionList.RunnableExecutorPair
171 RunnableExecutorPair(Runnable runnable, Executor executor, RunnableExecutorPair next) argument
[all...]
H A DSerializingExecutor.java34 * TODO(user): The tasks are given to the underlying executor as a single
35 * task, which means the semantics of the executor may be changed, e.g. the
36 * executor may have an afterExecute method that runs after every task
50 /** Underlying executor that all submitted Runnable objects are run on. */
51 private final Executor executor; field in class:SerializingExecutor
72 * Creates a SerializingExecutor, running tasks using {@code executor}.
74 * @param executor Executor in which tasks should be run. Must not be null.
76 public SerializingExecutor(Executor executor) { argument
77 Preconditions.checkNotNull(executor, "'executor' mus
[all...]
H A DAbstractScheduledService.java45 * <p>This class uses the {@link ScheduledExecutorService} returned from {@link #executor} to run
125 public Future<?> schedule(AbstractService service, ScheduledExecutorService executor,
127 return executor.scheduleWithFixedDelay(task, initialDelay, delay, unit);
144 public Future<?> schedule(AbstractService service, ScheduledExecutorService executor,
146 return executor.scheduleAtFixedRate(task, initialDelay, period, unit);
151 /** Schedules the task to run on the provided executor on behalf of the service. */
152 abstract Future<?> schedule(AbstractService service, ScheduledExecutorService executor, argument
191 executorService = MoreExecutors.renamingDecorator(executor(), new Supplier<String>() {
274 * executor will not be {@linkplain ScheduledExecutorService#shutdown shutdown} when this
286 protected ScheduledExecutorService executor() { method in class:AbstractScheduledService
334 addListener(Listener listener, Executor executor) argument
409 private final ScheduledExecutorService executor; field in class:AbstractScheduledService.CustomScheduler.ReschedulableCallable
428 ReschedulableCallable(AbstractService service, ScheduledExecutorService executor, Runnable runnable) argument
488 schedule(AbstractService service, ScheduledExecutorService executor, Runnable runnable) argument
[all...]
H A DListenerCallQueue.java32 * 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) { argument
67 this.executor = checkNotNull(executor);
86 executor.execute(this);
94 "Exception while running callbacks for " + listener + " on " + executor,
/external/guava/guava-tests/benchmark/com/google/common/util/concurrent/
H A DMoreExecutorsDirectExecutorBenchmark.java42 @Override Executor executor() {
47 @Override Executor executor() {
51 abstract Executor executor(); method in class:MoreExecutorsDirectExecutorBenchmark.Impl
55 Executor executor; field in class:MoreExecutorsDirectExecutorBenchmark
69 executor = impl.executor();
75 executor.execute(localRunnable);
92 return executor;
96 final Executor executor = this.executor;
[all...]
H A DExecutionListBenchmark.java53 void add(Runnable runnable, Executor executor); argument
64 @Override public void add(Runnable runnable, Executor executor) {
65 list.add(runnable, executor);
82 @Override public void add(Runnable runnable, Executor executor) {
83 list.add(runnable, executor);
100 @Override public void add(Runnable runnable, Executor executor) {
101 list.add(runnable, executor);
118 @Override public void add(Runnable runnable, Executor executor) {
119 list.add(runnable, executor);
136 @Override public void add(Runnable runnable, Executor executor) {
281 add(Runnable runnable, Executor executor) argument
315 final Executor executor; field in class:ExecutionListBenchmark.OldExecutionList.RunnableExecutorPair
317 RunnableExecutorPair(Runnable runnable, Executor executor) argument
342 add(Runnable runnable, Executor executor) argument
371 executeListener(Runnable runnable, Executor executor) argument
382 final Executor executor; field in class:ExecutionListBenchmark.NewExecutionListWithoutReverse.RunnableExecutorPair
385 RunnableExecutorPair(Runnable runnable, Executor executor, RunnableExecutorPair next) argument
405 add(Runnable runnable, Executor executor) argument
442 executeListener(Runnable runnable, Executor executor) argument
453 Executor executor; field in class:ExecutionListBenchmark.NewExecutionListQueue.RunnableExecutorPair
456 RunnableExecutorPair(Runnable runnable, Executor executor) argument
512 add(Runnable runnable, Executor executor) argument
558 final Executor executor; field in class:ExecutionListBenchmark.ExecutionListCAS.RunnableExecutorPair
562 RunnableExecutorPair(Runnable runnable, Executor executor) argument
[all...]
/external/tensorflow/tensorflow/compiler/xla/service/cpu/
H A Dcpu_transfer_manager.h40 Status TransferLiteralToInfeed(perftools::gputools::StreamExecutor* executor,
42 Status TransferBufferToInfeed(perftools::gputools::StreamExecutor* executor,
45 perftools::gputools::StreamExecutor* executor, const Shape& literal_shape,
52 perftools::gputools::StreamExecutor* executor, int64 size,
57 perftools::gputools::StreamExecutor* executor,
62 perftools::gputools::StreamExecutor* executor, void* destination,
69 perftools::gputools::StreamExecutor* executor,
/external/webrtc/webrtc/examples/androidtests/src/org/appspot/apprtc/test/
H A DLooperExecutorTest.java38 LooperExecutor executor = new LooperExecutor();
40 // Try to execute a counter increment task before starting an executor.
41 executor.execute(counterIncRunnable);
43 // Start the executor and run expected amount of counter increment task.
44 executor.requestStart();
46 executor.execute(counterIncRunnable);
48 executor.execute(new Runnable() {
54 executor.requestStop();
56 // Try to execute a task after stopping the executor.
57 executor
[all...]
/external/guava/guava/src/com/google/common/cache/
H A DRemovalListeners.java38 * notifications using {@code executor}.
41 * @param executor the executor with which removal notifications are
45 final RemovalListener<K, V> listener, final Executor executor) {
47 checkNotNull(executor);
51 executor.execute(new Runnable() {
44 asynchronous( final RemovalListener<K, V> listener, final Executor executor) argument
/external/lisa/libs/utils/
H A D__init__.py21 from executor import Executor
/external/python/futures/
H A Dprimes.py31 with ProcessPoolExecutor(10) as executor:
32 return list(executor.map(is_prime, PRIMES))
35 with ThreadPoolExecutor(10) as executor:
36 return list(executor.map(is_prime, PRIMES))
/external/tensorflow/tensorflow/compiler/xla/service/gpu/
H A Dgpu_transfer_manager.h39 Status TransferLiteralToInfeed(perftools::gputools::StreamExecutor* executor,
41 Status TransferBufferToInfeed(perftools::gputools::StreamExecutor* executor,
48 perftools::gputools::StreamExecutor* executor, int64 size,
53 Status EnqueueBuffersToInfeed(perftools::gputools::StreamExecutor* executor,
H A Dgpu_transfer_manager.cc49 Status GpuTransferManager::TransferLiteralToInfeed(se::StreamExecutor* executor, argument
57 return TransferBufferToInfeed(executor, size, literal.untyped_data());
83 TransferBufferToInfeedInternal(executor, tuple_element_size,
89 return EnqueueBuffersToInfeed(executor, buffers);
92 Status GpuTransferManager::TransferBufferToInfeed(se::StreamExecutor* executor, argument
96 TransferBufferToInfeedInternal(executor, size, source));
97 return EnqueueBuffersToInfeed(executor, {buffer});
101 se::StreamExecutor* executor, std::vector<gpu::InfeedBuffer*> buffers) {
103 se::Stream* stream = infeed_manager->GetStream(executor);
126 se::StreamExecutor* executor, int6
100 EnqueueBuffersToInfeed( se::StreamExecutor* executor, std::vector<gpu::InfeedBuffer*> buffers) argument
125 TransferBufferToInfeedInternal( se::StreamExecutor* executor, int64 size, const void* source) argument
[all...]
/external/guice/extensions/service/src/com/google/inject/service/
H A DAsyncService.java37 private final ExecutorService executor; field in class:AsyncService
41 public AsyncService(ExecutorService executor) { argument
42 this.executor = executor;
54 return executor.submit(new Callable<State>() {
79 return executor.submit(new Callable<State>() {
/external/tensorflow/tensorflow/compiler/xla/service/
H A Dgeneric_transfer_manager.h46 perftools::gputools::StreamExecutor* executor,
49 Status TransferLiteralToDevice(perftools::gputools::StreamExecutor* executor,
53 Status TransferLiteralToInfeed(perftools::gputools::StreamExecutor* executor,
56 perftools::gputools::StreamExecutor* executor, const Shape& literal_shape,
66 Status TransferBufferToInfeed(perftools::gputools::StreamExecutor* executor,
70 perftools::gputools::StreamExecutor* executor,
H A Dgeneric_transfer_manager.cc55 perftools::gputools::StreamExecutor* executor,
64 return TransferBufferToDevice(executor, GetByteSizeRequirement(shape),
70 se::StreamExecutor* executor, const ShapedBuffer& device_buffer) {
72 << executor->device_ordinal() << "; device buffer: " << device_buffer;
73 TF_RET_CHECK(executor->device_ordinal() == device_buffer.device_ordinal());
88 executor,
101 se::StreamExecutor* executor, const Literal& literal,
115 TF_RET_CHECK(executor->device_ordinal() == device_buffer.device_ordinal());
117 TF_RETURN_IF_ERROR(WriteTupleIndexTables(executor, device_buffer));
140 executor,
54 WriteSingleTupleIndexTable( perftools::gputools::StreamExecutor* executor, tensorflow::gtl::ArraySlice<se::DeviceMemoryBase> elements, const Shape& shape, perftools::gputools::DeviceMemoryBase* region) argument
69 TransferLiteralFromDevice( se::StreamExecutor* executor, const ShapedBuffer& device_buffer) argument
100 TransferLiteralToDevice( se::StreamExecutor* executor, const Literal& literal, const ShapedBuffer& device_buffer) argument
148 TransferLiteralToInfeed( se::StreamExecutor* executor, const Literal& literal) argument
153 TransferBufferToInfeed( perftools::gputools::StreamExecutor* executor, int64 size, const void* source) argument
159 TransferLiteralFromOutfeed( perftools::gputools::StreamExecutor* executor, const Shape& literal_shape, Literal* literal) argument
[all...]
H A Dtransfer_manager.h56 // using the provided executor. The optional literal_shape will be the shape
61 perftools::gputools::StreamExecutor* executor,
65 // represented by the given ShapedBuffer using the given executor. The shape
69 perftools::gputools::StreamExecutor* executor, const Literal& literal,
76 perftools::gputools::StreamExecutor* executor, const Literal& literal,
79 perftools::gputools::StreamExecutor* executor, const Shape& shape,
83 // using the given executor.
85 perftools::gputools::StreamExecutor* executor,
89 // using the given executor.
91 perftools::gputools::StreamExecutor* executor, cons
[all...]
/external/mockito/src/test/java/org/mockitousage/verification/
H A DDelayedExecution.java24 private final ScheduledExecutorService executor; field in class:DelayedExecution
27 this.executor = newScheduledThreadPool(CORE_POOL_SIZE, maxPrioThreadFactory());
33 executor.submit(delayedExecution(r, deadline));
37 executor.shutdownNow();
39 if (!executor.awaitTermination(5, SECONDS)) {
/external/python/cpython3/Lib/test/
H A Dtest_concurrent_futures.py68 self.executor = self.executor_type(max_workers=self.worker_count)
74 self.executor.shutdown(wait=True)
81 # Make sure that the executor is ready to do work before running the
83 futures = [self.executor.submit(time.sleep, 0.1)
100 self.executor.shutdown()
102 self.executor.submit,
120 fs = [self.executor.submit(time.sleep, 0.1) for _ in range(50)]
121 self.executor.shutdown()
131 self.executor.submit(mul, 21, 2)
132 self.executor
[all...]
/external/jacoco/org.jacoco.agent.rt.test/src/org/jacoco/agent/rt/internal/output/
H A DExecutorTestBase.java32 protected ExecutorService executor; field in class:ExecutorTestBase
36 executor = Executors.newSingleThreadExecutor();
41 executor.shutdown();
/external/guice/extensions/service/test/com/google/inject/service/
H A DSingleServiceIntegrationTest.java22 ExecutorService executor = Executors.newSingleThreadExecutor();
26 AsyncService service = new AsyncService(executor) {
54 executor.shutdown();
61 ExecutorService executor = Executors.newSingleThreadExecutor();
64 AsyncService service = new AsyncService(executor) {
77 executor.shutdown();

Completed in 1601 milliseconds

12345678910