blob: 615e9f83d74514bda7e95dcbb932720d213fd940 [file] [log] [blame]
// Copyright 2016 The Bazel Authors. All rights reserved.
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
package com.google.devtools.build.lib.remote;
import com.google.bytestream.ByteStreamGrpc;
import com.google.bytestream.ByteStreamGrpc.ByteStreamBlockingStub;
import com.google.bytestream.ByteStreamProto.ReadRequest;
import com.google.bytestream.ByteStreamProto.ReadResponse;
import com.google.common.annotations.VisibleForTesting;
import com.google.common.base.Throwables;
import com.google.common.collect.ImmutableList;
import com.google.common.collect.ImmutableSet;
import com.google.common.util.concurrent.ListeningScheduledExecutorService;
import com.google.common.util.concurrent.MoreExecutors;
import com.google.devtools.build.lib.actions.ActionInput;
import com.google.devtools.build.lib.actions.ActionInputFileCache;
import com.google.devtools.build.lib.concurrent.ThreadSafety.ThreadSafe;
import com.google.devtools.build.lib.remote.Chunker.SingleSourceBuilder;
import com.google.devtools.build.lib.remote.Digests.ActionKey;
import com.google.devtools.build.lib.remote.TreeNodeRepository.TreeNode;
import com.google.devtools.build.lib.util.Preconditions;
import com.google.devtools.build.lib.util.io.FileOutErr;
import com.google.devtools.build.lib.vfs.FileSystemUtils;
import com.google.devtools.build.lib.vfs.Path;
import com.google.devtools.remoteexecution.v1test.ActionCacheGrpc;
import com.google.devtools.remoteexecution.v1test.ActionCacheGrpc.ActionCacheBlockingStub;
import com.google.devtools.remoteexecution.v1test.ActionResult;
import com.google.devtools.remoteexecution.v1test.BatchUpdateBlobsRequest;
import com.google.devtools.remoteexecution.v1test.BatchUpdateBlobsResponse;
import com.google.devtools.remoteexecution.v1test.Command;
import com.google.devtools.remoteexecution.v1test.ContentAddressableStorageGrpc;
import com.google.devtools.remoteexecution.v1test.ContentAddressableStorageGrpc.ContentAddressableStorageBlockingStub;
import com.google.devtools.remoteexecution.v1test.Digest;
import com.google.devtools.remoteexecution.v1test.Directory;
import com.google.devtools.remoteexecution.v1test.FindMissingBlobsRequest;
import com.google.devtools.remoteexecution.v1test.FindMissingBlobsResponse;
import com.google.devtools.remoteexecution.v1test.GetActionResultRequest;
import com.google.devtools.remoteexecution.v1test.OutputDirectory;
import com.google.devtools.remoteexecution.v1test.OutputFile;
import com.google.devtools.remoteexecution.v1test.UpdateActionResultRequest;
import com.google.protobuf.ByteString;
import io.grpc.Channel;
import io.grpc.Status;
import io.grpc.StatusRuntimeException;
import io.grpc.protobuf.StatusProto;
import java.io.IOException;
import java.io.OutputStream;
import java.util.ArrayList;
import java.util.Collection;
import java.util.Iterator;
import java.util.List;
import java.util.concurrent.Executors;
import java.util.concurrent.TimeUnit;
/** A RemoteActionCache implementation that uses gRPC calls to a remote cache server. */
@ThreadSafe
public class GrpcRemoteCache implements RemoteActionCache {
private final RemoteOptions options;
private final ChannelOptions channelOptions;
private final Channel channel;
private final Retrier retrier;
private final ByteStreamUploader uploader;
private final ListeningScheduledExecutorService retryScheduler =
MoreExecutors.listeningDecorator(Executors.newScheduledThreadPool(1));
@VisibleForTesting
public GrpcRemoteCache(Channel channel, ChannelOptions channelOptions, RemoteOptions options) {
this.options = options;
this.channelOptions = channelOptions;
this.channel = channel;
this.retrier = new Retrier(options);
uploader = new ByteStreamUploader(options.remoteInstanceName, channel,
channelOptions.getCallCredentials(), options.remoteTimeout, retrier, retryScheduler);
}
private ContentAddressableStorageBlockingStub casBlockingStub() {
return ContentAddressableStorageGrpc.newBlockingStub(channel)
.withCallCredentials(channelOptions.getCallCredentials())
.withDeadlineAfter(options.remoteTimeout, TimeUnit.SECONDS);
}
private ByteStreamBlockingStub bsBlockingStub() {
return ByteStreamGrpc.newBlockingStub(channel)
.withCallCredentials(channelOptions.getCallCredentials())
.withDeadlineAfter(options.remoteTimeout, TimeUnit.SECONDS);
}
private ActionCacheBlockingStub acBlockingStub() {
return ActionCacheGrpc.newBlockingStub(channel)
.withCallCredentials(channelOptions.getCallCredentials())
.withDeadlineAfter(options.remoteTimeout, TimeUnit.SECONDS);
}
@Override
public void close() {
retryScheduler.shutdownNow();
uploader.shutdown();
}
public static boolean isRemoteCacheOptions(RemoteOptions options) {
return options.remoteCache != null;
}
private ImmutableSet<Digest> getMissingDigests(Iterable<Digest> digests)
throws IOException, InterruptedException {
FindMissingBlobsRequest.Builder request =
FindMissingBlobsRequest.newBuilder()
.setInstanceName(options.remoteInstanceName)
.addAllBlobDigests(digests);
if (request.getBlobDigestsCount() == 0) {
return ImmutableSet.of();
}
FindMissingBlobsResponse response =
retrier.execute(() -> casBlockingStub().findMissingBlobs(request.build()));
return ImmutableSet.copyOf(response.getMissingBlobDigestsList());
}
/**
* Upload enough of the tree metadata and data into remote cache so that the entire tree can be
* reassembled remotely using the root digest.
*/
@Override
public void ensureInputsPresent(
TreeNodeRepository repository, Path execRoot, TreeNode root, Command command)
throws IOException, InterruptedException {
repository.computeMerkleDigests(root);
// TODO(olaola): avoid querying all the digests, only ask for novel subtrees.
ImmutableSet<Digest> missingDigests = getMissingDigests(repository.getAllDigests(root));
// Only upload data that was missing from the cache.
ArrayList<ActionInput> actionInputs = new ArrayList<>();
ArrayList<Directory> treeNodes = new ArrayList<>();
repository.getDataFromDigests(missingDigests, actionInputs, treeNodes);
if (!treeNodes.isEmpty()) {
// TODO(olaola): split this into multiple requests if total size is > 10MB.
BatchUpdateBlobsRequest.Builder treeBlobRequest =
BatchUpdateBlobsRequest.newBuilder().setInstanceName(options.remoteInstanceName);
for (Directory d : treeNodes) {
byte[] data = d.toByteArray();
treeBlobRequest
.addRequestsBuilder()
.setContentDigest(Digests.computeDigest(data))
.setData(ByteString.copyFrom(data));
}
retrier.execute(
() -> {
BatchUpdateBlobsResponse response =
casBlockingStub().batchUpdateBlobs(treeBlobRequest.build());
for (BatchUpdateBlobsResponse.Response r : response.getResponsesList()) {
if (!Status.fromCodeValue(r.getStatus().getCode()).isOk()) {
throw StatusProto.toStatusRuntimeException(r.getStatus());
}
}
return null;
});
}
uploadBlob(command.toByteArray());
if (!actionInputs.isEmpty()) {
List<Chunker.SingleSourceBuilder> inputsToUpload = new ArrayList<>();
ActionInputFileCache inputFileCache = repository.getInputFileCache();
for (ActionInput actionInput : actionInputs) {
Digest digest = Digests.getDigestFromInputCache(actionInput, inputFileCache);
if (missingDigests.contains(digest)) {
Chunker.SingleSourceBuilder builder =
new Chunker.SingleSourceBuilder().input(actionInput, inputFileCache, execRoot);
inputsToUpload.add(builder);
}
}
uploader.uploadBlobs(inputsToUpload);
}
}
/**
* Download the entire tree data rooted by the given digest and write it into the given location.
*/
@SuppressWarnings("unused")
private void downloadTree(Digest rootDigest, Path rootLocation) {
throw new UnsupportedOperationException();
}
/**
* Download all results of a remotely executed action locally. TODO(olaola): will need to amend to
* include the {@link com.google.devtools.build.lib.remote.TreeNodeRepository} for updating.
*/
@Override
public void download(ActionResult result, Path execRoot, FileOutErr outErr)
throws IOException, InterruptedException, CacheNotFoundException {
for (OutputFile file : result.getOutputFilesList()) {
Path path = execRoot.getRelative(file.getPath());
FileSystemUtils.createDirectoryAndParents(path.getParentDirectory());
Digest digest = file.getDigest();
if (digest.getSizeBytes() == 0) {
// Handle empty file locally.
FileSystemUtils.writeContent(path, new byte[0]);
} else {
if (!file.getContent().isEmpty()) {
try (OutputStream stream = path.getOutputStream()) {
file.getContent().writeTo(stream);
}
} else {
try {
retrier.execute(
() -> {
try (OutputStream stream = path.getOutputStream()) {
Iterator<ReadResponse> replies = readBlob(digest);
while (replies.hasNext()) {
replies.next().getData().writeTo(stream);
}
}
Digest receivedDigest = Digests.computeDigest(path);
if (!receivedDigest.equals(digest)) {
throw new IOException(
"Digest does not match " + receivedDigest + " != " + digest);
}
return null;
});
} catch (RetryException e) {
Throwables.throwIfInstanceOf(e.getCause(), CacheNotFoundException.class);
throw e;
}
}
}
path.setExecutable(file.getIsExecutable());
}
for (OutputDirectory directory : result.getOutputDirectoriesList()) {
downloadTree(directory.getDigest(), execRoot.getRelative(directory.getPath()));
}
// TODO(ulfjack): use same code as above also for stdout / stderr if applicable.
downloadOutErr(result, outErr);
}
private void downloadOutErr(ActionResult result, FileOutErr outErr)
throws IOException, InterruptedException, CacheNotFoundException {
if (!result.getStdoutRaw().isEmpty()) {
result.getStdoutRaw().writeTo(outErr.getOutputStream());
outErr.getOutputStream().flush();
} else if (result.hasStdoutDigest()) {
byte[] stdoutBytes = downloadBlob(result.getStdoutDigest());
outErr.getOutputStream().write(stdoutBytes);
outErr.getOutputStream().flush();
}
if (!result.getStderrRaw().isEmpty()) {
result.getStderrRaw().writeTo(outErr.getErrorStream());
outErr.getErrorStream().flush();
} else if (result.hasStderrDigest()) {
byte[] stderrBytes = downloadBlob(result.getStderrDigest());
outErr.getErrorStream().write(stderrBytes);
outErr.getErrorStream().flush();
}
}
/**
* This method can throw {@link StatusRuntimeException}, but the RemoteCache interface does not
* allow throwing such an exception. Any caller must make sure to catch the
* {@link StatusRuntimeException}. Note that the retrier implicitly catches it, so if this is used
* in the context of {@link Retrier#execute}, that's perfectly safe.
*
* <p>On the other hand, this method can also throw {@link CacheNotFoundException}, but the
* retrier also implicitly catches that and wraps it in a {@link RetryException}, so any caller
* that wants to propagate the {@link CacheNotFoundException} needs to catch
* {@link RetryException} and rethrow the cause if it is a {@link CacheNotFoundException}.
*/
private Iterator<ReadResponse> readBlob(Digest digest)
throws CacheNotFoundException, StatusRuntimeException {
String resourceName = "";
if (!options.remoteInstanceName.isEmpty()) {
resourceName += options.remoteInstanceName + "/";
}
resourceName += "blobs/" + digest.getHash() + "/" + digest.getSizeBytes();
try {
return bsBlockingStub()
.read(ReadRequest.newBuilder().setResourceName(resourceName).build());
} catch (StatusRuntimeException e) {
if (e.getStatus().getCode() == Status.Code.NOT_FOUND) {
throw new CacheNotFoundException(digest);
}
throw e;
}
}
@Override
public void upload(ActionKey actionKey, Path execRoot, Collection<Path> files, FileOutErr outErr)
throws IOException, InterruptedException {
ActionResult.Builder result = ActionResult.newBuilder();
upload(execRoot, files, outErr, result);
try {
retrier.execute(
() ->
acBlockingStub()
.updateActionResult(
UpdateActionResultRequest.newBuilder()
.setInstanceName(options.remoteInstanceName)
.setActionDigest(actionKey.getDigest())
.setActionResult(result)
.build()));
} catch (RetryException e) {
if (e.causedByStatusCode(Status.Code.UNIMPLEMENTED)) {
// Silently return without upload.
return;
}
throw e;
}
}
void upload(Path execRoot, Collection<Path> files, FileOutErr outErr, ActionResult.Builder result)
throws IOException, InterruptedException {
ArrayList<Digest> digests = new ArrayList<>();
ImmutableSet<Digest> digestsToUpload = getMissingDigests(digests);
List<Chunker.SingleSourceBuilder> filesToUpload = new ArrayList<>(digestsToUpload.size());
for (Path file : files) {
if (!file.exists()) {
// We ignore requested results that have not been generated by the action.
continue;
}
if (file.isDirectory()) {
// TODO(olaola): to implement this for a directory, will need to create or pass a
// TreeNodeRepository to call uploadTree.
throw new UnsupportedOperationException("Storing a directory is not yet supported.");
}
Digest digest = Digests.computeDigest(file);
digests.add(digest);
if (digestsToUpload.contains(digest)) {
Chunker.SingleSourceBuilder chunkerBuilder = new SingleSourceBuilder().input(file);
filesToUpload.add(chunkerBuilder);
}
}
if (!filesToUpload.isEmpty()) {
uploader.uploadBlobs(filesToUpload);
}
int index = 0;
for (Path file : files) {
// Add to protobuf.
// TODO(olaola): inline small results here.
result
.addOutputFilesBuilder()
.setPath(file.relativeTo(execRoot).getPathString())
.setDigest(digests.get(index++))
.setIsExecutable(file.isExecutable());
}
// TODO(olaola): inline small stdout/stderr here.
if (outErr.getErrorPath().exists()) {
Digest stderr = uploadFileContents(outErr.getErrorPath());
result.setStderrDigest(stderr);
}
if (outErr.getOutputPath().exists()) {
Digest stdout = uploadFileContents(outErr.getOutputPath());
result.setStdoutDigest(stdout);
}
}
/**
* Put the file contents cache if it is not already in it. No-op if the file is already stored in
* cache. The given path must be a full absolute path.
*
* @return The key for fetching the file contents blob from cache.
*/
private Digest uploadFileContents(Path file) throws IOException, InterruptedException {
Digest digest = Digests.computeDigest(file);
ImmutableSet<Digest> missing = getMissingDigests(ImmutableList.of(digest));
if (!missing.isEmpty()) {
uploader.uploadBlob(new Chunker.SingleSourceBuilder().input(file));
}
return digest;
}
/**
* Put the file contents cache if it is not already in it. No-op if the file is already stored in
* cache. The given path must be a full absolute path.
*
* @return The key for fetching the file contents blob from cache.
*/
Digest uploadFileContents(ActionInput input, Path execRoot, ActionInputFileCache inputCache)
throws IOException, InterruptedException {
Digest digest = Digests.getDigestFromInputCache(input, inputCache);
ImmutableSet<Digest> missing = getMissingDigests(ImmutableList.of(digest));
if (!missing.isEmpty()) {
uploader.uploadBlob(new Chunker.SingleSourceBuilder().input(input, inputCache, execRoot));
}
return digest;
}
Digest uploadBlob(byte[] blob) throws IOException, InterruptedException {
Digest digest = Digests.computeDigest(blob);
ImmutableSet<Digest> missing = getMissingDigests(ImmutableList.of(digest));
if (!missing.isEmpty()) {
uploader.uploadBlob(new Chunker.SingleSourceBuilder().input(blob));
}
return digest;
}
byte[] downloadBlob(Digest digest)
throws IOException, InterruptedException, CacheNotFoundException {
if (digest.getSizeBytes() == 0) {
return new byte[0];
}
byte[] result = new byte[(int) digest.getSizeBytes()];
try {
retrier.execute(
() -> {
Iterator<ReadResponse> replies = readBlob(digest);
int offset = 0;
while (replies.hasNext()) {
ByteString data = replies.next().getData();
data.copyTo(result, offset);
offset += data.size();
}
Preconditions.checkState(digest.getSizeBytes() == offset);
return null;
});
} catch (RetryException e) {
Throwables.throwIfInstanceOf(e.getCause(), CacheNotFoundException.class);
throw e;
}
return result;
}
// Execution Cache API
@Override
public ActionResult getCachedActionResult(ActionKey actionKey)
throws IOException, InterruptedException {
try {
return retrier.execute(
() ->
acBlockingStub()
.getActionResult(
GetActionResultRequest.newBuilder()
.setInstanceName(options.remoteInstanceName)
.setActionDigest(actionKey.getDigest())
.build()));
} catch (RetryException e) {
if (e.causedByStatusCode(Status.Code.NOT_FOUND)) {
// Return null to indicate that it was a cache miss.
return null;
}
throw e;
}
}
}