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

12 3

  /external/tensorflow/tensorflow/contrib/gdr/
gdr_rendezvous_mgr.cc 43 const Rendezvous::Args& recv_args, int64 step_id,
49 req_.set_step_id(step_id);
128 GdrRemoteRendezvous(const WorkerEnv* env, int64 step_id,
130 : BaseRemoteRendezvous(env, step_id),
202 BaseRemoteRendezvous* GdrRendezvousMgr::Create(int64 step_id,
204 return new GdrRemoteRendezvous(worker_env, step_id, remote_memory_manager_);
  /external/tensorflow/tensorflow/core/distributed_runtime/rpc/
rpc_rendezvous_mgr.cc 42 RpcRemoteRendezvous(const WorkerEnv* env, int64 step_id)
43 : BaseRemoteRendezvous(env, step_id) {}
61 void Init(WorkerInterface* wi, int64 step_id, StringPiece key,
69 req_.set_step_id(step_id);
268 BaseRemoteRendezvous* RpcRendezvousMgr::Create(int64 step_id,
270 return new RpcRemoteRendezvous(worker_env, step_id);
grpc_worker_cache.cc 83 bool RetrieveLogs(int64 step_id, StepStats* ss) override {
84 return logger_.RetrieveLogs(step_id, ss);
grpc_worker_service.cc 374 const int64 step_id = request->step_id(); local
376 TRACEPRINTF("RecvTensor: %lld %s", step_id, key.c_str());
392 opts->SetCancelCallback([this, step_id]() { AbortStep(step_id); });
394 step_id, parsed,
454 for (const auto& step_id : request->fetch_step_id()) {
455 session_mgr->RetrieveLogs(step_id, response);
grpc_remote_worker.cc 130 int64 step_id = request->step_id();
157 logger_->RecordRecvTensor(step_id, send_start_usec, end_usec,
  /external/tensorflow/tensorflow/core/distributed_runtime/
graph_mgr.cc 335 Status GraphMgr::SendInputs(const int64 step_id, const NamedTensors& in) {
336 Rendezvous* rendezvous = worker_env_->rendezvous_mgr->Find(step_id);
351 Status GraphMgr::RecvOutputs(const int64 step_id, NamedTensors* out) {
352 Rendezvous* rendezvous = worker_env_->rendezvous_mgr->Find(step_id);
358 void GraphMgr::RecvOutputsAsync(const int64 step_id, NamedTensors* out,
360 Rendezvous* rendezvous = worker_env_->rendezvous_mgr->Find(step_id);
381 void GraphMgr::ExecuteAsync(const string& handle, const int64 step_id,
415 RemoteRendezvous* rendezvous = worker_env_->rendezvous_mgr->Find(step_id);
438 StartParallelExecutors(handle, step_id, item, rendezvous, collector,
447 void GraphMgr::StartParallelExecutors(const string& handle, int64 step_id,
    [all...]
session_mgr.cc 143 void SessionMgr::RetrieveLogs(tensorflow::int64 step_id,
151 if (worker_cache->RetrieveLogs(step_id, &step_stats)) {
153 labeled_step_stats->set_step_id(step_id);
164 if (worker_cache->RetrieveLogs(step_id, &step_stats)) {
166 labeled_step_stats->set_step_id(step_id);
master_session.cc 130 void RetrieveLogs(int64 step_id, StepStats* ss) {
132 worker_cache_->RetrieveLogs(step_id, ss);
136 req.add_fetch_step_id(step_id);
145 [step_id, ss, resp, &scoped_mu, &waiting_for,
151 if (step_id != lss.step_id()) {
152 LOG(ERROR) << "Wrong step_id in LoggingResponse";
176 Status RunPartitions(const MasterEnv* env, int64 step_id,
182 // Calls workers to cleanup states for the step "step_id". Calls
184 void CleanupPartitionsAsync(int64 step_id, StatusCallback done)
1336 uint64 step_id = (random::New64() & ((1uLL << 56) - 1)) | (1uLL << 56); local
1610 const uint64 step_id = (random::New64() & ((1uLL << 56) - 1)) | (1uLL << 56); local
    [all...]
worker_session.cc 70 bool RetrieveLogs(int64 step_id, StepStats* ss) override {
71 return wrapped_->RetrieveLogs(step_id, ss);
session_mgr.h 62 void RetrieveLogs(tensorflow::int64 step_id, LoggingResponse* response);
master_session.h 161 uint64 step_id; member in struct:tensorflow::MasterSession::RunState
169 const uint64 step_id, const int64 count);
message_wrappers.h 255 // The master generates a global unique `step_id` to distinguish
257 // (e.g., send/recv ops) with each other using `step_id` to
259 virtual int64 step_id() const = 0;
297 virtual void set_step_id(int64 step_id) = 0;
317 int64 step_id() const override;
332 void set_step_id(int64 step_id) override;
368 int64 step_id() const override;
383 void set_step_id(int64 step_id) override;
404 int64 step_id() const override;
message_wrappers.cc 297 int64 InMemoryRunGraphRequest::step_id() const { return step_id_; } function in class:tensorflow::InMemoryRunGraphRequest
299 void InMemoryRunGraphRequest::set_step_id(int64 step_id) { step_id_ = step_id; }
368 proto_version_->set_step_id(step_id());
400 int64 MutableProtoRunGraphRequest::step_id() const { function in class:tensorflow::MutableProtoRunGraphRequest
401 return request_.step_id();
404 void MutableProtoRunGraphRequest::set_step_id(int64 step_id) {
405 request_.set_step_id(step_id);
495 int64 ProtoRunGraphRequest::step_id() const { return request_->step_id(); } function in class:tensorflow::ProtoRunGraphRequest
    [all...]
cluster_function_library_runtime.cc 182 const uint64 step_id = (random::New64() & ((1uLL << 56) - 1)) | (1uLL << 56); local
183 req.set_step_id(step_id);
  /external/tensorflow/tensorflow/core/kernels/data/
captured_function.cc 197 f_opts.step_id = CapturedFunction::generate_step_id();
198 ScopedStepContainer step_container(f_opts.step_id, [ctx](const string& name) {
231 f_opts.step_id = CapturedFunction::generate_step_id();
232 ScopedStepContainer step_container(f_opts.step_id, [ctx](const string& name) {
276 f_opts.step_id = CapturedFunction::generate_step_id();
279 f_opts.step_id, [resource_mgr](const string& name) {
  /external/tensorflow/tensorflow/compiler/tf2xla/kernels/
function_ops.cc 76 opts.step_id = ctx->step_id();
  /external/tensorflow/tensorflow/core/common_runtime/gpu/
gpu_event_mgr.h 62 // operation and step_id are only populated when
65 int64 step_id; member in struct:tensorflow::EventMgr::BufRec
123 iu.bufrec.step_id, iu.bufrec.buf,
gpu_event_mgr.cc 69 ue->bufrec.step_id, ue->bufrec.buf,
  /external/tensorflow/tensorflow/core/common_runtime/
executor.h 59 // "step_id" is a process-wide unique identifier for the step being
60 // run. Executors on different devices may receive the same step_id
62 // step_id is used for tracking resource usage of a given step.
84 int64 step_id = 0; member in struct:tensorflow::Executor::Args
direct_session.cc 472 args.step_id = step_id_counter_.fetch_add(1);
482 run_options.debug_options(), args.step_id, executor_step_count,
510 RunState run_state(args.step_id, &devices_);
533 LogMemory::RecordStep(args.step_id, run_state_args.handle);
740 args.step_id = step_id_counter_.fetch_add(1);
742 new RunState(input_names, output_names, args.step_id, &devices_);
775 LogMemory::RecordStep(args.step_id, run_state_args.handle);
    [all...]
direct_session.h 175 RunState(int64 step_id, const std::vector<Device*>* devices);
178 const std::vector<string>& pending_output_names, int64 step_id,
  /external/tensorflow/tensorflow/core/kernels/
function_ops.cc 244 opts.step_id = ctx->step_id();
318 opts.step_id = ctx->step_id();
critical_section.cc 183 opts_.step_id = CapturedFunction::generate_step_id();
185 new ScopedStepContainer(opts_.step_id, [this](const string& name) {
functional_ops.cc 100 opts->step_id = ctx->step_id();
  /external/tensorflow/tensorflow/contrib/verbs/
rdma.h 107 // type|name_size|name|step_id|request_index|remote_addr/checksum|rkey|...
239 RdmaTensorRequest(uint32_t index, const string& key, int64 step_id,
432 const string& key, int64 step_id, Device* dst_dev,

Completed in 289 milliseconds

12 3