Searched refs:executor (Results 51 - 75 of 235) sorted by relevance

12345678910

/external/conscrypt/benchmark-base/src/main/java/org/conscrypt/
H A DClientSocketBenchmark.java48 private ExecutorService executor; field in class:ClientSocketBenchmark
82 executor = Executors.newSingleThreadExecutor();
83 sendingFuture = executor.submit(new Runnable() {
106 executor.shutdown();
107 executor.awaitTermination(5, TimeUnit.SECONDS);
H A DServerSocketBenchmark.java51 private ExecutorService executor; field in class:ServerSocketBenchmark
99 executor = Executors.newSingleThreadExecutor();
100 receivingFuture = executor.submit(new Runnable() {
126 executor.shutdown();
128 executor.awaitTermination(5, TimeUnit.SECONDS);
/external/guava/guava/src/com/google/common/util/concurrent/
H A DAbstractIdleService.java31 * which run in a executor which by default uses a separate thread
50 MoreExecutors.renamingDecorator(executor(), threadNameSupplier)
65 MoreExecutors.renamingDecorator(executor(), threadNameSupplier)
93 * priority. The returned executor's {@link Executor#execute(Runnable)
97 protected Executor executor() { method in class:AbstractIdleService
120 @Override public final void addListener(Listener listener, Executor executor) { argument
121 delegate.addListener(listener, executor);
H A DMoreExecutors.java76 * @param executor the executor to modify to make sure it exits when the
78 * @param terminationTimeout how long to wait for the executor to
85 ThreadPoolExecutor executor, long terminationTimeout, TimeUnit timeUnit) {
87 .getExitingExecutorService(executor, terminationTimeout, timeUnit);
99 * @param executor the executor to modify to make sure it exits when the
101 * @param terminationTimeout how long to wait for the executor to
108 ScheduledThreadPoolExecutor executor, long terminationTimeout, TimeUnit timeUnit) {
110 .getExitingScheduledExecutorService(executor, terminationTimeou
84 getExitingExecutorService( ThreadPoolExecutor executor, long terminationTimeout, TimeUnit timeUnit) argument
107 getExitingScheduledExecutorService( ScheduledThreadPoolExecutor executor, long terminationTimeout, TimeUnit timeUnit) argument
147 getExitingExecutorService(ThreadPoolExecutor executor) argument
167 getExitingScheduledExecutorService( ScheduledThreadPoolExecutor executor) argument
175 getExitingExecutorService( ThreadPoolExecutor executor, long terminationTimeout, TimeUnit timeUnit) argument
183 getExitingScheduledExecutorService( ScheduledThreadPoolExecutor executor, long terminationTimeout, TimeUnit timeUnit) argument
213 getExitingExecutorService(ThreadPoolExecutor executor) argument
217 getExitingScheduledExecutorService( ScheduledThreadPoolExecutor executor) argument
227 useDaemonThreadFactory(ThreadPoolExecutor executor) argument
840 renamingDecorator(final Executor executor, final Supplier<String> nameSupplier) argument
[all...]
H A DJdkFutureAdapters.java72 * ListenableFuture#addListener} by submitting a task to the given executor at
74 * executor promptly, or else the returned {@code ListenableFuture} may fail
91 Future<V> future, Executor executor) {
92 checkNotNull(executor);
96 return new ListenableFutureAdapter<V>(future, executor);
166 * from a user-supplied executor might be, but... what can we do?
90 listenInPoolThread( Future<V> future, Executor executor) argument
/external/guava/guava-tests/test/com/google/common/util/concurrent/
H A DAbstractScheduledServiceTest.java51 final ScheduledExecutorService executor = new ScheduledThreadPoolExecutor(10) { field in class:AbstractScheduledServiceTest
70 @Override protected ScheduledExecutorService executor() { return executor; } method in class:AbstractScheduledServiceTest.NullService
152 final AtomicReference<ScheduledExecutorService> executor = Atomics.newReference();
156 @Override protected ScheduledExecutorService executor() {
157 executor.set(super.executor());
158 return executor.get();
167 assertFalse(service.executor().isShutdown());
171 assertTrue(executor
267 protected ScheduledExecutorService executor() { method in class:AbstractScheduledServiceTest.TestService
415 @Override protected ScheduledExecutorService executor() { method in class:AbstractScheduledServiceTest.SchedulerTest.TestAbstractScheduledCustomService
461 @Override protected ScheduledExecutorService executor() { method in class:AbstractScheduledServiceTest.SchedulerTest.TestFailingCustomScheduledService
[all...]
H A DSerializingExecutorTest.java149 final SerializingExecutor executor = new SerializingExecutor(
165 executor.execute(task);
170 executor.execute(task);
180 final SerializingExecutor executor = new SerializingExecutor(service);
197 executor.execute(errorTask);
202 executor.execute(barrierTask);
/external/libmojo/mojo/public/java/bindings/src/org/chromium/mojo/bindings/
H A DExecutorFactory.java35 * Implementation of the executor which uses a pair of {@link MessagePipeHandle} for signaling.
36 * The executor will wait asynchronously on one end of a {@link MessagePipeHandle} on the thread
38 * executor will queue the {@link Runnable} and write a message on the other end of the handle.
39 * This will wake up the executor which is waiting on the handle, which will then dequeue the
93 * Close the handles. Should only be called on the executor thread.
134 * Execute the given |command| in the executor thread. This can be called on any thread.
141 // from the executor's thread.
145 "Trying to execute an action on a closed executor.");
154 * Keep one executor per executor threa
[all...]
/external/tensorflow/tensorflow/compiler/xla/service/gpu/
H A Dkernel_thunk.cc68 se::StreamExecutor* executor = stream->parent(); local
73 auto it = kernel_cache_.find(executor);
75 it = kernel_cache_.emplace(executor, se::KernelBase(executor)).first;
76 if (!executor->GetKernel(*loader_spec_, &it->second)) {
/external/tensorflow/tensorflow/contrib/nccl/kernels/
H A Dnccl_manager.h46 // participant is managed by <executor>, and its events are polled by
59 perftools::gputools::StreamExecutor* executor,
68 perftools::gputools::StreamExecutor* executor,
73 perftools::gputools::StreamExecutor* executor,
82 perftools::gputools::StreamExecutor* executor,
88 perftools::gputools::StreamExecutor* executor,
H A Dnccl_manager.cc40 perftools::gputools::StreamExecutor* executor = nullptr; member in struct:tensorflow::NcclManager::NcclStream
97 perftools::gputools::StreamExecutor* executor, int gpu_device_id,
103 executor(executor),
106 DCHECK(executor != nullptr);
124 // Matches the executor in CommunicatorMember::stream. Expected to be live for
126 perftools::gputools::StreamExecutor* const executor = nullptr; member in class:tensorflow::NcclManager::Participant::perftools::gputools
181 // Sort by executor to make ordering of executors deterministic.
185 return a->executor < b->executor;
95 Participant(const Tensor* in_t, Tensor* out_t, EventMgr* event_mgr, perftools::gputools::Stream* tensor_stream, perftools::gputools::StreamExecutor* executor, int gpu_device_id, NcclManager::DoneCallback done_callback) argument
232 auto* executor = collective->participants[i]->executor; local
299 AddToAllReduce(int num_devices, const string& key, ncclRedOp_t reduction_op, perftools::gputools::StreamExecutor* executor, int gpu_device_id, EventMgr* event_mgr, perftools::gputools::Stream* tensor_stream, const Tensor* in_t, Tensor* out_t, const DoneCallback& done_callback) argument
313 AddBroadcastSend( int num_devices, const string& key, perftools::gputools::StreamExecutor* executor, int gpu_device_id, EventMgr* event_mgr, perftools::gputools::Stream* tensor_stream, const Tensor* in_t, DoneCallback done_callback) argument
326 AddBroadcastRecv( int num_devices, const string& key, perftools::gputools::StreamExecutor* executor, int gpu_device_id, EventMgr* event_mgr, perftools::gputools::Stream* tensor_stream, Tensor* out_t, DoneCallback done_callback) argument
338 AddReduceSend(int num_devices, const string& key, ncclRedOp_t reduction_op, perftools::gputools::StreamExecutor* executor, int gpu_device_id, EventMgr* event_mgr, perftools::gputools::Stream* tensor_stream, const Tensor* in_t, DoneCallback done_callback) argument
352 AddReduceRecv(int num_devices, const string& key, ncclRedOp_t reduction_op, perftools::gputools::StreamExecutor* executor, int gpu_device_id, EventMgr* event_mgr, perftools::gputools::Stream* tensor_stream, const Tensor* in_t, Tensor* out_t, DoneCallback done_callback) argument
[all...]
/external/tensorflow/tensorflow/python/estimator/
H A Dtraining_test.py368 executor = training._TrainingExecutor(estimator, train_spec, eval_spec)
369 self.assertEqual(estimator, executor.estimator)
425 def _run_task(self, executor):
426 # We should not call executor.run as the test here is intended to test
428 return getattr(executor, 'run_' + self._run_config.task_type)()
440 executor = training._TrainingExecutor(mock_est, train_spec, mock_eval_spec)
441 self._run_task(executor)
470 executor = training._TrainingExecutor(
472 self._run_task(executor)
488 executor
[all...]
/external/webrtc/webrtc/examples/androidapp/src/org/appspot/apprtc/
H A DWebSocketRTCClient.java50 private final LooperExecutor executor; field in class:WebSocketRTCClient
59 public WebSocketRTCClient(SignalingEvents events, LooperExecutor executor) { argument
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
[all...]
H A DWebSocketChannelClient.java33 * <p>All public methods should be called from a looper executor thread
42 private final LooperExecutor executor; field in class:WebSocketChannelClient
65 * All events are dispatched from a looper executor thread.
73 public WebSocketChannelClient(LooperExecutor executor, WebSocketChannelEvents events) { argument
74 this.executor = executor;
208 executor.execute(new Runnable() {
240 if (!executor.checkOnLooperThread()) {
250 executor.execute(new Runnable() {
270 executor
[all...]
/external/lisa/libs/utils/
H A Dtest.py28 from executor import Executor
41 experiments_conf to configure the executor.
101 cls.executor = Executor(test_env, experiments_conf)
104 cls.wloads = cls.executor._experiments_conf["wloads"]
105 cls.confs = cls.executor._experiments_conf["confs"]
107 # Alias executor objects to make less verbose tests code
108 cls.te = cls.executor.te
109 cls.target = cls.executor.target
115 cls.executor.run()
117 cls.experiments = cls.executor
[all...]
/external/dagger2/compiler/src/it/producers-functional-tests/src/test/java/producerstest/
H A DMultibindingTest.java35 DaggerMultibindingComponent.builder().executor(MoreExecutors.directExecutor()).build();
44 DaggerMultibindingComponent.builder().executor(MoreExecutors.directExecutor()).build();
58 DaggerMultibindingComponent.builder().executor(MoreExecutors.directExecutor()).build();
H A DSimpleTest.java30 .executor(MoreExecutors.directExecutor())
/external/tensorflow/tensorflow/compiler/xla/service/interpreter/
H A Dplatform.cc20 #include "tensorflow/compiler/xla/service/interpreter/executor.h"
75 auto executor = port::MakeUnique<StreamExecutor>( local
77 auto init_status = executor->Init(config.ordinal, config.device_options);
86 return std::move(executor);
91 LOG(FATAL) << "not yet implemented: register executor trace listener";
95 LOG(FATAL) << "not yet implemented: unregister executor trace listener";
H A Dexecutable.cc29 #include "tensorflow/compiler/xla/service/interpreter/executor.h"
55 se::StreamExecutor* executor = stream->parent(); local
56 const se::Platform* platform = executor->platform();
82 transfer_manager->TransferLiteralFromDevice(executor, *arguments[p]));
98 executor, *result_literal, *result));
/external/tensorflow/tensorflow/stream_executor/host/
H A Dhost_platform.cc72 auto executor = port::MakeUnique<StreamExecutor>( local
74 auto init_status = executor->Init(config.ordinal, config.device_options);
83 return std::move(executor);
/external/conscrypt/testing/src/main/java/org/conscrypt/javax/net/ssl/
H A DTestSSLSocketPair.java68 ExecutorService executor = Executors.newFixedThreadPool(2);
69 Future<Void> s = executor.submit(new Callable<Void>() {
79 Future<Void> c = executor.submit(new Callable<Void>() {
89 executor.shutdown();
/external/guice/extensions/servlet/test/com/google/inject/servlet/
H A DContinuingRequestIntegrationTest.java101 private ExecutorService executor; field in class:ContinuingRequestIntegrationTest
110 executor = Executors.newSingleThreadExecutor();
116 bind(ExecutorService.class).toInstance(executor);
143 executor.shutdown();
144 executor.awaitTermination(10, TimeUnit.SECONDS);
152 executor = sameThreadExecutor;
157 bind(ExecutorService.class).toInstance(executor);
185 executor.shutdown();
186 executor.awaitTermination(10, TimeUnit.SECONDS);
/external/skia/src/core/
H A DSkTaskGroup.h18 // Tasks added to this SkTaskGroup will run on its executor.
19 explicit SkTaskGroup(SkExecutor& executor = SkExecutor::GetDefault());
/external/skqp/src/core/
H A DSkTaskGroup.h18 // Tasks added to this SkTaskGroup will run on its executor.
19 explicit SkTaskGroup(SkExecutor& executor = SkExecutor::GetDefault());
/external/tensorflow/tensorflow/compiler/xla/service/
H A Dbackend.cc109 se::StreamExecutor* executor) {
111 if (0 == stream_pools_.count(executor)) {
113 std::forward_as_tuple(executor),
114 std::forward_as_tuple([executor]() {
115 auto stream = MakeUnique<se::Stream>(executor);
120 return stream_pools_.at(executor).Allocate();
189 for (auto* executor : stream_executors_) {
190 if (executor->device_ordinal() == device_ordinal) {
191 return executor;
108 BorrowStream( se::StreamExecutor* executor) argument

Completed in 872 milliseconds

12345678910