Home
last modified time | relevance | path

Searched refs:cq (Results 1 – 25 of 584) sorted by relevance

12345678910>>...24

/external/grpc-grpc/src/core/lib/surface/
Dcompletion_queue.cc189 void (*shutdown)(grpc_completion_queue* cq);
191 bool (*begin_op)(grpc_completion_queue* cq, void* tag);
192 void (*end_op)(grpc_completion_queue* cq, void* tag, grpc_error* error,
195 grpc_event (*next)(grpc_completion_queue* cq, gpr_timespec deadline,
197 grpc_event (*pluck)(grpc_completion_queue* cq, void* tag,
295 static void cq_finish_shutdown_next(grpc_completion_queue* cq);
296 static void cq_finish_shutdown_pluck(grpc_completion_queue* cq);
297 static void cq_finish_shutdown_callback(grpc_completion_queue* cq);
298 static void cq_shutdown_next(grpc_completion_queue* cq);
299 static void cq_shutdown_pluck(grpc_completion_queue* cq);
[all …]
Dchannel_ping.cc34 grpc_completion_queue* cq; member
44 grpc_cq_end_op(pr->cq, pr->tag, GRPC_ERROR_REF(error), ping_destroy, pr, in ping_done()
48 void grpc_channel_ping(grpc_channel* channel, grpc_completion_queue* cq, in grpc_channel_ping() argument
51 (channel, cq, tag, reserved)); in grpc_channel_ping()
59 pr->cq = cq; in grpc_channel_ping()
62 op->bind_pollset = grpc_cq_pollset(cq); in grpc_channel_ping()
63 GPR_ASSERT(grpc_cq_begin_op(cq, tag)); in grpc_channel_ping()
/external/skqp/src/compute/skc/platforms/cl_12/
Dcq_pool_cl.c51 cl_command_queue cq; in skc_runtime_cl_12_create_cq() local
59 cq = clCreateCommandQueue(runtime->cl.context, in skc_runtime_cl_12_create_cq()
71 cq = clCreateCommandQueue(runtime_cl->context, in skc_runtime_cl_12_create_cq()
86 cq = clCreateCommandQueueWithProperties(runtime_cl->context, in skc_runtime_cl_12_create_cq()
93 return cq; in skc_runtime_cl_12_create_cq()
111 pool->cq = skc_runtime_host_perm_alloc(runtime,SKC_MEM_FLAGS_READ_WRITE, in skc_cq_pool_create()
112 pool->size * sizeof(*pool->cq)); in skc_cq_pool_create()
114 pool->cq[ii] = skc_runtime_cl_12_create_cq(runtime,pool); in skc_cq_pool_create()
116 pool->cq[size] = NULL; in skc_cq_pool_create()
131 skc_runtime_host_perm_free(runtime,pool->cq); in skc_cq_pool_dispose()
[all …]
Dextent_cl_12_unified.c55 cl_command_queue const cq,
60 void * hrw = clEnqueueMapBuffer(cq,extent->drw,
70 cl_command_queue const cq,
73 return skc_extent_thrw_tdrw_map_size(extent,extent->size,cq,event);
79 cl_command_queue const cq,
82 cl(EnqueueUnmapMemObject(cq,extent->drw,hrw,0,NULL,event));
121 cl_command_queue const cq, in skc_extent_phrw_pdrw_map_size() argument
126 void * hrw = clEnqueueMapBuffer(cq,extent->drw, in skc_extent_phrw_pdrw_map_size()
136 cl_command_queue const cq, in skc_extent_phrw_pdrw_map() argument
139 return skc_extent_phrw_pdrw_map_size(extent,extent->size,cq,event); in skc_extent_phrw_pdrw_map()
[all …]
Dextent_cl_12.h97 cl_command_queue const cq,
122 cl_command_queue const cq,
127 cl_command_queue const cq,
158 cl_command_queue const cq,
163 cl_command_queue const cq,
200 cl_command_queue const cq,
241 cl_command_queue const cq,
330 cl_command_queue const cq,
335 cl_command_queue const cq,
341 cl_command_queue const cq,
[all …]
/external/skia/src/compute/skc/platforms/cl_12/
Dcq_pool_cl.c51 cl_command_queue cq; in skc_runtime_cl_12_create_cq() local
59 cq = clCreateCommandQueue(runtime->cl.context, in skc_runtime_cl_12_create_cq()
71 cq = clCreateCommandQueue(runtime_cl->context, in skc_runtime_cl_12_create_cq()
86 cq = clCreateCommandQueueWithProperties(runtime_cl->context, in skc_runtime_cl_12_create_cq()
93 return cq; in skc_runtime_cl_12_create_cq()
111 pool->cq = skc_runtime_host_perm_alloc(runtime,SKC_MEM_FLAGS_READ_WRITE, in skc_cq_pool_create()
112 pool->size * sizeof(*pool->cq)); in skc_cq_pool_create()
114 pool->cq[ii] = skc_runtime_cl_12_create_cq(runtime,pool); in skc_cq_pool_create()
116 pool->cq[size] = NULL; in skc_cq_pool_create()
131 skc_runtime_host_perm_free(runtime,pool->cq); in skc_cq_pool_dispose()
[all …]
Dextent_cl_12_unified.c55 cl_command_queue const cq,
60 void * hrw = clEnqueueMapBuffer(cq,extent->drw,
70 cl_command_queue const cq,
73 return skc_extent_thrw_tdrw_map_size(extent,extent->size,cq,event);
79 cl_command_queue const cq,
82 cl(EnqueueUnmapMemObject(cq,extent->drw,hrw,0,NULL,event));
121 cl_command_queue const cq, in skc_extent_phrw_pdrw_map_size() argument
126 void * hrw = clEnqueueMapBuffer(cq,extent->drw, in skc_extent_phrw_pdrw_map_size()
136 cl_command_queue const cq, in skc_extent_phrw_pdrw_map() argument
139 return skc_extent_phrw_pdrw_map_size(extent,extent->size,cq,event); in skc_extent_phrw_pdrw_map()
[all …]
Dextent_cl_12.h97 cl_command_queue const cq,
122 cl_command_queue const cq,
127 cl_command_queue const cq,
158 cl_command_queue const cq,
163 cl_command_queue const cq,
200 cl_command_queue const cq,
241 cl_command_queue const cq,
330 cl_command_queue const cq,
335 cl_command_queue const cq,
341 cl_command_queue const cq,
[all …]
/external/grpc-grpc/test/core/surface/
Dnum_external_connectivity_watchers_test.cc40 grpc_completion_queue* cq) { in channel_idle_start_watch() argument
46 channel, GRPC_CHANNEL_IDLE, connect_deadline, cq, (void*)(next_tag++)); in channel_idle_start_watch()
52 grpc_completion_queue* cq) { in channel_idle_poll_for_timeout() argument
54 cq, gpr_inf_future(GPR_CLOCK_REALTIME), nullptr); in channel_idle_poll_for_timeout()
76 grpc_completion_queue* cq = grpc_completion_queue_create_for_next(nullptr); in run_timeouts_test() local
79 channel_idle_start_watch(channel, cq); in run_timeouts_test()
80 channel_idle_poll_for_timeout(channel, cq); in run_timeouts_test()
85 channel_idle_start_watch(channel, cq); in run_timeouts_test()
88 channel_idle_poll_for_timeout(channel, cq); in run_timeouts_test()
95 channel_idle_start_watch(channel, cq); in run_timeouts_test()
[all …]
Dserver_test.cc84 grpc_completion_queue* cq = grpc_completion_queue_create_for_next(nullptr); in test_bind_server_twice() local
87 grpc_server_register_completion_queue(server1, cq, nullptr); in test_bind_server_twice()
88 grpc_server_register_completion_queue(server2, cq, nullptr); in test_bind_server_twice()
96 grpc_server_shutdown_and_notify(server1, cq, nullptr); in test_bind_server_twice()
97 grpc_server_shutdown_and_notify(server2, cq, nullptr); in test_bind_server_twice()
98 grpc_completion_queue_next(cq, gpr_inf_future(GPR_CLOCK_MONOTONIC), nullptr); in test_bind_server_twice()
99 grpc_completion_queue_next(cq, gpr_inf_future(GPR_CLOCK_MONOTONIC), nullptr); in test_bind_server_twice()
102 grpc_completion_queue_destroy(cq); in test_bind_server_twice()
122 grpc_completion_queue* cq = grpc_completion_queue_create_for_next(nullptr); in test_bind_server_to_addr() local
123 grpc_server_register_completion_queue(server, cq, nullptr); in test_bind_server_to_addr()
[all …]
/external/grpc-grpc/test/cpp/microbenchmarks/
Dbm_cq.cc40 CompletionQueue cq; in BM_CreateDestroyCpp() local
52 CompletionQueue cq(core_cq); in BM_CreateDestroyCpp2() local
80 CompletionQueue cq; in BM_Pass1Cpp() local
81 grpc_completion_queue* c_cq = cq.cq(); in BM_Pass1Cpp()
92 cq.Next(&tag, &ok); in BM_Pass1Cpp()
101 grpc_completion_queue* cq = grpc_completion_queue_create_for_next(nullptr); in BM_Pass1Core() local
106 GPR_ASSERT(grpc_cq_begin_op(cq, nullptr)); in BM_Pass1Core()
107 grpc_cq_end_op(cq, nullptr, GRPC_ERROR_NONE, DoneWithCompletionOnStack, in BM_Pass1Core()
110 grpc_completion_queue_next(cq, deadline, nullptr); in BM_Pass1Core()
112 grpc_completion_queue_destroy(cq); in BM_Pass1Core()
[all …]
Dfullstack_streaming_ping_pong.h72 service.RequestBidiStream(&svr_ctx, &response_rw, fixture->cq(), in BM_StreamingPingPong()
73 fixture->cq(), tag(0)); in BM_StreamingPingPong()
77 auto request_rw = stub->AsyncBidiStream(&cli_ctx, fixture->cq(), tag(1)); in BM_StreamingPingPong()
84 GPR_ASSERT(fixture->cq()->Next(&t, &ok)); in BM_StreamingPingPong()
100 GPR_ASSERT(fixture->cq()->Next(&t, &ok)); in BM_StreamingPingPong()
124 GPR_ASSERT(fixture->cq()->Next(&t, &ok)); in BM_StreamingPingPong()
164 service.RequestBidiStream(&svr_ctx, &response_rw, fixture->cq(), in BM_StreamingPingPongMsgs()
165 fixture->cq(), tag(0)); in BM_StreamingPingPongMsgs()
169 auto request_rw = stub->AsyncBidiStream(&cli_ctx, fixture->cq(), tag(1)); in BM_StreamingPingPongMsgs()
176 GPR_ASSERT(fixture->cq()->Next(&t, &ok)); in BM_StreamingPingPongMsgs()
[all …]
Dfullstack_streaming_pump.h53 service.RequestBidiStream(&svr_ctx, &response_rw, fixture->cq(), in BM_PumpStreamClientToServer()
54 fixture->cq(), tag(0)); in BM_PumpStreamClientToServer()
58 auto request_rw = stub->AsyncBidiStream(&cli_ctx, fixture->cq(), tag(1)); in BM_PumpStreamClientToServer()
63 GPR_ASSERT(fixture->cq()->Next(&t, &ok)); in BM_PumpStreamClientToServer()
74 GPR_ASSERT(fixture->cq()->Next(&t, &ok)); in BM_PumpStreamClientToServer()
87 GPR_ASSERT(fixture->cq()->Next(&t, &ok)); in BM_PumpStreamClientToServer()
97 GPR_ASSERT(fixture->cq()->Next(&t, &ok)); in BM_PumpStreamClientToServer()
122 service.RequestBidiStream(&svr_ctx, &response_rw, fixture->cq(), in BM_PumpStreamServerToClient()
123 fixture->cq(), tag(0)); in BM_PumpStreamServerToClient()
127 auto request_rw = stub->AsyncBidiStream(&cli_ctx, fixture->cq(), tag(1)); in BM_PumpStreamServerToClient()
[all …]
/external/grpc-grpc/test/cpp/common/
Dalarm_test.cc35 CompletionQueue cq; in TEST() local
38 alarm.Set(&cq, grpc_timeout_seconds_to_deadline(1), junk); in TEST()
43 cq.AsyncNext(&output_tag, &ok, grpc_timeout_seconds_to_deadline(10)); in TEST()
111 CompletionQueue cq; in TEST() local
118 std::thread t1([&alarm, &cq, &junk] { in TEST()
119 alarm.Set(&cq, grpc_timeout_seconds_to_deadline(1), junk); in TEST()
122 std::thread t2([&cq, &ok, &output_tag, &status] { in TEST()
124 cq.AsyncNext(&output_tag, &ok, grpc_timeout_seconds_to_deadline(10)); in TEST()
135 CompletionQueue cq; in TEST() local
137 Alarm alarm(&cq, grpc_timeout_seconds_to_deadline(1), junk); in TEST()
[all …]
/external/grpc-grpc/test/cpp/qps/
Dclient_async.cc53 virtual void StartNewClone(CompletionQueue* cq) = 0;
59 virtual void Start(CompletionQueue* cq, const ClientConfig& config) = 0;
85 void Start(CompletionQueue* cq, const ClientConfig& config) override { in Start() argument
87 StartInternal(cq); in Start()
111 void StartNewClone(CompletionQueue* cq) override { in StartNewClone() argument
114 clone->StartInternal(cq); in StartNewClone()
138 void StartInternal(CompletionQueue* cq) { in StartInternal() argument
139 cq_ = cq; in StartInternal()
186 auto* cq = cli_cqs_[t].get(); in AsyncClient() local
189 ctx->Start(cq, config); in AsyncClient()
[all …]
/external/grpc-grpc/test/core/end2end/
Dh2_ssl_session_reuse_test.cc48 grpc_server* server_create(grpc_completion_queue* cq, char* server_addr) { in server_create() argument
56 grpc_server_register_completion_queue(server, cq, nullptr); in server_create()
94 void do_round_trip(grpc_completion_queue* cq, grpc_server* server, in do_round_trip() argument
99 cq_verifier* cqv = cq_verifier_create(cq); in do_round_trip()
113 client, nullptr, GRPC_PROPAGATE_DEFAULTS, cq, in do_round_trip()
151 &request_metadata_recv, cq, cq, tag(101)); in do_round_trip()
208 void drain_cq(grpc_completion_queue* cq) { in drain_cq() argument
211 ev = grpc_completion_queue_next(cq, five_seconds_time(), nullptr); in drain_cq()
221 grpc_completion_queue* cq = grpc_completion_queue_create_for_next(nullptr); in TEST() local
224 grpc_server* server = server_create(cq, server_addr); in TEST()
[all …]
/external/grpc-grpc/test/core/end2end/tests/
Dconnectivity.cc33 grpc_completion_queue* cq; member
41 ev = grpc_completion_queue_next(ce->cq, gpr_inf_future(GPR_CLOCK_MONOTONIC), in child_thread()
51 cq_verifier* cqv = cq_verifier_create(f.cq); in test_connectivity()
66 ce.cq = f.cq; in test_connectivity()
83 f.client, GRPC_CHANNEL_IDLE, gpr_now(GPR_CLOCK_MONOTONIC), f.cq, tag(1)); in test_connectivity()
94 f.cq, tag(2)); in test_connectivity()
106 f.cq, tag(3)); in test_connectivity()
124 f.client, state, grpc_timeout_seconds_to_deadline(3), f.cq, tag(4)); in test_connectivity()
139 f.cq, tag(5)); in test_connectivity()
141 grpc_server_shutdown_and_notify(f.server, f.cq, tag(0xdead)); in test_connectivity()
[all …]
Dshutdown_finishes_tags.cc52 static void drain_cq(grpc_completion_queue* cq) { in drain_cq() argument
55 ev = grpc_completion_queue_next(cq, five_seconds_from_now(), nullptr); in drain_cq()
68 grpc_completion_queue_shutdown(f->cq); in end_test()
69 drain_cq(f->cq); in end_test()
70 grpc_completion_queue_destroy(f->cq); in end_test()
79 cq_verifier* cqv = cq_verifier_create(f.cq); in test_early_server_shutdown_finishes_tags()
91 &request_metadata_recv, f.cq, f.cq, tag(101))); in test_early_server_shutdown_finishes_tags()
92 grpc_server_shutdown_and_notify(f.server, f.cq, tag(1000)); in test_early_server_shutdown_finishes_tags()
/external/grpc-grpc/src/csharp/Grpc.Core/Internal/
DCompletionQueueSafeHandle.cs52 var cq = Native.grpcsharp_completion_queue_create_async(); in CreateAsync()
53 cq.completionRegistry = completionRegistry; in CreateAsync()
54 return cq; in CreateAsync()
120 readonly CompletionQueueSafeHandle cq; field
122 public UsageScope(CompletionQueueSafeHandle cq) in UsageScope()
124 this.cq = cq; in UsageScope()
125 this.cq.BeginOp(); in UsageScope()
130 cq.EndOp(); in Dispose()
/external/grpc-grpc/src/cpp/client/
Dchannel_cc.cc104 CompletionQueue* cq) { in CreateCall() argument
110 context->propagation_options_.c_bitmask(), cq->cq(), in CreateCall()
126 context->propagation_options_.c_bitmask(), cq->cq(), method_slice, in CreateCall()
136 return internal::Call(c_call, this, cq); in CreateCall()
178 CompletionQueue* cq, void* tag) { in NotifyOnStateChangeImpl() argument
181 cq->cq(), tag_saver); in NotifyOnStateChangeImpl()
186 CompletionQueue cq; in WaitForStateChangeImpl() local
189 NotifyOnStateChangeImpl(last_observed, deadline, &cq, nullptr); in WaitForStateChangeImpl()
190 cq.Next(&tag, &ok); in WaitForStateChangeImpl()
201 void TakeCQ(CompletionQueue* cq) { cq_ = cq; } in TakeCQ() argument
/external/grpc-grpc/test/cpp/end2end/
Dhybrid_end2end_test.cc47 bool VerifyReturnSuccess(CompletionQueue* cq, int i) { in VerifyReturnSuccess() argument
50 EXPECT_TRUE(cq->Next(&got_tag, &ok)); in VerifyReturnSuccess()
55 void Verify(CompletionQueue* cq, int i, bool expect_ok) { in Verify() argument
56 EXPECT_EQ(expect_ok, VerifyReturnSuccess(cq, i)); in Verify()
61 void HandleEcho(Service* service, ServerCompletionQueue* cq, bool dup_service) { in HandleEcho() argument
66 service->RequestEcho(&srv_ctx, &recv_request, &response_writer, cq, cq, in HandleEcho()
68 Verify(cq, 1, true); in HandleEcho()
74 Verify(cq, 2, true); in HandleEcho()
81 void HandleRawEcho(Service* service, ServerCompletionQueue* cq, in HandleRawEcho() argument
86 service->RequestEcho(&srv_ctx, &recv_buffer, &response_writer, cq, cq, in HandleRawEcho()
[all …]
/external/flatbuffers/tests/
Dmonster_test.grpc.fb.h39 …ontext* context, const flatbuffers::grpc::Message<Monster>& request, ::grpc::CompletionQueue* cq) { in AsyncStore() argument
40 …ncResponseReaderInterface< flatbuffers::grpc::Message<Stat>>>(AsyncStoreRaw(context, request, cq)); in AsyncStore()
42 …ontext* context, const flatbuffers::grpc::Message<Monster>& request, ::grpc::CompletionQueue* cq) { in PrepareAsyncStore() argument
43 …nseReaderInterface< flatbuffers::grpc::Message<Stat>>>(PrepareAsyncStoreRaw(context, request, cq)); in PrepareAsyncStore()
48 …context, const flatbuffers::grpc::Message<Stat>& request, ::grpc::CompletionQueue* cq, void* tag) { in AsyncRetrieve() argument
49 …eaderInterface< flatbuffers::grpc::Message<Monster>>>(AsyncRetrieveRaw(context, request, cq, tag)); in AsyncRetrieve()
51 …ntContext* context, const flatbuffers::grpc::Message<Stat>& request, ::grpc::CompletionQueue* cq) { in PrepareAsyncRetrieve() argument
52 …derInterface< flatbuffers::grpc::Message<Monster>>>(PrepareAsyncRetrieveRaw(context, request, cq)); in PrepareAsyncRetrieve()
57 …ext* context, flatbuffers::grpc::Message<Stat>* response, ::grpc::CompletionQueue* cq, void* tag) { in AsyncGetMaxHitPoint() argument
58 …terface< flatbuffers::grpc::Message<Monster>>>(AsyncGetMaxHitPointRaw(context, response, cq, tag)); in AsyncGetMaxHitPoint()
[all …]
/external/autotest/
DCOMMIT-QUEUE.ini11 pre-cq-configs: betty-arcnext-pre-cq betty-pre-cq moblab-generic-vm-pre-cq
13 # Allow union of pre-cq configs from subdirectory
14 union-pre-cq-sub-configs: yes
15 # Some sub-configs enalbe submit-in-pre-cq, but we do not want that option to be
17 submit-in-pre-cq: no key
/external/grpc-grpc/src/csharp/Grpc.Core/
DServer.cs79 foreach (var cq in environment.CompletionQueues) in Server()
81 this.handle.RegisterCompletionQueue(cq); in Server()
159 foreach (var cq in environment.CompletionQueues) in Start()
161 AllowOneRpc(cq); in Start()
219 var cq = environment.CompletionQueues.First(); // any cq will do in ShutdownInternalAsync()
220 handle.ShutdownAndNotify(HandleServerShutdown, cq); in ShutdownInternalAsync()
299 private void AllowOneRpc(CompletionQueueSafeHandle cq) in AllowOneRpc() argument
304 handle.RequestCall((success, ctx) => HandleNewServerRpc(success, ctx, cq), cq); in AllowOneRpc()
337 …private async Task HandleCallAsync(ServerRpcNew newRpc, CompletionQueueSafeHandle cq, Action conti… in HandleCallAsync() argument
346 await callHandler.HandleCall(newRpc, cq).ConfigureAwait(false); in HandleCallAsync()
[all …]
/external/grpc-grpc/test/core/end2end/fuzzers/
Dserver_fuzzer.cc57 grpc_completion_queue* cq = grpc_completion_queue_create_for_next(nullptr); in LLVMFuzzerTestOneInput() local
58 grpc_server_register_completion_queue(server, cq, nullptr); in LLVMFuzzerTestOneInput()
77 &request_metadata1, cq, cq, tag(1))); in LLVMFuzzerTestOneInput()
83 ev = grpc_completion_queue_next(cq, gpr_inf_past(GPR_CLOCK_REALTIME), in LLVMFuzzerTestOneInput()
104 grpc_server_shutdown_and_notify(server, cq, tag(0xdead)); in LLVMFuzzerTestOneInput()
118 ev = grpc_completion_queue_next(cq, gpr_inf_past(GPR_CLOCK_REALTIME), in LLVMFuzzerTestOneInput()
125 grpc_completion_queue_shutdown(cq); in LLVMFuzzerTestOneInput()
128 ev = grpc_completion_queue_next(cq, gpr_inf_past(GPR_CLOCK_REALTIME), in LLVMFuzzerTestOneInput()
136 grpc_completion_queue_destroy(cq); in LLVMFuzzerTestOneInput()

12345678910>>...24