HomeSort by relevance Sort by last modified time
    Searched refs:executor (Results 26 - 50 of 1056) sorted by null

12 3 4 5 6 7 8 91011>>

  /external/tensorflow/tensorflow/compiler/xla/service/
generic_transfer_manager.h 46 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,
generic_transfer_manager.cc 55 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,
    [all...]
  /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/benchmark/com/google/common/util/concurrent/
ExecutionListBenchmark.java 33 import java.util.concurrent.Executor;
53 void add(Runnable runnable, Executor executor);
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)
    [all...]
  /external/guava/guava/src/com/google/common/util/concurrent/
AbstractScheduledService.java 27 import java.util.concurrent.Executor;
45 * <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,
191 executorService = MoreExecutors.renamingDecorator(executor(), new Supplier<String>() {
274 * executor will not be {@linkplain ScheduledExecutorService#shutdown shutdown} when this
    [all...]
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...]
  /external/mockito/src/test/java/org/mockitousage/verification/
DelayedExecution.java 24 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)) {
  /frameworks/base/core/java/android/net/
NetworkRecommendationProvider.java 30 import java.util.concurrent.Executor;
59 * @param executor used to execute the incoming requests. Cannot be {@code null}.
61 public NetworkRecommendationProvider(Context context, Executor executor) {
63 Preconditions.checkNotNull(executor);
64 mService = new ServiceWrapper(context, executor);
89 private final Executor mExecutor;
92 ServiceWrapper(Context context, Executor executor) {
94 mExecutor = executor;
    [all...]
  /packages/apps/Dialer/java/com/android/dialer/common/concurrent/
AsyncTaskExecutors.java 22 import java.util.concurrent.Executor;
79 private final Executor executor; field in class:AsyncTaskExecutors.SimpleAsyncTaskExecutor
81 public SimpleAsyncTaskExecutor(Executor executor) {
82 this.executor = executor;
89 return task.executeOnExecutor(executor, params);
  /tools/apkzlib/src/main/java/com/android/tools/build/apkzlib/zip/compress/
ExecutorCompressor.java 24 import java.util.concurrent.Executor;
34 * The executor that does the work.
37 private final Executor executor; field in class:ExecutorCompressor
40 * Compressor that delegates execution into the given executor.
41 * @param executor the executor that will do the compress
43 public ExecutorCompressor(@Nonnull Executor executor) {
44 this.executor = executor
    [all...]
  /external/python/cpython3/Lib/test/
test_concurrent_futures.py 68 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.submit(mul, 6, 7
    [all...]
  /external/jacoco/org.jacoco.agent.rt.test/src/org/jacoco/agent/rt/internal/output/
ExecutorTestBase.java 16 import java.util.concurrent.Executor;
27 * Unit tests base for tests that need an {@link Executor} for multithreaded
32 protected ExecutorService executor; field in class:ExecutorTestBase
36 executor = Executors.newSingleThreadExecutor();
41 executor.shutdown();
  /external/tensorflow/tensorflow/compiler/xla/service/gpu/
gpu_transfer_manager.cc 49 Status GpuTransferManager::TransferLiteralToInfeed(se::StreamExecutor* executor,
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,
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, int64 size, const void* source)
    [all...]
  /frameworks/support/app-toolkit/core-testing/src/main/java/androidx/arch/core/executor/testing/
InstantTaskExecutorRule.java 17 package androidx.arch.core.executor.testing;
19 import androidx.arch.core.executor.ArchTaskExecutor;
20 import androidx.arch.core.executor.TaskExecutor;
26 * A JUnit Test Rule that swaps the background executor used by the Architecture Components with a
  /packages/inputmethods/LatinIME/tests/src/com/android/inputmethod/latin/utils/
ExecutorUtilsTests.java 38 final ExecutorService executor = local
42 executor.execute(new Runnable() {
50 executor.awaitTermination(DELAY_FOR_WAITING_TASKS_MILLISECONDS, TimeUnit.MILLISECONDS);
  /external/guice/extensions/service/test/com/google/inject/service/
SingleServiceIntegrationTest.java 22 ExecutorService executor = Executors.newSingleThreadExecutor(); local
26 AsyncService service = new AsyncService(executor) {
54 executor.shutdown();
61 ExecutorService executor = Executors.newSingleThreadExecutor(); local
64 AsyncService service = new AsyncService(executor) {
77 executor.shutdown();
  /dalvik/dx/tests/127-merge-stress/com/android/dx/merge/
MergeTest.class 
  /external/dagger2/compiler/src/it/producers-functional-tests/src/main/java/producerstest/builder/
TestComponentWithBuilder.java 20 import java.util.concurrent.Executor;
34 Builder executor(Executor executor); method in interface:TestComponentWithBuilder.Builder
  /external/guava/guava-testlib/test/com/google/common/util/concurrent/testing/
TestingExecutorsTest.java 56 ListeningScheduledExecutorService executor = TestingExecutors.noOpScheduledExecutor(); local
57 assertFalse(executor.isShutdown());
58 assertFalse(executor.isTerminated());
59 executor.shutdown();
60 assertTrue(executor.isShutdown());
61 assertTrue(executor.isTerminated());
65 ListeningScheduledExecutorService executor = TestingExecutors.noOpScheduledExecutor(); local
73 List<Future<Boolean>> futureList = executor.invokeAll(
  /packages/apps/Camera2/src/com/android/camera/async/
ExecutorCallback.java 21 import java.util.concurrent.Executor;
28 * which runs it on an executor.
34 private final Executor mExecutor;
38 * @param executor The executor on which to invoke the callback.
40 public ExecutorCallback(Callback<T> callback, Executor executor) {
42 mExecutor = executor;
ForwardingObservable.java 21 import java.util.concurrent.Executor;
38 public SafeCloseable addCallback(Runnable callback, Executor executor) {
39 return mDelegate.addCallback(callback, executor);
  /packages/apps/Dialer/java/com/android/incallui/ringtone/
InCallTonePlayer.java 40 @NonNull private final PausableExecutor executor; field in class:InCallTonePlayer
48 * @param executor the {@link PausableExecutor} used to play tones in a background thread.
49 * @throws NullPointerException if audioModeProvider, toneGeneratorFactory, or executor are {@code
53 @NonNull ToneGeneratorFactory toneGeneratorFactory, @NonNull PausableExecutor executor) {
55 this.executor = Objects.requireNonNull(executor);
76 executor.execute(
115 executor.milestone();
119 executor.milestone();
131 executor.milestone()
    [all...]
  /frameworks/base/core/java/android/hardware/camera2/impl/
CameraCaptureSessionImpl.java 33 import java.util.concurrent.Executor;
54 /** User-specified state executor used for outgoing state callback events */
55 private final Executor mStateExecutor;
59 /** Internal executor; used for all incoming events to preserve total order */
60 private final Executor mDeviceExecutor;
87 CameraCaptureSession.StateCallback callback, Executor stateExecutor,
89 Executor deviceStateExecutor, boolean configureSuccess) {
179 public int captureSingleRequest(CaptureRequest request, Executor executor,
181 if (executor == null)
582 final Executor executor = (callback != null) ? CameraDeviceImpl.checkAndWrapHandler( local
    [all...]
  /cts/tests/tests/media/src/android/media/cts/
MockPlayer.java 27 import java.util.concurrent.Executor;
45 public ArrayMap<PlayerEventCallback, Executor> mCallbacks = new ArrayMap<>();
134 public void registerPlayerEventCallback(@NonNull Executor executor,
136 mCallbacks.put(callback, executor);
148 final Executor executor = mCallbacks.valueAt(i); local
149 executor.execute(() -> callback.onPlayerStateChanged(this, state));
156 final Executor executor = mCallbacks.valueAt(i) local
164 final Executor executor = mCallbacks.valueAt(i); local
172 final Executor executor = mCallbacks.valueAt(i); local
180 final Executor executor = mCallbacks.valueAt(i); local
    [all...]
  /frameworks/base/telephony/java/android/telephony/
TelephonyScanManager.java 36 import java.util.concurrent.Executor;
60 * TelephonyManager#requestNetworkScan(NetworkScanRequest, Executor, NetworkScanCallback)}
89 private final Executor mExecutor;
93 NetworkScanRequest request, Executor executor, NetworkScanCallback callback) {
95 mExecutor = executor;
121 Executor executor = nsi.mExecutor;
126 if (executor == null) {
128 "Failed to find Executor with id " + message.arg2)
    [all...]

Completed in 3109 milliseconds

12 3 4 5 6 7 8 91011>>