Home
last modified time | relevance | path

Searched refs:rpc (Results 1 – 25 of 492) sorted by relevance

12345678910>>...20

/external/grpc-grpc/src/python/grpcio_tests/tests/testing/
D_client_test.py57 invocation_metadata, request, rpc = (
60 rpc.send_initial_metadata(())
61 rpc.terminate(_application_common.UNARY_UNARY_RESPONSE, (),
73 invocation_metadata, request, rpc = (
76 rpc.send_initial_metadata(())
77 rpc.terminate((), grpc.StatusCode.OK, '')
88 invocation_metadata, rpc = self._real_time_channel.take_stream_unary(
90 rpc.send_initial_metadata(())
91 first_request = rpc.take_request()
92 second_request = rpc.take_request()
[all …]
D_server_test.py41 rpc = self._real_time_server.invoke_unary_unary(
44 initial_metadata = rpc.initial_metadata()
45 response, trailing_metadata, code, details = rpc.termination()
51 rpc = self._real_time_server.invoke_unary_stream(
54 initial_metadata = rpc.initial_metadata()
55 trailing_metadata, code, details = rpc.termination()
60 rpc = self._real_time_server.invoke_stream_unary(
62 rpc.send_request(_application_common.STREAM_UNARY_REQUEST)
63 rpc.send_request(_application_common.STREAM_UNARY_REQUEST)
64 rpc.send_request(_application_common.STREAM_UNARY_REQUEST)
[all …]
/external/ltp/testcases/network/rpc/rpc-tirpc/
D.gitignore15 /tests_pack/rpc_suite/rpc/rpc_stdcall_clnt_control/rpc_clnt_control
16 /tests_pack/rpc_suite/rpc/rpc_stdcall_clnt_control/rpc_clnt_control_dataint
17 /tests_pack/rpc_suite/rpc/rpc_stdcall_svc_sendreply/rpc_svc_sendreply
18 /tests_pack/rpc_suite/rpc/rpc_stdcall_svc_sendreply/rpc_svc_sendreply_client
19 /tests_pack/rpc_suite/rpc/rpc_createdestroy_clntraw_create/rpc_clntraw_create_performance
20 /tests_pack/rpc_suite/rpc/rpc_createdestroy_clntraw_create/rpc_clntraw_create
21 /tests_pack/rpc_suite/rpc/rpc_createdestroy_clntraw_create/rpc_clntraw_create_complex
22 /tests_pack/rpc_suite/rpc/rpc_err_clnt_sperrno/rpc_clnt_sperrno
23 /tests_pack/rpc_suite/rpc/rpc_addrmanagmt_pmap_getmaps/rpc_pmap_getmaps
24 /tests_pack/rpc_suite/rpc/rpc_regunreg_xprt_register/rpc_xprt_register
[all …]
/external/grpc-grpc/src/python/grpcio_testing/grpc_testing/_server/
D_service.py20 def __init__(self, rpc, handler): argument
21 self._rpc = rpc
45 def _unary_response(argument, implementation, rpc, servicer_context): argument
49 rpc.application_exception_abort(exception)
51 rpc.unary_response_complete(response)
54 def _stream_response(argument, implementation, rpc, servicer_context): argument
58 rpc.application_exception_abort(exception)
64 rpc.stream_response_complete()
67 rpc.application_exception_abort(exception)
70 rpc.stream_response(response)
[all …]
D_server.py33 def service(implementation, rpc, servicer_context): argument
34 _service.unary_unary(implementation, rpc, request, servicer_context)
41 def service(implementation, rpc, servicer_context): argument
42 _service.unary_stream(implementation, rpc, request, servicer_context)
49 def service(implementation, rpc, servicer_context): argument
50 _service.stream_unary(implementation, rpc, handler, servicer_context)
57 def service(implementation, rpc, servicer_context): argument
58 _service.stream_stream(implementation, rpc, handler, servicer_context)
73 rpc = _rpc.Rpc(handler, invocation_metadata)
74 if handler.add_termination_callback(rpc.extrinsic_abort):
[all …]
/external/grpc-grpc/examples/ruby/pubsub/tech/pubsub/proto/
Dpubsub_services.rb35 rpc :CreateTopic, Topic, Topic
36 rpc :Publish, PublishRequest, Google::Protobuf::Empty
37 rpc :PublishBatch, PublishBatchRequest, PublishBatchResponse
38 rpc :GetTopic, GetTopicRequest, Topic
39 rpc :ListTopics, ListTopicsRequest, ListTopicsResponse
40 rpc :DeleteTopic, DeleteTopicRequest, Google::Protobuf::Empty
56 rpc :CreateSubscription, Subscription, Subscription
57 rpc :GetSubscription, GetSubscriptionRequest, Subscription
58 rpc :ListSubscriptions, ListSubscriptionsRequest, ListSubscriptionsResponse
59 rpc :DeleteSubscription, DeleteSubscriptionRequest, Google::Protobuf::Empty
[all …]
/external/swiftshader/third_party/llvm-7.0/llvm/include/llvm/ExecutionEngine/Orc/
DOrcRemoteTargetRPCAPI.h77 namespace rpc {
174 : public rpc::Function<RegisterEHFrames,
182 : public rpc::Function<DeregisterEHFrames,
196 : public rpc::Function<CallIntVoid, int32_t(JITTargetAddress Addr)> {
204 : public rpc::Function<CallMain, int32_t(JITTargetAddress Addr,
213 : public rpc::Function<CallVoidVoid, void(JITTargetAddress FnAddr)> {
225 : public rpc::Function<CreateRemoteAllocator,
233 : public rpc::Function<DestroyRemoteAllocator,
241 : public rpc::Function<ReadMem, std::vector<uint8_t>(JITTargetAddress Src,
249 : public rpc::Function<ReserveMem,
[all …]
/external/libevent/
Devrpc.c95 struct evrpc *rpc; in evrpc_free() local
100 while ((rpc = TAILQ_FIRST(&base->registered_rpcs)) != NULL) { in evrpc_free()
101 r = evrpc_unregister_rpc(base, rpc->uri); in evrpc_free()
228 evrpc_register_rpc(struct evrpc_base *base, struct evrpc *rpc, in evrpc_register_rpc() argument
231 char *constructed_uri = evrpc_construct_uri(rpc->uri); in evrpc_register_rpc()
233 rpc->base = base; in evrpc_register_rpc()
234 rpc->cb = cb; in evrpc_register_rpc()
235 rpc->cb_arg = cb_arg; in evrpc_register_rpc()
237 TAILQ_INSERT_TAIL(&base->registered_rpcs, rpc, next); in evrpc_register_rpc()
242 rpc); in evrpc_register_rpc()
[all …]
/external/grpc-grpc/src/ruby/spec/generic/
Dservice_spec.rb72 rpc :AnRpc, GoodMsg, GoodMsg
82 rpc :AnRpc, GoodMsg, GoodMsg
130 rpc :AnRpc, GoodMsg
138 rpc :AnRpc
149 rpc :AnRpc, GoodMsg, Object
166 rpc :AnRpc, OnlyMarshal, GoodMsg
182 rpc :AnRpc, GoodMsg, OnlyUnmarshal
193 rpc :AnRpc, GoodMsg, GoodMsg
205 rpc :AnRpc, EncodeDecodeMsg, EncodeDecodeMsg
216 rpc :AnRpc, GoodMsg, GoodMsg
[all …]
/external/grpc-grpc/src/ruby/pb/src/proto/grpc/testing/
Dtest_services_pb.rb39 rpc :EmptyCall, Empty, Empty
41 rpc :UnaryCall, SimpleRequest, SimpleResponse
45 rpc :CacheableUnaryCall, SimpleRequest, SimpleResponse
48 rpc :StreamingOutputCall, StreamingOutputCallRequest, stream(StreamingOutputCallResponse)
51 rpc :StreamingInputCall, stream(StreamingInputCallRequest), StreamingInputCallResponse
55 rpc :FullDuplexCall, stream(StreamingOutputCallRequest), stream(StreamingOutputCallResponse)
60 rpc :HalfDuplexCall, stream(StreamingOutputCallRequest), stream(StreamingOutputCallResponse)
63 rpc :UnimplementedCall, Empty, Empty
80 rpc :UnimplementedCall, Empty, Empty
95 rpc :Start, ReconnectParams, Empty
[all …]
/external/tensorflow/tensorflow/core/distributed_runtime/rpc/eager/
DBUILD28 "//tensorflow/core/distributed_runtime/rpc:grpc_channel",
29 "//tensorflow/core/distributed_runtime/rpc:grpc_client_cq_tag",
30 "//tensorflow/core/distributed_runtime/rpc:grpc_state",
31 "//tensorflow/core/distributed_runtime/rpc:grpc_util",
32 "//tensorflow/core/distributed_runtime/rpc/eager:grpc_eager_service",
46 "//tensorflow/core/distributed_runtime/rpc:async_service_interface",
47 "//tensorflow/core/distributed_runtime/rpc:grpc_call",
48 "//tensorflow/core/distributed_runtime/rpc:grpc_channel",
49 "//tensorflow/core/distributed_runtime/rpc:grpc_util",
50 "//tensorflow/core/distributed_runtime/rpc:grpc_worker_cache",
[all …]
/external/tensorflow/tensorflow/core/protobuf/
Dworker_service.proto40 rpc GetStatus(GetStatusRequest) returns (GetStatusResponse);
43 rpc CreateWorkerSession(CreateWorkerSessionRequest)
47 rpc DeleteWorkerSession(DeleteWorkerSessionRequest)
51 rpc RegisterGraph(RegisterGraphRequest) returns (RegisterGraphResponse);
54 rpc DeregisterGraph(DeregisterGraphRequest) returns (DeregisterGraphResponse);
57 rpc RunGraph(RunGraphRequest) returns (RunGraphResponse);
60 rpc CleanupGraph(CleanupGraphRequest) returns (CleanupGraphResponse);
63 rpc CleanupAll(CleanupAllRequest) returns (CleanupAllResponse);
66 rpc RecvTensor(RecvTensorRequest) returns (RecvTensorResponse) {
71 rpc Logging(LoggingRequest) returns (LoggingResponse);
[all …]
/external/nos/host/generic/nugget/proto/nugget/app/avb/
Davb.proto30 rpc GetState (GetStateRequest) returns (GetStateResponse);
31 rpc Load (LoadRequest) returns (LoadResponse);
32 rpc Store (StoreRequest) returns (StoreResponse);
33 rpc GetLock (GetLockRequest) returns (GetLockResponse);
34 rpc CarrierLock (CarrierLockRequest) returns (CarrierLockResponse);
35 rpc CarrierUnlock (CarrierUnlockRequest) returns (CarrierUnlockResponse);
36 rpc SetDeviceLock (SetDeviceLockRequest) returns (SetDeviceLockResponse);
37 rpc SetBootLock (SetBootLockRequest) returns (SetBootLockResponse);
38 rpc SetOwnerLock (SetOwnerLockRequest) returns (SetOwnerLockResponse);
39 rpc SetProduction (SetProductionRequest) returns (SetProductionResponse);
[all …]
/external/tensorflow/tensorflow/c/eager/
DBUILD64 "//tensorflow/core/distributed_runtime/rpc/eager:grpc_eager_client",
65 "//tensorflow/core/distributed_runtime/rpc:grpc_channel",
66 "//tensorflow/core/distributed_runtime/rpc:grpc_server_lib",
67 "//tensorflow/core/distributed_runtime/rpc:grpc_worker_cache",
68 "//tensorflow/core/distributed_runtime/rpc:grpc_worker_service",
69 "//tensorflow/core/distributed_runtime/rpc:rpc_rendezvous_mgr",
107 "//tensorflow/core/distributed_runtime/rpc:grpc_channel",
108 "//tensorflow/core/distributed_runtime/rpc:grpc_server_lib",
109 "//tensorflow/core/distributed_runtime/rpc:grpc_worker_cache",
110 "//tensorflow/core/distributed_runtime/rpc:grpc_worker_service",
[all …]
/external/grpc-grpc-java/protobuf/src/main/java/io/grpc/protobuf/
DStatusProto.java35 private static final Metadata.Key<com.google.rpc.Status> STATUS_DETAILS_KEY =
38 ProtoLiteUtils.metadataMarshaller(com.google.rpc.Status.getDefaultInstance()));
51 public static StatusRuntimeException toStatusRuntimeException(com.google.rpc.Status statusProto) { in toStatusRuntimeException()
69 com.google.rpc.Status statusProto, Metadata metadata) { in toStatusRuntimeException()
84 public static StatusException toStatusException(com.google.rpc.Status statusProto) { in toStatusException()
102 com.google.rpc.Status statusProto, Metadata metadata) { in toStatusException()
106 private static Status toStatus(com.google.rpc.Status statusProto) { in toStatus()
112 private static Metadata toMetadata(com.google.rpc.Status statusProto) { in toMetadata()
118 private static Metadata toMetadata(com.google.rpc.Status statusProto, Metadata metadata) { in toMetadata()
134 public static com.google.rpc.Status fromThrowable(Throwable t) { in fromThrowable()
[all …]
/external/nos/host/generic/nugget/proto/nugget/app/keymaster/
Dkeymaster.proto50 rpc AddRngEntropy (AddRngEntropyRequest) returns (AddRngEntropyResponse);
51 rpc GenerateKey (GenerateKeyRequest) returns (GenerateKeyResponse);
52 rpc GetKeyCharacteristics (GetKeyCharacteristicsRequest) returns (GetKeyCharacteristicsResponse);
53 rpc ImportKey (ImportKeyRequest) returns (ImportKeyResponse);
54 rpc ExportKey (ExportKeyRequest) returns (ExportKeyResponse);
55 rpc StartAttestKey (StartAttestKeyRequest) returns (StartAttestKeyResponse);
56 rpc UpgradeKey (UpgradeKeyRequest) returns (UpgradeKeyResponse);
57 rpc DeleteKey (DeleteKeyRequest) returns (DeleteKeyResponse);
58 rpc DeleteAllKeys (DeleteAllKeysRequest) returns (DeleteAllKeysResponse);
59 rpc DestroyAttestationIds (DestroyAttestationIdsRequest) returns (DestroyAttestationIdsResponse);
[all …]
/external/tensorflow/tensorflow/contrib/rpc/
DBUILD10 name = "rpc",
14 deps = ["//tensorflow/contrib/rpc/python/ops:rpc_op_py"],
21 otherwise = ["//tensorflow/contrib/rpc/python/kernel_tests:libtestexample.so"],
24 ":rpc",
25 "//tensorflow/contrib/rpc/python/kernel_tests:py_test_deps",
26 "//tensorflow/contrib/rpc/python/kernel_tests:rpc_op_test_base",
27 "//tensorflow/contrib/rpc/python/kernel_tests:rpc_op_test_servicer",
/external/tensorflow/tensorflow/compiler/xla/rpc/
Dxla_service.proto57 rpc Unregister(UnregisterRequest) returns (UnregisterResponse) {
62 rpc DeconstructTuple(DeconstructTupleRequest)
70 rpc Unpack(UnpackRequest) returns (UnpackResponse) {
74 rpc GetShape(GetShapeRequest) returns (GetShapeResponse) {
78 rpc GetComputationGraphStats(ComputationGraphStatsRequest)
83 rpc LoadData(LoadDataRequest) returns (LoadDataResponse) {
87 rpc TransferToClient(TransferToClientRequest)
93 rpc TransferToServer(TransferToServerRequest)
98 rpc TransferToInfeed(TransferToInfeedRequest)
103 rpc TransferFromOutfeed(TransferFromOutfeedRequest)
[all …]
/external/perfetto/protos/perfetto/ipc/
Dconsumer_port.proto33 // rpc CreateBuffers(CreateBuffersRequest) returns (CreateBuffersResponse) {}
44 rpc EnableTracing(EnableTracingRequest) returns (EnableTracingResponse) {}
47 rpc DisableTracing(DisableTracingRequest) returns (DisableTracingResponse) {}
54 rpc ReadBuffers(ReadBuffersRequest) returns (stream ReadBuffersResponse) {}
58 rpc FreeBuffers(FreeBuffersRequest) returns (FreeBuffersResponse) {}
67 rpc Flush(FlushRequest) returns (FlushResponse) {}
75 rpc StartTracing(StartTracingRequest) returns (StartTracingResponse) {}
79 rpc ChangeTraceConfig(ChangeTraceConfigRequest)
85 rpc Detach(DetachRequest) returns (DetachResponse) {}
91 rpc Attach(AttachRequest) returns (AttachResponse) {}
[all …]
Dproducer_port.proto30 rpc InitializeConnection(InitializeConnectionRequest)
34 rpc RegisterDataSource(RegisterDataSourceRequest)
38 rpc UnregisterDataSource(UnregisterDataSourceRequest)
45 rpc CommitData(protos.CommitDataRequest) returns (CommitDataResponse) {}
49 rpc GetAsyncCommand(GetAsyncCommandRequest)
57 rpc RegisterTraceWriter(RegisterTraceWriterRequest)
62 rpc UnregisterTraceWriter(UnregisterTraceWriterRequest)
68 rpc NotifyDataSourceStarted(NotifyDataSourceStartedRequest)
74 rpc NotifyDataSourceStopped(NotifyDataSourceStoppedRequest)
80 rpc ActivateTriggers(ActivateTriggersRequest)
[all …]
/external/grpc-grpc-java/protobuf/src/test/java/io/grpc/protobuf/
DStatusProtoTest.java47 com.google.rpc.Status extractedStatusProto = StatusProto.fromThrowable(sre); in toStatusRuntimeException()
57 com.google.rpc.Status extractedStatusProto = StatusProto.fromThrowable(sre); in toStatusRuntimeExceptionWithMetadata_shouldIncludeMetadata()
89 com.google.rpc.Status extractedStatusProto = StatusProto.fromThrowable(se); in toStatusException()
99 com.google.rpc.Status extractedStatusProto = StatusProto.fromThrowable(se); in toStatusExceptionWithMetadata_shouldIncludeMetadata()
150 com.google.rpc.Status extractedStatusProto = StatusProto.fromThrowable(sre); in fromThrowableWithNestedStatusRuntimeException()
151 com.google.rpc.Status extractedStatusProtoFromNestedSre = StatusProto.fromThrowable(nestedSre); in fromThrowableWithNestedStatusRuntimeException()
161 com.google.rpc.Status extractedStatusProto = StatusProto.fromThrowable(se); in fromThrowableWithNestedStatusException()
162 com.google.rpc.Status extractedStatusProtoFromNestedSe = StatusProto.fromThrowable(nestedSe); in fromThrowableWithNestedStatusException()
177 private static final com.google.rpc.Status STATUS_PROTO =
178 com.google.rpc.Status.newBuilder()
[all …]
/external/python/cpython3/Lib/idlelib/idle_test/
Dtest_rpc.py3 from idlelib import rpc
12 func, (cbytes,) = rpc.pickle_code(f.__code__)
13 self.assertIs(func, rpc.unpickle_code)
15 code = rpc.unpickle_code(cbytes)
20 rpc.CodePickler.dispatch_table)
25 self.assertIn(b'test_rpc.py', rpc.dumps(f.__code__))
/external/tensorflow/tensorflow/contrib/rpc/python/kernel_tests/
Dtest_example.proto5 package tensorflow.contrib.rpc;
14 rpc Increment(TestCase) returns (TestCase) {
18 rpc SleepForever(TestCase) returns (TestCase) {
22 rpc SometimesSleepForever(TestCase) returns (TestCase) {
26 rpc AlwaysFailWithInvalidArgument(TestCase) returns (TestCase) {
30 rpc SometimesFailWithInvalidArgument(TestCase) returns (TestCase) {
/external/grpc-grpc/src/proto/grpc/testing/
Decho.proto23 rpc Echo(EchoRequest) returns (EchoResponse);
24 rpc RequestStream(stream EchoRequest) returns (EchoResponse);
25 rpc ResponseStream(EchoRequest) returns (stream EchoResponse);
26 rpc BidiStream(stream EchoRequest) returns (stream EchoResponse);
27 rpc Unimplemented(EchoRequest) returns (EchoResponse);
31 rpc Unimplemented(EchoRequest) returns (EchoResponse);
34 // A service without any rpc defined to test coverage.
Dtest.proto30 rpc EmptyCall(grpc.testing.Empty) returns (grpc.testing.Empty);
33 rpc UnaryCall(SimpleRequest) returns (SimpleResponse);
38 rpc CacheableUnaryCall(SimpleRequest) returns (SimpleResponse);
42 rpc StreamingOutputCall(StreamingOutputCallRequest)
47 rpc StreamingInputCall(stream StreamingInputCallRequest)
53 rpc FullDuplexCall(stream StreamingOutputCallRequest)
60 rpc HalfDuplexCall(stream StreamingOutputCallRequest)
65 rpc UnimplementedCall(grpc.testing.Empty) returns (grpc.testing.Empty);
72 rpc UnimplementedCall(grpc.testing.Empty) returns (grpc.testing.Empty);
77 rpc Start(grpc.testing.ReconnectParams) returns (grpc.testing.Empty);
[all …]

12345678910>>...20