Add MSVC support for FOLLY_FINAL and FOLLY_OVERRIDE
[folly.git] / folly / Subprocess.cpp
1 /*
2  * Copyright 2015 Facebook, Inc.
3  *
4  * Licensed under the Apache License, Version 2.0 (the "License");
5  * you may not use this file except in compliance with the License.
6  * You may obtain a copy of the License at
7  *
8  *   http://www.apache.org/licenses/LICENSE-2.0
9  *
10  * Unless required by applicable law or agreed to in writing, software
11  * distributed under the License is distributed on an "AS IS" BASIS,
12  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
13  * See the License for the specific language governing permissions and
14  * limitations under the License.
15  */
16
17 #ifndef _GNU_SOURCE
18 #define _GNU_SOURCE
19 #endif
20
21 #include <folly/Subprocess.h>
22
23 #if __linux__
24 #include <sys/prctl.h>
25 #endif
26 #include <fcntl.h>
27 #include <poll.h>
28
29 #include <unistd.h>
30
31 #include <array>
32 #include <algorithm>
33 #include <system_error>
34
35 #include <boost/container/flat_set.hpp>
36 #include <boost/range/adaptors.hpp>
37
38 #include <glog/logging.h>
39
40 #include <folly/Conv.h>
41 #include <folly/Exception.h>
42 #include <folly/ScopeGuard.h>
43 #include <folly/String.h>
44 #include <folly/io/Cursor.h>
45
46 extern char** environ;
47
48 constexpr int kExecFailure = 127;
49 constexpr int kChildFailure = 126;
50
51 namespace folly {
52
53 ProcessReturnCode::ProcessReturnCode(ProcessReturnCode&& p) noexcept
54   : rawStatus_(p.rawStatus_) {
55   p.rawStatus_ = ProcessReturnCode::RV_NOT_STARTED;
56 }
57
58 ProcessReturnCode& ProcessReturnCode::operator=(ProcessReturnCode&& p)
59     noexcept {
60   rawStatus_ = p.rawStatus_;
61   p.rawStatus_ = ProcessReturnCode::RV_NOT_STARTED;
62   return *this;
63 }
64
65 ProcessReturnCode::State ProcessReturnCode::state() const {
66   if (rawStatus_ == RV_NOT_STARTED) return NOT_STARTED;
67   if (rawStatus_ == RV_RUNNING) return RUNNING;
68   if (WIFEXITED(rawStatus_)) return EXITED;
69   if (WIFSIGNALED(rawStatus_)) return KILLED;
70   throw std::runtime_error(to<std::string>(
71       "Invalid ProcessReturnCode: ", rawStatus_));
72 }
73
74 void ProcessReturnCode::enforce(State expected) const {
75   State s = state();
76   if (s != expected) {
77     throw std::logic_error(to<std::string>(
78       "Bad use of ProcessReturnCode; state is ", s, " expected ", expected
79     ));
80   }
81 }
82
83 int ProcessReturnCode::exitStatus() const {
84   enforce(EXITED);
85   return WEXITSTATUS(rawStatus_);
86 }
87
88 int ProcessReturnCode::killSignal() const {
89   enforce(KILLED);
90   return WTERMSIG(rawStatus_);
91 }
92
93 bool ProcessReturnCode::coreDumped() const {
94   enforce(KILLED);
95   return WCOREDUMP(rawStatus_);
96 }
97
98 std::string ProcessReturnCode::str() const {
99   switch (state()) {
100   case NOT_STARTED:
101     return "not started";
102   case RUNNING:
103     return "running";
104   case EXITED:
105     return to<std::string>("exited with status ", exitStatus());
106   case KILLED:
107     return to<std::string>("killed by signal ", killSignal(),
108                            (coreDumped() ? " (core dumped)" : ""));
109   }
110   CHECK(false);  // unreached
111   return "";  // silence GCC warning
112 }
113
114 CalledProcessError::CalledProcessError(ProcessReturnCode rc)
115   : returnCode_(rc),
116     what_(returnCode_.str()) {
117 }
118
119 SubprocessSpawnError::SubprocessSpawnError(const char* executable,
120                                            int errCode,
121                                            int errnoValue)
122   : errnoValue_(errnoValue),
123     what_(to<std::string>(errCode == kExecFailure ?
124                             "failed to execute " :
125                             "error preparing to execute ",
126                           executable, ": ", errnoStr(errnoValue))) {
127 }
128
129 namespace {
130
131 // Copy pointers to the given strings in a format suitable for posix_spawn
132 std::unique_ptr<const char*[]> cloneStrings(const std::vector<std::string>& s) {
133   std::unique_ptr<const char*[]> d(new const char*[s.size() + 1]);
134   for (size_t i = 0; i < s.size(); i++) {
135     d[i] = s[i].c_str();
136   }
137   d[s.size()] = nullptr;
138   return d;
139 }
140
141 // Check a wait() status, throw on non-successful
142 void checkStatus(ProcessReturnCode returnCode) {
143   if (returnCode.state() != ProcessReturnCode::EXITED ||
144       returnCode.exitStatus() != 0) {
145     throw CalledProcessError(returnCode);
146   }
147 }
148
149 }  // namespace
150
151 Subprocess::Options& Subprocess::Options::fd(int fd, int action) {
152   if (action == Subprocess::PIPE) {
153     if (fd == 0) {
154       action = Subprocess::PIPE_IN;
155     } else if (fd == 1 || fd == 2) {
156       action = Subprocess::PIPE_OUT;
157     } else {
158       throw std::invalid_argument(
159           to<std::string>("Only fds 0, 1, 2 are valid for action=PIPE: ", fd));
160     }
161   }
162   fdActions_[fd] = action;
163   return *this;
164 }
165
166 Subprocess::Subprocess(
167     const std::vector<std::string>& argv,
168     const Options& options,
169     const char* executable,
170     const std::vector<std::string>* env)
171   : pid_(-1),
172     returnCode_(RV_NOT_STARTED) {
173   if (argv.empty()) {
174     throw std::invalid_argument("argv must not be empty");
175   }
176   if (!executable) executable = argv[0].c_str();
177   spawn(cloneStrings(argv), executable, options, env);
178 }
179
180 Subprocess::Subprocess(
181     const std::string& cmd,
182     const Options& options,
183     const std::vector<std::string>* env)
184   : pid_(-1),
185     returnCode_(RV_NOT_STARTED) {
186   if (options.usePath_) {
187     throw std::invalid_argument("usePath() not allowed when running in shell");
188   }
189   const char* shell = getenv("SHELL");
190   if (!shell) {
191     shell = "/bin/sh";
192   }
193
194   std::unique_ptr<const char*[]> argv(new const char*[4]);
195   argv[0] = shell;
196   argv[1] = "-c";
197   argv[2] = cmd.c_str();
198   argv[3] = nullptr;
199   spawn(std::move(argv), shell, options, env);
200 }
201
202 Subprocess::~Subprocess() {
203   CHECK_NE(returnCode_.state(), ProcessReturnCode::RUNNING)
204     << "Subprocess destroyed without reaping child";
205 }
206
207 namespace {
208
209 struct ChildErrorInfo {
210   int errCode;
211   int errnoValue;
212 };
213
214 FOLLY_NORETURN void childError(int errFd, int errCode, int errnoValue);
215 void childError(int errFd, int errCode, int errnoValue) {
216   ChildErrorInfo info = {errCode, errnoValue};
217   // Write the error information over the pipe to our parent process.
218   // We can't really do anything else if this write call fails.
219   writeNoInt(errFd, &info, sizeof(info));
220   // exit
221   _exit(errCode);
222 }
223
224 }  // namespace
225
226 void Subprocess::setAllNonBlocking() {
227   for (auto& p : pipes_) {
228     int fd = p.pipe.fd();
229     int flags = ::fcntl(fd, F_GETFL);
230     checkUnixError(flags, "fcntl");
231     int r = ::fcntl(fd, F_SETFL, flags | O_NONBLOCK);
232     checkUnixError(r, "fcntl");
233   }
234 }
235
236 void Subprocess::spawn(
237     std::unique_ptr<const char*[]> argv,
238     const char* executable,
239     const Options& optionsIn,
240     const std::vector<std::string>* env) {
241   if (optionsIn.usePath_ && env) {
242     throw std::invalid_argument(
243         "usePath() not allowed when overriding environment");
244   }
245
246   // Make a copy, we'll mutate options
247   Options options(optionsIn);
248
249   // On error, close all pipes_ (ignoring errors, but that seems fine here).
250   auto pipesGuard = makeGuard([this] { pipes_.clear(); });
251
252   // Create a pipe to use to receive error information from the child,
253   // in case it fails before calling exec()
254   int errFds[2];
255 #if FOLLY_HAVE_PIPE2
256   checkUnixError(::pipe2(errFds, O_CLOEXEC), "pipe2");
257 #else
258   checkUnixError(::pipe(errFds), "pipe");
259 #endif
260   SCOPE_EXIT {
261     CHECK_ERR(::close(errFds[0]));
262     if (errFds[1] >= 0) {
263       CHECK_ERR(::close(errFds[1]));
264     }
265   };
266
267 #if !FOLLY_HAVE_PIPE2
268   // Ask the child to close the read end of the error pipe.
269   checkUnixError(fcntl(errFds[0], F_SETFD, FD_CLOEXEC), "set FD_CLOEXEC");
270   // Set the close-on-exec flag on the write side of the pipe.
271   // This way the pipe will be closed automatically in the child if execve()
272   // succeeds.  If the exec fails the child can write error information to the
273   // pipe.
274   checkUnixError(fcntl(errFds[1], F_SETFD, FD_CLOEXEC), "set FD_CLOEXEC");
275 #endif
276
277   // Perform the actual work of setting up pipes then forking and
278   // executing the child.
279   spawnInternal(std::move(argv), executable, options, env, errFds[1]);
280
281   // After spawnInternal() returns the child is alive.  We have to be very
282   // careful about throwing after this point.  We are inside the constructor,
283   // so if we throw the Subprocess object will have never existed, and the
284   // destructor will never be called.
285   //
286   // We should only throw if we got an error via the errFd, and we know the
287   // child has exited and can be immediately waited for.  In all other cases,
288   // we have no way of cleaning up the child.
289
290   // Close writable side of the errFd pipe in the parent process
291   CHECK_ERR(::close(errFds[1]));
292   errFds[1] = -1;
293
294   // Read from the errFd pipe, to tell if the child ran into any errors before
295   // calling exec()
296   readChildErrorPipe(errFds[0], executable);
297
298   // We have fully succeeded now, so release the guard on pipes_
299   pipesGuard.dismiss();
300 }
301
302 void Subprocess::spawnInternal(
303     std::unique_ptr<const char*[]> argv,
304     const char* executable,
305     Options& options,
306     const std::vector<std::string>* env,
307     int errFd) {
308   // Parent work, pre-fork: create pipes
309   std::vector<int> childFds;
310   // Close all of the childFds as we leave this scope
311   SCOPE_EXIT {
312     // These are only pipes, closing them shouldn't fail
313     for (int cfd : childFds) {
314       CHECK_ERR(::close(cfd));
315     }
316   };
317
318   int r;
319   for (auto& p : options.fdActions_) {
320     if (p.second == PIPE_IN || p.second == PIPE_OUT) {
321       int fds[2];
322       // We're setting both ends of the pipe as close-on-exec. The child
323       // doesn't need to reset the flag on its end, as we always dup2() the fd,
324       // and dup2() fds don't share the close-on-exec flag.
325 #if FOLLY_HAVE_PIPE2
326       // If possible, set close-on-exec atomically. Otherwise, a concurrent
327       // Subprocess invocation can fork() between "pipe" and "fnctl",
328       // causing FDs to leak.
329       r = ::pipe2(fds, O_CLOEXEC);
330       checkUnixError(r, "pipe2");
331 #else
332       r = ::pipe(fds);
333       checkUnixError(r, "pipe");
334       r = fcntl(fds[0], F_SETFD, FD_CLOEXEC);
335       checkUnixError(r, "set FD_CLOEXEC");
336       r = fcntl(fds[1], F_SETFD, FD_CLOEXEC);
337       checkUnixError(r, "set FD_CLOEXEC");
338 #endif
339       pipes_.emplace_back();
340       Pipe& pipe = pipes_.back();
341       pipe.direction = p.second;
342       int cfd;
343       if (p.second == PIPE_IN) {
344         // Child gets reading end
345         pipe.pipe = folly::File(fds[1], /*owns_fd=*/ true);
346         cfd = fds[0];
347       } else {
348         pipe.pipe = folly::File(fds[0], /*owns_fd=*/ true);
349         cfd = fds[1];
350       }
351       p.second = cfd;  // ensure it gets dup2()ed
352       pipe.childFd = p.first;
353       childFds.push_back(cfd);
354     }
355   }
356
357   // This should already be sorted, as options.fdActions_ is
358   DCHECK(std::is_sorted(pipes_.begin(), pipes_.end()));
359
360   // Note that the const casts below are legit, per
361   // http://pubs.opengroup.org/onlinepubs/009695399/functions/exec.html
362
363   char** argVec = const_cast<char**>(argv.get());
364
365   // Set up environment
366   std::unique_ptr<const char*[]> envHolder;
367   char** envVec;
368   if (env) {
369     envHolder = cloneStrings(*env);
370     envVec = const_cast<char**>(envHolder.get());
371   } else {
372     envVec = environ;
373   }
374
375   // Block all signals around vfork; see http://ewontfix.com/7/.
376   //
377   // As the child may run in the same address space as the parent until
378   // the actual execve() system call, any (custom) signal handlers that
379   // the parent has might alter parent's memory if invoked in the child,
380   // with undefined results.  So we block all signals in the parent before
381   // vfork(), which will cause them to be blocked in the child as well (we
382   // rely on the fact that Linux, just like all sane implementations, only
383   // clones the calling thread).  Then, in the child, we reset all signals
384   // to their default dispositions (while still blocked), and unblock them
385   // (so the exec()ed process inherits the parent's signal mask)
386   //
387   // The parent also unblocks all signals as soon as vfork() returns.
388   sigset_t allBlocked;
389   r = sigfillset(&allBlocked);
390   checkUnixError(r, "sigfillset");
391   sigset_t oldSignals;
392
393   r = pthread_sigmask(SIG_SETMASK, &allBlocked, &oldSignals);
394   checkPosixError(r, "pthread_sigmask");
395   SCOPE_EXIT {
396     // Restore signal mask
397     r = pthread_sigmask(SIG_SETMASK, &oldSignals, nullptr);
398     CHECK_EQ(r, 0) << "pthread_sigmask: " << errnoStr(r);  // shouldn't fail
399   };
400
401   // Call c_str() here, as it's not necessarily safe after fork.
402   const char* childDir =
403     options.childDir_.empty() ? nullptr : options.childDir_.c_str();
404   pid_t pid = vfork();
405   if (pid == 0) {
406     int errnoValue = prepareChild(options, &oldSignals, childDir);
407     if (errnoValue != 0) {
408       childError(errFd, kChildFailure, errnoValue);
409     }
410
411     errnoValue = runChild(executable, argVec, envVec, options);
412     // If we get here, exec() failed.
413     childError(errFd, kExecFailure, errnoValue);
414   }
415   // In parent.  Make sure vfork() succeeded.
416   checkUnixError(pid, errno, "vfork");
417
418   // Child is alive.  We have to be very careful about throwing after this
419   // point.  We are inside the constructor, so if we throw the Subprocess
420   // object will have never existed, and the destructor will never be called.
421   //
422   // We should only throw if we got an error via the errFd, and we know the
423   // child has exited and can be immediately waited for.  In all other cases,
424   // we have no way of cleaning up the child.
425   pid_ = pid;
426   returnCode_ = ProcessReturnCode(RV_RUNNING);
427 }
428
429 int Subprocess::prepareChild(const Options& options,
430                              const sigset_t* sigmask,
431                              const char* childDir) const {
432   // While all signals are blocked, we must reset their
433   // dispositions to default.
434   for (int sig = 1; sig < NSIG; ++sig) {
435     ::signal(sig, SIG_DFL);
436   }
437
438   {
439     // Unblock signals; restore signal mask.
440     int r = pthread_sigmask(SIG_SETMASK, sigmask, nullptr);
441     if (r != 0) {
442       return r;  // pthread_sigmask() returns an errno value
443     }
444   }
445
446   // Change the working directory, if one is given
447   if (childDir) {
448     if (::chdir(childDir) == -1) {
449       return errno;
450     }
451   }
452
453   // We don't have to explicitly close the parent's end of all pipes,
454   // as they all have the FD_CLOEXEC flag set and will be closed at
455   // exec time.
456
457   // Close all fds that we're supposed to close.
458   for (auto& p : options.fdActions_) {
459     if (p.second == CLOSE) {
460       if (::close(p.first) == -1) {
461         return errno;
462       }
463     } else if (p.second != p.first) {
464       if (::dup2(p.second, p.first) == -1) {
465         return errno;
466       }
467     }
468   }
469
470   // If requested, close all other file descriptors.  Don't close
471   // any fds in options.fdActions_, and don't touch stdin, stdout, stderr.
472   // Ignore errors.
473   if (options.closeOtherFds_) {
474     for (int fd = getdtablesize() - 1; fd >= 3; --fd) {
475       if (options.fdActions_.count(fd) == 0) {
476         ::close(fd);
477       }
478     }
479   }
480
481 #if __linux__
482   // Opt to receive signal on parent death, if requested
483   if (options.parentDeathSignal_ != 0) {
484     if (prctl(PR_SET_PDEATHSIG, options.parentDeathSignal_, 0, 0, 0) == -1) {
485       return errno;
486     }
487   }
488 #endif
489
490   if (options.processGroupLeader_) {
491     if (setpgrp() == -1) {
492       return errno;
493     }
494   }
495
496   return 0;
497 }
498
499 int Subprocess::runChild(const char* executable,
500                          char** argv, char** env,
501                          const Options& options) const {
502   // Now, finally, exec.
503   if (options.usePath_) {
504     ::execvp(executable, argv);
505   } else {
506     ::execve(executable, argv, env);
507   }
508   return errno;
509 }
510
511 void Subprocess::readChildErrorPipe(int pfd, const char* executable) {
512   ChildErrorInfo info;
513   auto rc = readNoInt(pfd, &info, sizeof(info));
514   if (rc == 0) {
515     // No data means the child executed successfully, and the pipe
516     // was closed due to the close-on-exec flag being set.
517     return;
518   } else if (rc != sizeof(ChildErrorInfo)) {
519     // An error occurred trying to read from the pipe, or we got a partial read.
520     // Neither of these cases should really occur in practice.
521     //
522     // We can't get any error data from the child in this case, and we don't
523     // know if it is successfully running or not.  All we can do is to return
524     // normally, as if the child executed successfully.  If something bad
525     // happened the caller should at least get a non-normal exit status from
526     // the child.
527     LOG(ERROR) << "unexpected error trying to read from child error pipe " <<
528       "rc=" << rc << ", errno=" << errno;
529     return;
530   }
531
532   // We got error data from the child.  The child should exit immediately in
533   // this case, so wait on it to clean up.
534   wait();
535
536   // Throw to signal the error
537   throw SubprocessSpawnError(executable, info.errCode, info.errnoValue);
538 }
539
540 ProcessReturnCode Subprocess::poll() {
541   returnCode_.enforce(ProcessReturnCode::RUNNING);
542   DCHECK_GT(pid_, 0);
543   int status;
544   pid_t found = ::waitpid(pid_, &status, WNOHANG);
545   // The spec guarantees that EINTR does not occur with WNOHANG, so the only
546   // two remaining errors are ECHILD (other code reaped the child?), or
547   // EINVAL (cosmic rays?), both of which merit an abort:
548   PCHECK(found != -1) << "waitpid(" << pid_ << ", &status, WNOHANG)";
549   if (found != 0) {
550     // Though the child process had quit, this call does not close the pipes
551     // since its descendants may still be using them.
552     returnCode_ = ProcessReturnCode(status);
553     pid_ = -1;
554   }
555   return returnCode_;
556 }
557
558 bool Subprocess::pollChecked() {
559   if (poll().state() == ProcessReturnCode::RUNNING) {
560     return false;
561   }
562   checkStatus(returnCode_);
563   return true;
564 }
565
566 ProcessReturnCode Subprocess::wait() {
567   returnCode_.enforce(ProcessReturnCode::RUNNING);
568   DCHECK_GT(pid_, 0);
569   int status;
570   pid_t found;
571   do {
572     found = ::waitpid(pid_, &status, 0);
573   } while (found == -1 && errno == EINTR);
574   // The only two remaining errors are ECHILD (other code reaped the
575   // child?), or EINVAL (cosmic rays?), and both merit an abort:
576   PCHECK(found != -1) << "waitpid(" << pid_ << ", &status, WNOHANG)";
577   // Though the child process had quit, this call does not close the pipes
578   // since its descendants may still be using them.
579   DCHECK_EQ(found, pid_);
580   returnCode_ = ProcessReturnCode(status);
581   pid_ = -1;
582   return returnCode_;
583 }
584
585 void Subprocess::waitChecked() {
586   wait();
587   checkStatus(returnCode_);
588 }
589
590 void Subprocess::sendSignal(int signal) {
591   returnCode_.enforce(ProcessReturnCode::RUNNING);
592   int r = ::kill(pid_, signal);
593   checkUnixError(r, "kill");
594 }
595
596 pid_t Subprocess::pid() const {
597   return pid_;
598 }
599
600 namespace {
601
602 std::pair<const uint8_t*, size_t> queueFront(const IOBufQueue& queue) {
603   auto* p = queue.front();
604   if (!p) return std::make_pair(nullptr, 0);
605   return io::Cursor(p).peek();
606 }
607
608 // fd write
609 bool handleWrite(int fd, IOBufQueue& queue) {
610   for (;;) {
611     auto p = queueFront(queue);
612     if (p.second == 0) {
613       return true;  // EOF
614     }
615
616     ssize_t n = writeNoInt(fd, p.first, p.second);
617     if (n == -1 && errno == EAGAIN) {
618       return false;
619     }
620     checkUnixError(n, "write");
621     queue.trimStart(n);
622   }
623 }
624
625 // fd read
626 bool handleRead(int fd, IOBufQueue& queue) {
627   for (;;) {
628     auto p = queue.preallocate(100, 65000);
629     ssize_t n = readNoInt(fd, p.first, p.second);
630     if (n == -1 && errno == EAGAIN) {
631       return false;
632     }
633     checkUnixError(n, "read");
634     if (n == 0) {
635       return true;
636     }
637     queue.postallocate(n);
638   }
639 }
640
641 bool discardRead(int fd) {
642   static const size_t bufSize = 65000;
643   // Thread unsafe, but it doesn't matter.
644   static std::unique_ptr<char[]> buf(new char[bufSize]);
645
646   for (;;) {
647     ssize_t n = readNoInt(fd, buf.get(), bufSize);
648     if (n == -1 && errno == EAGAIN) {
649       return false;
650     }
651     checkUnixError(n, "read");
652     if (n == 0) {
653       return true;
654     }
655   }
656 }
657
658 }  // namespace
659
660 std::pair<std::string, std::string> Subprocess::communicate(
661     StringPiece input) {
662   IOBufQueue inputQueue;
663   inputQueue.wrapBuffer(input.data(), input.size());
664
665   auto outQueues = communicateIOBuf(std::move(inputQueue));
666   auto outBufs = std::make_pair(outQueues.first.move(),
667                                 outQueues.second.move());
668   std::pair<std::string, std::string> out;
669   if (outBufs.first) {
670     outBufs.first->coalesce();
671     out.first.assign(reinterpret_cast<const char*>(outBufs.first->data()),
672                      outBufs.first->length());
673   }
674   if (outBufs.second) {
675     outBufs.second->coalesce();
676     out.second.assign(reinterpret_cast<const char*>(outBufs.second->data()),
677                      outBufs.second->length());
678   }
679   return out;
680 }
681
682 std::pair<IOBufQueue, IOBufQueue> Subprocess::communicateIOBuf(
683     IOBufQueue input) {
684   // If the user supplied a non-empty input buffer, make sure
685   // that stdin is a pipe so we can write the data.
686   if (!input.empty()) {
687     // findByChildFd() will throw std::invalid_argument if no pipe for
688     // STDIN_FILENO exists
689     findByChildFd(STDIN_FILENO);
690   }
691
692   std::pair<IOBufQueue, IOBufQueue> out;
693
694   auto readCallback = [&] (int pfd, int cfd) -> bool {
695     if (cfd == STDOUT_FILENO) {
696       return handleRead(pfd, out.first);
697     } else if (cfd == STDERR_FILENO) {
698       return handleRead(pfd, out.second);
699     } else {
700       // Don't close the file descriptor, the child might not like SIGPIPE,
701       // just read and throw the data away.
702       return discardRead(pfd);
703     }
704   };
705
706   auto writeCallback = [&] (int pfd, int cfd) -> bool {
707     if (cfd == STDIN_FILENO) {
708       return handleWrite(pfd, input);
709     } else {
710       // If we don't want to write to this fd, just close it.
711       return true;
712     }
713   };
714
715   communicate(std::move(readCallback), std::move(writeCallback));
716
717   return out;
718 }
719
720 void Subprocess::communicate(FdCallback readCallback,
721                              FdCallback writeCallback) {
722   // This serves to prevent wait() followed by communicate(), but if you
723   // legitimately need that, send a patch to delete this line.
724   returnCode_.enforce(ProcessReturnCode::RUNNING);
725   setAllNonBlocking();
726
727   std::vector<pollfd> fds;
728   fds.reserve(pipes_.size());
729   std::vector<size_t> toClose;  // indexes into pipes_
730   toClose.reserve(pipes_.size());
731
732   while (!pipes_.empty()) {
733     fds.clear();
734     toClose.clear();
735
736     for (auto& p : pipes_) {
737       pollfd pfd;
738       pfd.fd = p.pipe.fd();
739       // Yes, backwards, PIPE_IN / PIPE_OUT are defined from the
740       // child's point of view.
741       if (!p.enabled) {
742         // Still keeping fd in watched set so we get notified of POLLHUP /
743         // POLLERR
744         pfd.events = 0;
745       } else if (p.direction == PIPE_IN) {
746         pfd.events = POLLOUT;
747       } else {
748         pfd.events = POLLIN;
749       }
750       fds.push_back(pfd);
751     }
752
753     int r;
754     do {
755       r = ::poll(fds.data(), fds.size(), -1);
756     } while (r == -1 && errno == EINTR);
757     checkUnixError(r, "poll");
758
759     for (size_t i = 0; i < pipes_.size(); ++i) {
760       auto& p = pipes_[i];
761       auto parentFd = p.pipe.fd();
762       DCHECK_EQ(fds[i].fd, parentFd);
763       short events = fds[i].revents;
764
765       bool closed = false;
766       if (events & POLLOUT) {
767         DCHECK(!(events & POLLIN));
768         if (writeCallback(parentFd, p.childFd)) {
769           toClose.push_back(i);
770           closed = true;
771         }
772       }
773
774       // Call read callback on POLLHUP, to give it a chance to read (and act
775       // on) end of file
776       if (events & (POLLIN | POLLHUP)) {
777         DCHECK(!(events & POLLOUT));
778         if (readCallback(parentFd, p.childFd)) {
779           toClose.push_back(i);
780           closed = true;
781         }
782       }
783
784       if ((events & (POLLHUP | POLLERR)) && !closed) {
785         toClose.push_back(i);
786         closed = true;
787       }
788     }
789
790     // Close the fds in reverse order so the indexes hold after erase()
791     for (int idx : boost::adaptors::reverse(toClose)) {
792       auto pos = pipes_.begin() + idx;
793       pos->pipe.close();  // Throws on error
794       pipes_.erase(pos);
795     }
796   }
797 }
798
799 void Subprocess::enableNotifications(int childFd, bool enabled) {
800   pipes_[findByChildFd(childFd)].enabled = enabled;
801 }
802
803 bool Subprocess::notificationsEnabled(int childFd) const {
804   return pipes_[findByChildFd(childFd)].enabled;
805 }
806
807 size_t Subprocess::findByChildFd(int childFd) const {
808   auto pos = std::lower_bound(
809       pipes_.begin(), pipes_.end(), childFd,
810       [] (const Pipe& pipe, int fd) { return pipe.childFd < fd; });
811   if (pos == pipes_.end() || pos->childFd != childFd) {
812     throw std::invalid_argument(folly::to<std::string>(
813         "child fd not found ", childFd));
814   }
815   return pos - pipes_.begin();
816 }
817
818 void Subprocess::closeParentFd(int childFd) {
819   int idx = findByChildFd(childFd);
820   pipes_[idx].pipe.close();  // May throw
821   pipes_.erase(pipes_.begin() + idx);
822 }
823
824 std::vector<Subprocess::ChildPipe> Subprocess::takeOwnershipOfPipes() {
825   std::vector<Subprocess::ChildPipe> pipes;
826   for (auto& p : pipes_) {
827     pipes.emplace_back(p.childFd, std::move(p.pipe));
828   }
829   pipes_.clear();
830   return pipes;
831 }
832
833 namespace {
834
835 class Initializer {
836  public:
837   Initializer() {
838     // We like EPIPE, thanks.
839     ::signal(SIGPIPE, SIG_IGN);
840   }
841 };
842
843 Initializer initializer;
844
845 }  // namespace
846
847 }  // namespace folly