123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785 |
- #include "globals.hh"
- #include "misc.hh"
- #include "local-store.hh"
- #include <functional>
- #include <queue>
- #include <algorithm>
- #include <sys/types.h>
- #include <sys/stat.h>
- #include <errno.h>
- #include <fcntl.h>
- #include <unistd.h>
- #include <climits>
- namespace nix {
- static string gcLockName = "gc.lock";
- static string tempRootsDir = "temproots";
- static string gcRootsDir = "gcroots";
- /* Acquire the global GC lock. This is used to prevent new build
- processes from starting after the temporary root files have been
- read. To be precise: when they try to create a new temporary root
- file, they will block until the garbage collector has finished /
- yielded the GC lock. */
- int LocalStore::openGCLock(LockType lockType)
- {
- Path fnGCLock = (format("%1%/%2%")
- % settings.nixStateDir % gcLockName).str();
- debug(format("acquiring global GC lock `%1%'") % fnGCLock);
- AutoCloseFD fdGCLock = open(fnGCLock.c_str(), O_RDWR | O_CREAT, 0600);
- if (fdGCLock == -1)
- throw SysError(format("opening global GC lock `%1%'") % fnGCLock);
- closeOnExec(fdGCLock);
- if (!lockFile(fdGCLock, lockType, false)) {
- printMsg(lvlError, format("waiting for the big garbage collector lock..."));
- lockFile(fdGCLock, lockType, true);
- }
- /* !!! Restrict read permission on the GC root. Otherwise any
- process that can open the file for reading can DoS the
- collector. */
- return fdGCLock.borrow();
- }
- static void makeSymlink(const Path & link, const Path & target)
- {
- /* Create directories up to `gcRoot'. */
- createDirs(dirOf(link));
- /* Create the new symlink. */
- Path tempLink = (format("%1%.tmp-%2%-%3%")
- % link % getpid() % rand()).str();
- createSymlink(target, tempLink);
- /* Atomically replace the old one. */
- if (rename(tempLink.c_str(), link.c_str()) == -1)
- throw SysError(format("cannot rename `%1%' to `%2%'")
- % tempLink % link);
- }
- void LocalStore::syncWithGC()
- {
- AutoCloseFD fdGCLock = openGCLock(ltRead);
- }
- void LocalStore::addIndirectRoot(const Path & path)
- {
- string hash = printHash32(hashString(htSHA1, path));
- Path realRoot = canonPath((format("%1%/%2%/auto/%3%")
- % settings.nixStateDir % gcRootsDir % hash).str());
- makeSymlink(realRoot, path);
- }
- Path addPermRoot(StoreAPI & store, const Path & _storePath,
- const Path & _gcRoot, bool indirect, bool allowOutsideRootsDir)
- {
- Path storePath(canonPath(_storePath));
- Path gcRoot(canonPath(_gcRoot));
- assertStorePath(storePath);
- if (isInStore(gcRoot))
- throw Error(format(
- "creating a garbage collector root (%1%) in the store is forbidden "
- "(are you running nix-build inside the store?)") % gcRoot);
- if (indirect) {
- /* Don't clobber the link if it already exists and doesn't
- point to the store. */
- if (pathExists(gcRoot) && (!isLink(gcRoot) || !isInStore(readLink(gcRoot))))
- throw Error(format("cannot create symlink `%1%'; already exists") % gcRoot);
- makeSymlink(gcRoot, storePath);
- store.addIndirectRoot(gcRoot);
- }
- else {
- if (!allowOutsideRootsDir) {
- Path rootsDir = canonPath((format("%1%/%2%") % settings.nixStateDir % gcRootsDir).str());
- if (string(gcRoot, 0, rootsDir.size() + 1) != rootsDir + "/")
- throw Error(format(
- "path `%1%' is not a valid garbage collector root; "
- "it's not in the directory `%2%'")
- % gcRoot % rootsDir);
- }
- if (baseNameOf(gcRoot) == baseNameOf(storePath))
- writeFile(gcRoot, "");
- else
- makeSymlink(gcRoot, storePath);
- }
- /* Check that the root can be found by the garbage collector.
- !!! This can be very slow on machines that have many roots.
- Instead of reading all the roots, it would be more efficient to
- check if the root is in a directory in or linked from the
- gcroots directory. */
- if (settings.checkRootReachability) {
- Roots roots = store.findRoots();
- if (roots.find(gcRoot) == roots.end())
- printMsg(lvlError,
- format(
- "warning: `%1%' is not in a directory where the garbage collector looks for roots; "
- "therefore, `%2%' might be removed by the garbage collector")
- % gcRoot % storePath);
- }
- /* Grab the global GC root, causing us to block while a GC is in
- progress. This prevents the set of permanent roots from
- increasing while a GC is in progress. */
- store.syncWithGC();
- return gcRoot;
- }
- void LocalStore::addTempRoot(const Path & path)
- {
- /* Create the temporary roots file for this process. */
- if (fdTempRoots == -1) {
- while (1) {
- Path dir = (format("%1%/%2%") % settings.nixStateDir % tempRootsDir).str();
- createDirs(dir);
- fnTempRoots = (format("%1%/%2%")
- % dir % getpid()).str();
- AutoCloseFD fdGCLock = openGCLock(ltRead);
- if (pathExists(fnTempRoots))
- /* It *must* be stale, since there can be no two
- processes with the same pid. */
- unlink(fnTempRoots.c_str());
- fdTempRoots = openLockFile(fnTempRoots, true);
- fdGCLock.close();
- debug(format("acquiring read lock on `%1%'") % fnTempRoots);
- lockFile(fdTempRoots, ltRead, true);
- /* Check whether the garbage collector didn't get in our
- way. */
- struct stat st;
- if (fstat(fdTempRoots, &st) == -1)
- throw SysError(format("statting `%1%'") % fnTempRoots);
- if (st.st_size == 0) break;
- /* The garbage collector deleted this file before we could
- get a lock. (It won't delete the file after we get a
- lock.) Try again. */
- }
- }
- /* Upgrade the lock to a write lock. This will cause us to block
- if the garbage collector is holding our lock. */
- debug(format("acquiring write lock on `%1%'") % fnTempRoots);
- lockFile(fdTempRoots, ltWrite, true);
- string s = path + '\0';
- writeFull(fdTempRoots, s);
- /* Downgrade to a read lock. */
- debug(format("downgrading to read lock on `%1%'") % fnTempRoots);
- lockFile(fdTempRoots, ltRead, true);
- }
- typedef std::shared_ptr<AutoCloseFD> FDPtr;
- typedef list<FDPtr> FDs;
- static void readTempRoots(PathSet & tempRoots, FDs & fds)
- {
- /* Read the `temproots' directory for per-process temporary root
- files. */
- DirEntries tempRootFiles = readDirectory(
- (format("%1%/%2%") % settings.nixStateDir % tempRootsDir).str());
- for (auto & i : tempRootFiles) {
- Path path = (format("%1%/%2%/%3%") % settings.nixStateDir % tempRootsDir % i.name).str();
- debug(format("reading temporary root file `%1%'") % path);
- FDPtr fd(new AutoCloseFD(open(path.c_str(), O_RDWR, 0666)));
- if (*fd == -1) {
- /* It's okay if the file has disappeared. */
- if (errno == ENOENT) continue;
- throw SysError(format("opening temporary roots file `%1%'") % path);
- }
- /* This should work, but doesn't, for some reason. */
- //FDPtr fd(new AutoCloseFD(openLockFile(path, false)));
- //if (*fd == -1) continue;
- /* Try to acquire a write lock without blocking. This can
- only succeed if the owning process has died. In that case
- we don't care about its temporary roots. */
- if (lockFile(*fd, ltWrite, false)) {
- printMsg(lvlError, format("removing stale temporary roots file `%1%'") % path);
- unlink(path.c_str());
- writeFull(*fd, "d");
- continue;
- }
- /* Acquire a read lock. This will prevent the owning process
- from upgrading to a write lock, therefore it will block in
- addTempRoot(). */
- debug(format("waiting for read lock on `%1%'") % path);
- lockFile(*fd, ltRead, true);
- /* Read the entire file. */
- string contents = readFile(*fd);
- /* Extract the roots. */
- string::size_type pos = 0, end;
- while ((end = contents.find((char) 0, pos)) != string::npos) {
- Path root(contents, pos, end - pos);
- debug(format("got temporary root `%1%'") % root);
- assertStorePath(root);
- tempRoots.insert(root);
- pos = end + 1;
- }
- fds.push_back(fd); /* keep open */
- }
- }
- static void foundRoot(StoreAPI & store,
- const Path & path, const Path & target, Roots & roots)
- {
- Path storePath = toStorePath(target);
- if (store.isValidPath(storePath))
- roots[path] = storePath;
- else
- printMsg(lvlInfo, format("skipping invalid root from `%1%' to `%2%'") % path % storePath);
- }
- static void findRoots(StoreAPI & store, const Path & path, unsigned char type, Roots & roots)
- {
- try {
- if (type == DT_UNKNOWN)
- type = getFileType(path);
- if (type == DT_DIR) {
- for (auto & i : readDirectory(path))
- findRoots(store, path + "/" + i.name, i.type, roots);
- }
- else if (type == DT_LNK) {
- Path target = readLink(path);
- if (isInStore(target))
- foundRoot(store, path, target, roots);
- /* Handle indirect roots. */
- else {
- target = absPath(target, dirOf(path));
- if (!pathExists(target)) {
- if (isInDir(path, settings.nixStateDir + "/" + gcRootsDir + "/auto")) {
- printMsg(lvlInfo, format("removing stale link from `%1%' to `%2%'") % path % target);
- unlink(path.c_str());
- }
- } else {
- struct stat st2 = lstat(target);
- if (!S_ISLNK(st2.st_mode)) return;
- Path target2 = readLink(target);
- if (isInStore(target2)) foundRoot(store, target, target2, roots);
- }
- }
- }
- else if (type == DT_REG) {
- Path storePath = settings.nixStore + "/" + baseNameOf(path);
- if (store.isValidPath(storePath))
- roots[path] = storePath;
- }
- }
- catch (SysError & e) {
- /* We only ignore permanent failures. */
- if (e.errNo == EACCES || e.errNo == ENOENT || e.errNo == ENOTDIR)
- printMsg(lvlInfo, format("cannot read potential root `%1%'") % path);
- else
- throw;
- }
- }
- Roots LocalStore::findRoots()
- {
- Roots roots;
- /* Process direct roots in {gcroots,manifests,profiles}. */
- nix::findRoots(*this, settings.nixStateDir + "/" + gcRootsDir, DT_UNKNOWN, roots);
- if (pathExists(settings.nixStateDir + "/manifests"))
- nix::findRoots(*this, settings.nixStateDir + "/manifests", DT_UNKNOWN, roots);
- nix::findRoots(*this, settings.nixStateDir + "/profiles", DT_UNKNOWN, roots);
- return roots;
- }
- static void addAdditionalRoots(StoreAPI & store, PathSet & roots)
- {
- debug(format("executing `%1% gc --list-busy' to find additional roots")
- % settings.guixProgram);
- const Strings args = { "gc", "--list-busy" };
- string result = runProgram(settings.guixProgram, false, args);
- StringSet paths = tokenizeString<StringSet>(result, "\n");
- foreach (StringSet::iterator, i, paths) {
- if (isInStore(*i)) {
- Path path = toStorePath(*i);
- if (roots.find(path) == roots.end() && store.isValidPath(path)) {
- debug(format("got additional root `%1%'") % path);
- roots.insert(path);
- }
- }
- }
- }
- struct GCLimitReached { };
- struct LocalStore::GCState
- {
- GCOptions options;
- GCResults & results;
- PathSet roots;
- PathSet tempRoots;
- PathSet dead;
- PathSet alive;
- bool gcKeepOutputs;
- bool gcKeepDerivations;
- unsigned long long bytesInvalidated;
- bool moveToTrash = true;
- Path trashDir;
- bool shouldDelete;
- GCState(GCResults & results_) : results(results_), bytesInvalidated(0) { }
- };
- bool LocalStore::isActiveTempFile(const GCState & state,
- const Path & path, const string & suffix)
- {
- return hasSuffix(path, suffix)
- && state.tempRoots.find(string(path, 0, path.size() - suffix.size())) != state.tempRoots.end();
- }
- void LocalStore::deleteGarbage(GCState & state, const Path & path)
- {
- unsigned long long bytesFreed;
- /* When deduplication is on, store items always have at least two links:
- the one at PATH, and one in /gnu/store/.links. In that case, increase
- bytesFreed when PATH has two or fewer links. */
- size_t linkThreshold =
- (settings.autoOptimiseStore && isStorePath(path)) ? 2 : 1;
- deletePath(path, bytesFreed, linkThreshold);
- state.results.bytesFreed += bytesFreed;
- }
- void LocalStore::deletePathRecursive(GCState & state, const Path & path)
- {
- checkInterrupt();
- unsigned long long size = 0;
- if (isValidPath(path)) {
- PathSet referrers;
- queryReferrers(path, referrers);
- foreach (PathSet::iterator, i, referrers)
- if (*i != path) deletePathRecursive(state, *i);
- size = queryPathInfo(path).narSize;
- invalidatePathChecked(path);
- }
- struct stat st;
- if (lstat(path.c_str(), &st)) {
- if (errno == ENOENT) return;
- throw SysError(format("getting status of %1%") % path);
- }
- if (state.options.maxFreed != ULLONG_MAX) {
- auto freed = state.results.bytesFreed + state.bytesInvalidated;
- double fraction = ((double) freed) / (double) state.options.maxFreed;
- unsigned int percentage = (fraction > 1. ? 1. : fraction) * 100.;
- printMsg(lvlInfo, format("[%1%%%] deleting '%2%'") % percentage % path);
- } else {
- auto freed = state.results.bytesFreed + state.bytesInvalidated;
- freed /= 1024ULL * 1024ULL;
- printMsg(lvlInfo, format("[%1% MiB] deleting '%2%'") % freed % path);
- }
- state.results.paths.insert(path);
- /* If the path is not a regular file or symlink, move it to the
- trash directory. The move is to ensure that later (when we're
- not holding the global GC lock) we can delete the path without
- being afraid that the path has become alive again. Otherwise
- delete it right away. */
- if (state.moveToTrash && S_ISDIR(st.st_mode)) {
- // Estimate the amount freed using the narSize field. FIXME:
- // if the path was not valid, need to determine the actual
- // size.
- try {
- if (chmod(path.c_str(), st.st_mode | S_IWUSR) == -1)
- throw SysError(format("making `%1%' writable") % path);
- Path tmp = state.trashDir + "/" + baseNameOf(path);
- if (rename(path.c_str(), tmp.c_str()))
- throw SysError(format("unable to rename `%1%' to `%2%'") % path % tmp);
- state.bytesInvalidated += size;
- } catch (SysError & e) {
- /* In a Docker container, rename(2) returns EXDEV when the source
- and destination are not both on the "top layer". See:
- https://bugs.gnu.org/41607 */
- if (e.errNo == ENOSPC || e.errNo == EXDEV) {
- printMsg(lvlInfo, format("note: can't create move `%1%': %2%") % path % e.msg());
- deleteGarbage(state, path);
- }
- }
- } else
- deleteGarbage(state, path);
- if (state.results.bytesFreed + state.bytesInvalidated > state.options.maxFreed) {
- printMsg(lvlInfo, format("deleted or invalidated more than %1% bytes; stopping") % state.options.maxFreed);
- throw GCLimitReached();
- }
- }
- bool LocalStore::canReachRoot(GCState & state, PathSet & visited, const Path & path)
- {
- if (visited.find(path) != visited.end()) return false;
- if (state.alive.find(path) != state.alive.end()) {
- return true;
- }
- if (state.dead.find(path) != state.dead.end()) {
- return false;
- }
- if (state.roots.find(path) != state.roots.end()) {
- printMsg(lvlDebug, format("cannot delete `%1%' because it's a root") % path);
- state.alive.insert(path);
- return true;
- }
- visited.insert(path);
- if (!isValidPath(path)) return false;
- PathSet incoming;
- /* Don't delete this path if any of its referrers are alive. */
- queryReferrers(path, incoming);
- /* If gc-keep-derivations is set and this is a derivation, then
- don't delete the derivation if any of the outputs are alive. */
- if (state.gcKeepDerivations && isDerivation(path)) {
- PathSet outputs = queryDerivationOutputs(path);
- foreach (PathSet::iterator, i, outputs)
- if (isValidPath(*i) && queryDeriver(*i) == path)
- incoming.insert(*i);
- }
- /* If gc-keep-outputs is set, then don't delete this path if there
- are derivers of this path that are not garbage. */
- if (state.gcKeepOutputs) {
- PathSet derivers = queryValidDerivers(path);
- foreach (PathSet::iterator, i, derivers)
- incoming.insert(*i);
- }
- foreach (PathSet::iterator, i, incoming)
- if (*i != path)
- if (canReachRoot(state, visited, *i)) {
- state.alive.insert(path);
- return true;
- }
- return false;
- }
- void LocalStore::tryToDelete(GCState & state, const Path & path)
- {
- checkInterrupt();
- if (path == linksDir || path == state.trashDir) return;
- startNest(nest, lvlDebug, format("considering whether to delete `%1%'") % path);
- if (!isValidPath(path)) {
- /* A lock file belonging to a path that we're building right
- now isn't garbage. */
- if (isActiveTempFile(state, path, ".lock")) return;
- /* Don't delete .chroot directories for derivations that are
- currently being built. */
- if (isActiveTempFile(state, path, ".chroot")) return;
- }
- PathSet visited;
- if (canReachRoot(state, visited, path)) {
- printMsg(lvlDebug, format("cannot delete `%1%' because it's still reachable") % path);
- } else {
- /* No path we visited was a root, so everything is garbage.
- But we only delete ‘path’ and its referrers here so that
- ‘nix-store --delete’ doesn't have the unexpected effect of
- recursing into derivations and outputs. */
- state.dead.insert(visited.begin(), visited.end());
- if (state.shouldDelete)
- deletePathRecursive(state, path);
- }
- }
- /* Unlink all files in /nix/store/.links that have a link count of 1,
- which indicates that there are no other links and so they can be
- safely deleted. FIXME: race condition with optimisePath(): we
- might see a link count of 1 just before optimisePath() increases
- the link count. */
- void LocalStore::removeUnusedLinks(const GCState & state)
- {
- AutoCloseDir dir = opendir(linksDir.c_str());
- if (!dir) throw SysError(format("opening directory `%1%'") % linksDir);
- long long actualSize = 0, unsharedSize = 0;
- struct dirent * dirent;
- while (errno = 0, dirent = readdir(dir)) {
- checkInterrupt();
- string name = dirent->d_name;
- if (name == "." || name == "..") continue;
- Path path = linksDir + "/" + name;
- #ifdef HAVE_STATX
- # define st_size stx_size
- # define st_nlink stx_nlink
- static int statx_flags = AT_SYMLINK_NOFOLLOW | AT_STATX_DONT_SYNC;
- struct statx st;
- if (statx(AT_FDCWD, path.c_str(), statx_flags,
- STATX_SIZE | STATX_NLINK, &st) == -1) {
- if (errno == EINVAL) {
- /* Old 3.10 kernels (CentOS 7) don't support
- AT_STATX_DONT_SYNC, so try again without it. */
- statx_flags &= ~AT_STATX_DONT_SYNC;
- if (statx(AT_FDCWD, path.c_str(), statx_flags,
- STATX_SIZE | STATX_NLINK, &st) == -1)
- throw SysError(format("statting `%1%'") % path);
- } else {
- throw SysError(format("statting `%1%'") % path);
- }
- }
- #else
- struct stat st;
- if (lstat(path.c_str(), &st) == -1)
- throw SysError(format("statting `%1%'") % path);
- #endif
- if (st.st_nlink != 1) {
- actualSize += st.st_size;
- unsharedSize += (st.st_nlink - 1) * st.st_size;
- continue;
- }
- printMsg(lvlTalkative, format("deleting unused link `%1%'") % path);
- if (unlink(path.c_str()) == -1)
- throw SysError(format("deleting `%1%'") % path);
- state.results.bytesFreed += st.st_size;
- #undef st_size
- #undef st_nlink
- }
- struct stat st;
- if (stat(linksDir.c_str(), &st) == -1)
- throw SysError(format("statting `%1%'") % linksDir);
- long long overhead = st.st_size;
- printMsg(lvlInfo, format("note: currently hard linking saves %.2f MiB")
- % ((unsharedSize - actualSize - overhead) / (1024.0 * 1024.0)));
- }
- void LocalStore::collectGarbage(const GCOptions & options, GCResults & results)
- {
- GCState state(results);
- state.options = options;
- state.trashDir = settings.nixStore + "/trash";
- state.gcKeepOutputs = settings.gcKeepOutputs;
- state.gcKeepDerivations = settings.gcKeepDerivations;
- /* Using `--ignore-liveness' with `--delete' can have unintended
- consequences if `gc-keep-outputs' or `gc-keep-derivations' are
- true (the garbage collector will recurse into deleting the
- outputs or derivers, respectively). So disable them. */
- if (options.action == GCOptions::gcDeleteSpecific && options.ignoreLiveness) {
- state.gcKeepOutputs = false;
- state.gcKeepDerivations = false;
- }
- state.shouldDelete = options.action == GCOptions::gcDeleteDead || options.action == GCOptions::gcDeleteSpecific;
- /* Acquire the global GC root. This prevents
- a) New roots from being added.
- b) Processes from creating new temporary root files. */
- AutoCloseFD fdGCLock = openGCLock(ltWrite);
- /* Find the roots. Since we've grabbed the GC lock, the set of
- permanent roots cannot increase now. */
- printMsg(lvlError, format("finding garbage collector roots..."));
- Roots rootMap = options.ignoreLiveness ? Roots() : findRoots();
- foreach (Roots::iterator, i, rootMap) state.roots.insert(i->second);
- /* Add additional roots returned by 'guix gc --list-busy'. This is
- typically used to add running programs to the set of roots (to prevent
- them from being garbage collected). */
- if (!options.ignoreLiveness)
- addAdditionalRoots(*this, state.roots);
- /* Read the temporary roots. This acquires read locks on all
- per-process temporary root files. So after this point no paths
- can be added to the set of temporary roots. */
- FDs fds;
- readTempRoots(state.tempRoots, fds);
- state.roots.insert(state.tempRoots.begin(), state.tempRoots.end());
- /* After this point the set of roots or temporary roots cannot
- increase, since we hold locks on everything. So everything
- that is not reachable from `roots' is garbage. */
- if (state.shouldDelete) {
- if (pathExists(state.trashDir)) deleteGarbage(state, state.trashDir);
- try {
- createDirs(state.trashDir);
- } catch (SysError & e) {
- if (e.errNo == ENOSPC) {
- printMsg(lvlInfo, format("note: can't create trash directory: %1%") % e.msg());
- state.moveToTrash = false;
- }
- }
- }
- /* Now either delete all garbage paths, or just the specified
- paths (for gcDeleteSpecific). */
- if (options.action == GCOptions::gcDeleteSpecific) {
- foreach (PathSet::iterator, i, options.pathsToDelete) {
- assertStorePath(*i);
- tryToDelete(state, *i);
- if (state.dead.find(*i) == state.dead.end())
- throw Error(format("cannot delete path `%1%' since it is still alive") % *i);
- }
- } else if (options.maxFreed > 0) {
- if (state.shouldDelete)
- printMsg(lvlError, format("deleting garbage..."));
- else
- printMsg(lvlError, format("determining live/dead paths..."));
- try {
- AutoCloseDir dir = opendir(settings.nixStore.c_str());
- if (!dir) throw SysError(format("opening directory `%1%'") % settings.nixStore);
- /* Read the store and immediately delete all paths that
- aren't valid. When using --max-freed etc., deleting
- invalid paths is preferred over deleting unreachable
- paths, since unreachable paths could become reachable
- again. We don't use readDirectory() here so that GCing
- can start faster. */
- Paths entries;
- struct dirent * dirent;
- while (errno = 0, dirent = readdir(dir)) {
- checkInterrupt();
- string name = dirent->d_name;
- if (name == "." || name == "..") continue;
- Path path = settings.nixStore + "/" + name;
- if (isValidPath(path))
- entries.push_back(path);
- else
- tryToDelete(state, path);
- }
- dir.close();
- /* Now delete the unreachable valid paths. Randomise the
- order in which we delete entries to make the collector
- less biased towards deleting paths that come
- alphabetically first (e.g. /nix/store/000...). This
- matters when using --max-freed etc. */
- vector<Path> entries_(entries.begin(), entries.end());
- random_shuffle(entries_.begin(), entries_.end());
- foreach (vector<Path>::iterator, i, entries_)
- tryToDelete(state, *i);
- } catch (GCLimitReached & e) {
- }
- }
- if (state.options.action == GCOptions::gcReturnLive) {
- state.results.paths = state.alive;
- return;
- }
- if (state.options.action == GCOptions::gcReturnDead) {
- state.results.paths = state.dead;
- return;
- }
- /* Allow other processes to add to the store from here on. */
- fdGCLock.close();
- fds.clear();
- /* Delete the trash directory. */
- printMsg(lvlInfo, format("deleting `%1%'") % state.trashDir);
- deleteGarbage(state, state.trashDir);
- /* Clean up the links directory. */
- if (options.action == GCOptions::gcDeleteDead || options.action == GCOptions::gcDeleteSpecific) {
- printMsg(lvlError, format("deleting unused links..."));
- removeUnusedLinks(state);
- }
- /* While we're at it, vacuum the database. */
- //if (options.action == GCOptions::gcDeleteDead) vacuumDB();
- }
- }
|