Searched refs:executor (Results 151 - 175 of 235) sorted by relevance

12345678910

/external/guava/guava/src/com/google/common/util/concurrent/
H A DServiceManager.java219 * executor. The listener will not have previous state changes replayed, so it is
238 * @param executor the executor in which the listeners callback methods will be run.
240 public void addListener(Listener listener, Executor executor) { argument
241 state.addListener(listener, executor);
518 void addListener(Listener listener, Executor executor) { argument
520 checkNotNull(executor, "executor");
525 listeners.add(new ListenerCallQueue<Listener>(listener, executor));
/external/tensorflow/tensorflow/contrib/cudnn_rnn/kernels/
H A Dcudnn_rnn_ops.cc68 * stream-executor is done through ScratchAllocator. In general,
69 * stream-executor is responsible for creating the memory of proper size. And
835 auto* executor = stream->parent(); variable
842 auto input_desc_s = executor->createRnnSequenceTensorDescriptor(
848 auto hidden_state_desc_s = executor->createRnnStateTensorDescriptor(
854 auto output_desc_s = executor->createRnnSequenceTensorDescriptor(
894 auto rnn_desc_s = executor->createRnnDescriptor(
1036 auto* executor = stream->parent(); variable
1042 auto input_desc_s = executor->createRnnSequenceTensorDescriptor(
1048 auto hidden_state_desc_s = executor
[all...]
/external/okhttp/mockwebserver/src/main/java/com/squareup/okhttp/mockwebserver/
H A DMockWebServer.java123 private ExecutorService executor; field in class:MockWebServer
178 if (executor != null) {
349 executor = Executors.newCachedThreadPool(Util.threadFactory("MockWebServer", false));
357 executor.execute(new NamedRunnable("MockWebServer %s", port) {
376 executor.shutdown();
410 if (!executor.awaitTermination(5, TimeUnit.SECONDS)) {
411 throw new IOException("Gave up waiting for executor to shut down");
419 executor.execute(new NamedRunnable("MockWebServer %s", raw.getRemoteSocketAddress()) {
/external/okhttp/okhttp/src/main/java/com/squareup/okhttp/internal/framed/
H A DFramedConnection.java69 private static final ExecutorService executor = new ThreadPoolExecutor(0, field in class:FramedConnection
81 * on {@link #executor}.
349 executor.submit(new NamedRunnable("OkHttp %s stream %d", hostName, streamId) {
364 executor.execute(new NamedRunnable("OkHttp Window Update %s stream %d", hostName, streamId) {
396 executor.execute(new NamedRunnable("OkHttp %s ping %08x%08x",
447 * internal executor services.
672 executor.execute(new NamedRunnable("OkHttp %s stream %d", hostName, streamId) {
733 executor.execute(new NamedRunnable("OkHttp %s settings", hostName) {
749 executor.execute(new NamedRunnable("OkHttp %s ACK Settings", hostName) {
/external/okhttp/okhttp-tests/src/test/java/com/squareup/okhttp/
H A DInterceptorTest.java547 ExceptionCatchingExecutor executor = new ExceptionCatchingExecutor();
548 client.setDispatcher(new Dispatcher(executor));
555 assertEquals("boom!", executor.takeException().getMessage());
569 ExceptionCatchingExecutor executor = new ExceptionCatchingExecutor();
570 client.setDispatcher(new Dispatcher(executor));
595 ExceptionCatchingExecutor executor = new ExceptionCatchingExecutor();
596 client.setDispatcher(new Dispatcher(executor));
/external/tensorflow/tensorflow/core/common_runtime/gpu/
H A Dgpu_device.cc203 gpu::StreamExecutor* executor) {
208 group->compute = new gpu::Stream(executor);
213 group->host_to_device = new gpu::Stream(executor);
218 group->device_to_host = new gpu::Stream(executor);
223 group->device_to_device = new gpu::Stream(executor);
1310 auto executor = GpuIdUtil::ExecutorForCudaGpuId(gpu_manager, cuda_gpu_id); local
1311 if (!executor.ok()) {
1312 return StreamExecutorUtil::ConvertStatus(executor.status());
1315 auto stream_exec = executor.ValueOrDie();
1363 << " whose executor i
201 GetOrCreate(TfGpuId tf_gpu_id, int stream_group_within_gpu, gpu::StreamExecutor* executor) argument
[all...]
H A Dgpu_device.h94 // The executor that provides control for the device; e.g., for CUDA this
96 gpu::StreamExecutor* executor() const { return executor_; } function in class:tensorflow::BaseGPUDevice
/external/deqp/modules/glshared/
H A DglsRandomShaderCase.cpp483 // Reference program executor.
484 rsg::ProgramExecutor executor (reference.getAccess(), m_gridWidth, m_gridHeight);
528 executor.setTexture(unitNdx, &texture->getRefTexture(), glu::mapGLSampler(TEXTURE_WRAP_S, TEXTURE_WRAP_T, TEXTURE_MIN_FILTER, TEXTURE_MAG_FILTER));
540 executor.setTexture(unitNdx, &texture->getRefTexture(), glu::mapGLSampler(TEXTURE_WRAP_S, TEXTURE_WRAP_T, TEXTURE_MIN_FILTER, TEXTURE_MAG_FILTER));
551 executor.execute(m_vertexShader, m_fragmentShader, m_uniforms);
/external/glide/library/src/main/java/com/bumptech/glide/
H A DGlideBuilder.java17 import com.bumptech.glide.load.engine.executor.FifoPriorityThreadPoolExecutor;
86 * @see com.bumptech.glide.load.engine.executor.FifoPriorityThreadPoolExecutor
106 * @see com.bumptech.glide.load.engine.executor.FifoPriorityThreadPoolExecutor
/external/tensorflow/tensorflow/compiler/xla/service/
H A Dbackend.h104 // Returns the stream executor for the given device ordinal.
108 // Returns the stream executor for the default device ordinal. This stream
109 // executor can only be used when the number of computations is 1 (replication
121 perftools::gputools::StreamExecutor* executor);
174 // Vector of stream executors. stream_executors_[0] is the default executor.
179 // Mapping from stream executor to stream pools, used by `BorrowStream` above.
/external/tensorflow/tensorflow/core/common_runtime/
H A Dexecutor.h37 // Executor* executor;
38 // TF_CHECK_OK(NewSimpleExecutor(my_device, graph, &executor));
41 // TF_CHECK_OK(executor->Run({ExecutorOpts, rendezvous, nullptr}));
71 // RunAsync() is provided a "call_frame", if the executor is used
125 // If successful, returns the constructed executor in "*executor". Otherwise,
128 // "params" provides a set of context for the executor. We expect that
137 // delete_kernel is called for every kernel used by the executor
138 // when the executor is deleted.
146 Executor** executor);
[all...]
/external/v8/src/builtins/
H A Dbuiltins-promise.h123 Node* promise_constructor, Node* executor,
H A Dbuiltins-promise.cc153 Node* executor = AllocateFunctionWithMapAndContext( local
157 constructor, executor);
894 Node* executor, Label* if_noaccess) {
896 var_executor.Bind(executor);
899 // If executor is a bound function, load the bound function until we've
1018 Node* const executor = Parameter(1); local
1029 GotoIf(TaggedIsSmi(executor), &if_notcallable);
1031 Node* const executor_map = LoadMap(executor);
1042 BranchIfAccessCheckFailed(context, native_context, promise_fun, executor,
1089 Node* const maybe_exception = CallJS(call_callable, context, executor,
892 BranchIfAccessCheckFailed( Node* context, Node* native_context, Node* promise_constructor, Node* executor, Label* if_noaccess) argument
[all...]
/external/guava/guava-tests/test/com/google/common/eventbus/
H A DEventBusTest.java271 ExecutorService executor = Executors.newFixedThreadPool(10);
274 futures.add(executor.submit(new Registrator(bus, catchers)));
/external/pdfium/testing/tools/coverage/
H A Dcoverage_report.py56 """Initialize executor based on the current script environment
386 executor = CoverageExecutor(parser, args)
387 if executor.run():
/external/python/cpython3/Lib/
H A Dcompileall.py79 with ProcessPoolExecutor(max_workers=workers) as executor:
80 results = executor.map(partial(compile_file,
/external/tensorflow/tensorflow/contrib/nccl/kernels/
H A Dnccl_manager_test.cc199 num_ranks, "allreduce", reduction_op, device->executor(),
266 device->executor(), device->gpu_id(), event_mgr, stream,
/external/tensorflow/tensorflow/core/kernels/
H A Dremote_fused_graph_execute_op_test.cc234 // 2. Register a builder of your custom executor
237 std::unique_ptr<IRemoteFusedGraphExecutor>* executor) {
238 executor->reset(new SampleRemoteFusedGraphExecutor());
242 // This class instantiation registers executor to the
236 BuildRemoteFusedGraphExecutor( std::unique_ptr<IRemoteFusedGraphExecutor>* executor) argument
H A Dremote_fused_graph_execute_utils_test.cc52 std::unique_ptr<IRemoteFusedGraphExecutor>* executor) {
53 executor->reset(
59 std::unique_ptr<IRemoteFusedGraphExecutor>* executor) {
60 executor->reset(new TestRemoteFusedGraphExecutor(
73 [](std::unique_ptr<IRemoteFusedGraphExecutor>* executor) -> Status {
443 "executor", def, inputs, outputs, /*require_shape_type=*/true,
472 "fused_name", "executor", def, inputs, outputs,
51 BuildRemoteFusedGraphExecutor0( std::unique_ptr<IRemoteFusedGraphExecutor>* executor) argument
58 BuildRemoteFusedGraphExecutor1( std::unique_ptr<IRemoteFusedGraphExecutor>* executor) argument
/external/deqp/modules/gles31/functional/
H A Des31fOpaqueTypeIndexingTests.cpp528 ShaderExecutorPtr executor (createExecutor(m_context.getRenderContext(), m_shaderType, shaderSpec));
535 m_testCtx.getLog() << *executor;
537 if (!executor->isOk())
540 executor->useProgram();
546 const int samplerLoc = gl.getUniformLocation(executor->getProgram(), samplerName.c_str());
574 uploadUniformIndices(gl, executor->getProgram(), "index", numLookups, &lookupIndices[0]);
581 executor->execute(numInvocations, &inputs[0], &outputs[0]);
/external/deqp/
H A DAndroidGen.mk13 executor/xeBatchExecutor.cpp \
14 executor/xeBatchResult.cpp \
15 executor/xeCallQueue.cpp \
16 executor/xeCommLink.cpp \
17 executor/xeContainerFormatParser.cpp \
18 executor/xeDefs.cpp \
19 executor/xeLocalTcpIpLink.cpp \
20 executor/xeTcpIpLink.cpp \
21 executor/xeTestCase.cpp \
22 executor/xeTestCaseListParse
[all...]
/external/okhttp/okhttp-tests/src/test/java/com/squareup/okhttp/internal/framed/
H A DHttpOverSpdyTest.java200 ExecutorService executor = Executors.newCachedThreadPool();
202 executor.execute(new SpdyRequest("/r1", countDownLatch));
203 executor.execute(new SpdyRequest("/r2", countDownLatch));
/external/gemmlowp/internal/
H A Dunpack.h93 const OutputPipelineExecutorType& executor, DstType* dst,
124 executor.Execute(acc, dst, src_global_row, src_global_col, dst_row, dst_col);
92 UnpackResultBlock(const SrcMapType& src, const OutputPipelineExecutorType& executor, DstType* dst, const VectorMap<const std::int32_t, VectorShape::Col>& lhs_sums_of_each_slice, const VectorMap<const std::int32_t, VectorShape::Row>& rhs_sums_of_each_slice, const LhsOffset& lhs_offset, const RhsOffset& rhs_offset, int depth, int src_row, int src_col, int src_global_row, int src_global_col, int dst_row, int dst_col) argument
/external/python/cpython3/Lib/asyncio/
H A Devents.py288 def run_in_executor(self, executor, func, *args):
291 def set_default_executor(self, executor):
/external/tensorflow/tensorflow/compiler/xla/service/cpu/
H A Dparallel_cpu_executable.cc435 Executor executor(
439 TF_RETURN_IF_ERROR(executor.Run());

Completed in 2963 milliseconds

12345678910