summaryrefslogtreecommitdiffstats
diff options
context:
space:
mode:
authorSimon Rettberg2024-05-08 18:42:18 +0200
committerSimon Rettberg2024-05-08 18:42:18 +0200
commit0082ee56a557575cbad60f7efb55a12a2f9953dd (patch)
tree8b1cc0d464bc521bf132fa1805e14bd2c16a8e02
parent[server] Add support for CoW sessions (diff)
downloadtutor-module-0082ee56a557575cbad60f7efb55a12a2f9953dd.tar.gz
tutor-module-0082ee56a557575cbad60f7efb55a12a2f9953dd.tar.xz
tutor-module-0082ee56a557575cbad60f7efb55a12a2f9953dd.zip
[server] ADD FUSDDS STIFF
-rw-r--r--dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/Cow.java27
-rw-r--r--dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowFinalizer.java207
-rw-r--r--dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowSession.java452
-rw-r--r--dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowSessionData.java47
-rw-r--r--dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowSessionManager.java87
-rw-r--r--dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/util/BashVars.java46
6 files changed, 866 insertions, 0 deletions
diff --git a/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/Cow.java b/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/Cow.java
new file mode 100644
index 00000000..9c4b6d81
--- /dev/null
+++ b/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/Cow.java
@@ -0,0 +1,27 @@
+package org.openslx.bwlp.sat.fileserv.cow;
+
+public class Cow {
+
+ public static int BLOCK_SIZE = 4096;
+
+ /** Number of bytes of a L2 entry bit field */
+ public static int BITFIELD_SIZE = 40;
+
+ public static int BITFIELD_BITS = BITFIELD_SIZE * 8;
+
+ /**
+ * Number of entries in L2 table, that each will have a 320bit mask for all
+ * the blocks in the L2 entry
+ */
+ public static int L2_TABLE_ENTRIES = 1024;
+
+ /** 1280KiB. Size of a cluster's data in bytes */
+ public static int L2_CLUSTER_DATA_SIZE = BITFIELD_BITS * BLOCK_SIZE;
+
+ /**
+ * 1280MiB. Net capacity of a full L1 entry referring to data clusters, i.e.
+ * what is addressable by an L2 table (=L1 entry)
+ */
+ public static int FULL_L2_TABLE_DATA_SIZE = L2_TABLE_ENTRIES * L2_CLUSTER_DATA_SIZE;
+
+}
diff --git a/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowFinalizer.java b/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowFinalizer.java
new file mode 100644
index 00000000..b305374a
--- /dev/null
+++ b/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowFinalizer.java
@@ -0,0 +1,207 @@
+package org.openslx.bwlp.sat.fileserv.cow;
+
+import java.io.File;
+import java.io.IOException;
+import java.io.RandomAccessFile;
+import java.nio.file.Files;
+import java.nio.file.StandardCopyOption;
+import java.sql.SQLException;
+import java.util.UUID;
+import java.util.concurrent.Semaphore;
+
+import org.apache.commons.io.FileUtils;
+import org.apache.logging.log4j.LogManager;
+import org.apache.logging.log4j.Logger;
+import org.openslx.bwlp.sat.database.mappers.DbImage;
+import org.openslx.bwlp.sat.permissions.User;
+import org.openslx.bwlp.sat.thrift.cache.OperatingSystemList;
+import org.openslx.bwlp.sat.util.Configuration;
+import org.openslx.bwlp.sat.util.FileSystem;
+import org.openslx.bwlp.thrift.iface.ImageBaseWrite;
+import org.openslx.bwlp.thrift.iface.ImageDetailsRead;
+import org.openslx.bwlp.thrift.iface.ImageVersionWrite;
+import org.openslx.filetransfer.util.ChunkList;
+import org.openslx.filetransfer.util.FileChunk;
+import org.openslx.filetransfer.util.HashChecker;
+import org.openslx.filetransfer.util.HashChecker.HashCheckCallback;
+import org.openslx.filetransfer.util.HashChecker.HashResult;
+import org.openslx.filetransfer.util.IncomingTransferBase;
+import org.openslx.virtualization.configuration.VirtualizationConfiguration;
+import org.openslx.virtualization.configuration.VirtualizationConfigurationException;
+
+/**
+ * After a successful CoW session, hash the new image and create the database
+ * entry.
+ */
+public class CowFinalizer {
+
+ private static final Logger LOGGER = LogManager.getLogger(CowFinalizer.class);
+
+ private ChunkList chunks;
+
+ private boolean hashesDone;
+
+ private final CowSessionData data;
+
+ private String error;
+
+ private int progressPercent;
+
+ private CowSession cowSession;
+
+ public CowFinalizer(CowSessionData data, CowSession cowSession) {
+ this.data = data;
+ this.cowSession = cowSession;
+ if (data.newFileSize() == -1)
+ throw new IllegalStateException("Initialized finalizer before new file size was set");
+ worker.start();
+ }
+
+ private void setError(String msg) {
+ if (this.error != null)
+ return;
+ LOGGER.warn(msg);
+ this.error = msg;
+ if (cowSession != null) {
+ cowSession.finalizerFinished();
+ cowSession = null;
+ }
+ }
+
+ public int progressPercent() {
+ return this.progressPercent;
+ }
+
+ public String getError() {
+ return this.error;
+ }
+
+ private void calculateHashes() throws IOException {
+ byte[] buffer = new byte[FileChunk.CHUNK_SIZE];
+ HashChecker hc = IncomingTransferBase.getHashChecker();
+ if (hc == null) {
+ LOGGER.info("No hash checker, skipping...");
+ return;
+ }
+ final Semaphore pendingChunks;
+ try (RandomAccessFile file = new RandomAccessFile(data.temporaryImageFile, "r")) {
+ chunks = new ChunkList(data.temporaryImageFile.length(), null);
+ int chunkCount = chunks.getAll().size();
+ pendingChunks = new Semaphore(0);
+ HashCheckCallback cb = new HashCheckCallback() {
+ @Override
+ public void hashCheckDone(HashResult result, byte[] data, FileChunk chunk) {
+ pendingChunks.release();
+ progressPercent = (pendingChunks.availablePermits() * 100) / (chunkCount + 1);
+ }
+ };
+ for (FileChunk chunk : chunks.getAll()) {
+ file.readFully(buffer, 0, chunk.range.getLength());
+ hc.queue(chunk, buffer, cb, HashChecker.BLOCKING | HashChecker.CALC_CRC32 | HashChecker.CALC_SHA1
+ | HashChecker.NO_SLOW_WARN);
+ }
+ pendingChunks.acquire(chunkCount);
+ progressPercent = 99;
+ hashesDone = true;
+ } catch (InterruptedException e) {
+ LOGGER.info("Interrupted while hashing");
+ Thread.currentThread().interrupt();
+ return;
+ }
+ }
+
+ private final Thread worker = new Thread("cow-work") {
+ @Override
+ public void run() {
+ // Sanity check: destination should be a sub directory of the vmStorePath
+ String relPath = FileSystem.getRelativePath(data.destinationFile,
+ Configuration.getVmStoreBasePath());
+ if (relPath == null) {
+ setError(data.destinationFile.getAbsolutePath() + " is not a subdir of "
+ + Configuration.getVmStoreBasePath().getAbsolutePath());
+ return;
+ }
+ // First, generate hashes as this might take a while
+ try {
+ calculateHashes();
+ } catch (IOException e) {
+ LOGGER.warn("Cannot calculate hashes of new image, continuing without", e);
+ }
+ if (hashesDone) {
+ // Put into proper place
+ try {
+ FileUtils.writeByteArrayToFile(new File(data.destinationFile + ".crc"),
+ chunks.getDnbd3Crc32List());
+ } catch (IllegalStateException | IOException e) {
+ LOGGER.warn("Could not write dnbd3 crc list", e);
+ }
+ }
+ // Now move file to final destination
+ try {
+ Files.move(data.temporaryImageFile.toPath(), data.destinationFile.toPath(),
+ StandardCopyOption.ATOMIC_MOVE);
+ } catch (IOException e1) {
+ LOGGER.warn("Cannot rename", e1);
+ if (!data.temporaryImageFile.renameTo(data.destinationFile)) {
+ setError("Renaming temporary file to final name failed");
+ return;
+ }
+ }
+ // Add DB entries
+ String uuid = UUID.randomUUID().toString();
+ try {
+ boolean copy = true;
+ if ("EDIT".equals(data.sessionType)) {
+ try {
+ User.canEditBaseImageOrFail(data.owner, data.imageBaseId);
+ copy = false;
+ } catch (Exception e) {
+
+ }
+ }
+ String baseId = data.imageBaseId;
+ if (copy) {
+ String imgName;
+ ImageBaseWrite ibw = new ImageBaseWrite();
+ ImageDetailsRead id = null;
+ try {
+ id = DbImage.getImageDetails(null, data.imageBaseId);
+ imgName = id.imageName;
+ } catch (Exception e) {
+ imgName = "[UNKNOWN VM]";
+ }
+ ibw.setImageName("Copy of " + imgName);
+ if (id != null) {
+ ibw.setDefaultPermissions(id.defaultPermissions);
+ ibw.setDescription(ibw.imageName);
+ ibw.setOsId(id.osId);
+ ibw.setVirtId(ibw.virtId);
+ } else {
+ try {
+ VirtualizationConfiguration conf = VirtualizationConfiguration.getInstance(
+ OperatingSystemList.get(), data.machineDescription, data.machineDescription.length);
+ ibw.setVirtId(conf.getVirtualizer().getId());
+ } catch (IOException | VirtualizationConfigurationException e) {
+ LOGGER.error("Can neither get virtID from existing image, nor guess from description", e);
+ }
+ }
+ baseId = DbImage.createImage(data.owner, ibw.imageName);
+ DbImage.updateImageMetadata(null, baseId, ibw);
+ }
+ DbImage.createImageVersion(baseId, uuid, data.owner, data.newFileSize(),
+ relPath, new ImageVersionWrite(data.restricted), hashesDone ? chunks : null,
+ data.machineDescription);
+ } catch (SQLException e) {
+ setError("Cannot write new version to database");
+ return;
+ }
+ LOGGER.info("Processing CoW session done.");
+ progressPercent = 100;
+ if (cowSession != null) {
+ cowSession.finalizerFinished();
+ cowSession = null;
+ }
+ }
+ };
+
+}
diff --git a/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowSession.java b/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowSession.java
new file mode 100644
index 00000000..f53cb2cc
--- /dev/null
+++ b/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowSession.java
@@ -0,0 +1,452 @@
+package org.openslx.bwlp.sat.fileserv.cow;
+
+import java.io.File;
+import java.io.IOException;
+import java.io.RandomAccessFile;
+import java.nio.file.Files;
+import java.util.ArrayList;
+import java.util.List;
+
+import org.apache.logging.log4j.Level;
+import org.apache.logging.log4j.LogManager;
+import org.apache.logging.log4j.Logger;
+import org.openslx.bwlp.sat.util.Configuration;
+import org.openslx.bwlp.sat.util.Formatter;
+import org.openslx.bwlp.thrift.iface.UserInfo;
+import org.openslx.util.Json;
+import org.openslx.util.Util;
+
+public class CowSession {
+
+ // DO NOT RENAME THESE!
+ // Used as string literal in JSON status, expected like this on client
+ static enum Status {
+ COPYING, // Still busy copying original file, new chunks are only accepted in already copied range
+ WAITING_FOR_UPLOAD_DONE, // Copying done, just waiting for new chunks until client signals that it's done
+ WAITING_FOR_COPYING_DONE, // Copying not done, but dnbd3-fuse already told us it's done, wait for copying
+ UPLOAD_DONE, // dnbd3-fuse signaled merge request, upload is thus done and no new chunks are accepted
+ PROCESSING, // Hashing, renaming, creating DB entry
+ ERROR,
+ COMPLETELY_DONE;
+ }
+
+ private static final Logger LOGGER = LogManager.getLogger(CowSession.class);
+
+ private static int TIMEOUT_MS = 12 * 3600_000; // No update for 12 hours, assume session died
+
+ private static int COPY_BLOCK_SIZE = 1024 * 1024; // 1 MiB
+
+ public long lastActivity = Util.tickCount();
+
+ private final long sourceFileSize;
+ private RandomAccessFile sourceFile;
+ private RandomAccessFile destinationFile;
+ private Thread copyThread;
+ private Status status = Status.COPYING;
+
+ private final CowSessionData data;
+
+ private int estimatedSpeedKbs = 0;
+
+ /**
+ * Use for operations on destinationFile.
+ * Not needed for sourceFile for now, as it's only touched in initialization
+ * once, and then in the copy thread.
+ */
+ private final Object destFileLock = new Object();
+
+ /** Catch-all lock for: status, copyThread */
+ private final Object varLock = new Object();
+
+ /**
+ * Progress of copying the original image to a new file, which happens in
+ * the background
+ */
+ private long fileCopyPosition = 0;
+
+ /** Error message to supply to client */
+ private String errorMessage;
+
+ private CowFinalizer finalizer;
+
+ public CowSession(String sourceFileName, byte[] machineDescription, String imageBaseId, String vmName,
+ boolean restricted, UserInfo owner, String sessionType) {
+ RandomAccessFile srcFile;
+ try {
+ srcFile = new RandomAccessFile(Configuration.getVmStoreBasePath() + "/" + sourceFileName, "r");
+ } catch (IOException e) {
+ setError("Cannot open source file for reading", e);
+ srcFile = null;
+ }
+ // Create filenames
+ File tmpFile = null;
+ do {
+ tmpFile = Formatter.getTempImageName();
+ } while (tmpFile.exists());
+ tmpFile.getParentFile().mkdirs();
+ String ext = sourceFileName.replaceFirst("^.*\\.", "");
+ File finalFile = new File(tmpFile.getParent(),
+ Formatter.vmName(System.currentTimeMillis(), owner, vmName,
+ ext)).getAbsoluteFile();
+ RandomAccessFile df = null;
+ long sfl = -1;
+ try {
+ df = new RandomAccessFile(tmpFile, "rw");
+ } catch (Exception e) {
+ setError("Cannot open destination file for writing", e);
+ }
+ if (srcFile != null) {
+ try {
+ sfl = srcFile.length();
+ } catch (IOException e) {
+ setError("Cannot determine size of source file", e);
+ }
+ }
+ this.sourceFileSize = sfl;
+ if (srcFile != null && df != null && sfl != -1) {
+ this.sourceFile = srcFile;
+ this.destinationFile = df;
+ } else {
+ Util.safeClose(srcFile, df);
+ }
+ this.data = new CowSessionData(imageBaseId, restricted, tmpFile, finalFile, owner,
+ machineDescription, sessionType);
+ startCopying();
+ }
+
+ public boolean timedout() {
+ if (status == Status.COMPLETELY_DONE || status == Status.ERROR)
+ return Util.tickCount() > lastActivity + 300_000;
+ return Util.tickCount() > lastActivity + TIMEOUT_MS;
+ }
+
+ public String getError() {
+ return errorMessage;
+ }
+
+ /**
+ * Get current status of transfer as JSON. Will be an array of objects with key 'title'
+ * and optional keys 'error' and 'percent'.
+ * @return
+ */
+ public String getStatusJson() {
+ JsonStatus ret = new JsonStatus();
+ if (status == Status.COPYING || status == Status.WAITING_FOR_COPYING_DONE) {
+ ret.tasks.add(new ProgressItem("Copying source file", (int) (fileCopyPosition * 100 / sourceFileSize),
+ errorMessage));
+ } else {
+ ret.tasks.add(new ProgressItem("Waiting for Upload to finish",
+ status == Status.WAITING_FOR_UPLOAD_DONE ? -1 : 100, errorMessage));
+ }
+ if (finalizer != null) {
+ ret.tasks.add(new ProgressItem("Hashing modified image", finalizer.progressPercent(),
+ finalizer.getError()));
+ }
+ ret.state = this.status.name();
+ return Json.serialize(ret);
+ }
+
+ /**
+ * Set new status of this cow session, but take care that we can't change
+ * back e.g. from ERROR to WORKING.
+ */
+ private void setStatus(Status s) {
+ if (this.status == Status.ERROR || this.status == Status.COMPLETELY_DONE)
+ return;
+ if (s != Status.ERROR) {
+ boolean illegal = false;
+ switch (status) {
+ case ERROR:
+ case COMPLETELY_DONE:
+ break;
+ case COPYING:
+ illegal = (s != Status.WAITING_FOR_UPLOAD_DONE && s != Status.WAITING_FOR_COPYING_DONE);
+ break;
+ case WAITING_FOR_UPLOAD_DONE:
+ illegal = (s != Status.UPLOAD_DONE);
+ break;
+ case WAITING_FOR_COPYING_DONE:
+ illegal = (s != Status.UPLOAD_DONE);
+ break;
+ case UPLOAD_DONE:
+ illegal = (s != Status.PROCESSING);
+ break;
+ case PROCESSING:
+ illegal = (s != Status.COMPLETELY_DONE);
+ break;
+ }
+ if (illegal) {
+ LOGGER.log(Level.ERROR, "Illegal state change: " + status + " -> " + s,
+ new RuntimeException());
+ }
+ }
+ this.status = s;
+ }
+
+ private boolean transition(Status from, Status to) {
+ synchronized (varLock) {
+ if (this.status != from)
+ return false;
+ setStatus(to);
+ }
+ return true;
+ }
+
+ private void setError(String message, Exception e) {
+ LOGGER.log(Level.ERROR, message, e);
+ if (errorMessage == null) {
+ this.errorMessage = message;
+ setStatus(Status.ERROR);
+ }
+ }
+
+ /**
+ * Abort an ongoing CoW session. Deletes the destination file, and causes
+ * the copy thread to exit, if it is still running.
+ */
+ public void abort() {
+ synchronized (varLock) {
+ if (status == Status.ERROR || status == Status.COMPLETELY_DONE)
+ return;
+ setError("Session aborted by user", null);
+ }
+ synchronized (destFileLock) {
+ Util.safeClose(destinationFile);
+ destinationFile = null;
+ }
+ LOGGER.info("Deleting " + data.temporaryImageFile.getPath());
+ try {
+ Files.delete(data.temporaryImageFile.toPath());
+ } catch (Exception e) {
+ LOGGER.log(Level.WARN, "Cannot delete CoW file for aborted session", e);
+ }
+ }
+
+ /**
+ * dnbd3-fuse notifies us that the upload finished.
+ */
+ public void uploadFinished(long newFileSize) throws IllegalTransitionException {
+ synchronized (varLock) {
+ if (!transition(Status.WAITING_FOR_UPLOAD_DONE, Status.UPLOAD_DONE)
+ && !transition(Status.COPYING, Status.WAITING_FOR_COPYING_DONE))
+ throw new IllegalTransitionException("Cannot mark upload as finished, unexpected state " + status);
+ }
+ LOGGER.info("Upload of clusters for '" + data.destinationFile + "' finished, final size: " + newFileSize);
+ data.setFinalSize(newFileSize);
+ }
+
+ /**
+ * Remote client called for finishing up the session, e.g. keep the modified
+ * image and add the according database entries.
+ */
+ public void requestFinalization() throws IllegalTransitionException {
+ synchronized (varLock) {
+ if (!transition(Status.UPLOAD_DONE, Status.PROCESSING))
+ throw new IllegalTransitionException("Cannot finish before upload is complete");
+ Util.safeClose(destinationFile);
+ destinationFile = null;
+ LOGGER.info("Finalization of '" + data.destinationFile + "' requested");
+ this.finalizer = new CowFinalizer(data, this);
+ lastActivity = Util.tickCount();
+ }
+ }
+
+ void finalizerFinished() {
+ if (finalizer == null)
+ return;
+ if (finalizer.getError() == null) {
+ setStatus(Status.COMPLETELY_DONE);
+ } else {
+ setStatus(Status.ERROR);
+ }
+ }
+
+ /**
+ * Add data from a modified cluster to the image.
+ *
+ * @param clusterIndex absolute index of cluster in file, i.e.
+ * file_offset / cluster_size
+ * @param rawData raw submitted data - bitmask plus changed blocks in chunk
+ * @return 0 on success, -1 on error, or a desired throttle in seconds to
+ * forward to client
+ */
+ public int addCluster(long clusterIndex, byte[] rawData) {
+ if (rawData.length < Cow.BITFIELD_SIZE) {
+ LOGGER.warn("Short cluster upload: Not enough payload for bitfield"
+ + " (" + rawData.length + " bytes)");
+ return -1;
+ }
+ int readPos = Cow.BITFIELD_SIZE;
+ synchronized (destFileLock) {
+ if (destinationFile == null) {
+ setError("Destination file already closed", null);
+ return -1;
+ }
+ for (int byt = 0; byt < Cow.BITFIELD_SIZE; ++byt) {
+ int bytVal = rawData[byt] & 0xff;
+ for (int bit = 0; bit < 8; ++bit) {
+ if ((bytVal & (1 << bit)) == 0)
+ continue;
+ // Block changed
+ if (readPos + Cow.BLOCK_SIZE > rawData.length) {
+ LOGGER.warn("Not enough data payload for COW block (short of "
+ + (readPos + Cow.BLOCK_SIZE - rawData.length) + " bytes)");
+ return -1;
+ }
+ int ret = writeBlock(clusterIndex * Cow.BITFIELD_BITS + byt * 8 + bit, rawData, readPos);
+ if (ret != 0) {
+ return ret;
+ }
+ readPos += Cow.BLOCK_SIZE;
+ }
+ }
+ }
+ lastActivity = Util.tickCount();
+ return 0;
+ }
+
+ /**
+ * Write a block (4k) out to the image as it changed. This does not acquire
+ * "lock", do so in the caller!
+ *
+ * @param blockIndex absolute index in image file
+ * @param readArrayStart start pointer in rawData for the 4k block in
+ * question
+ * @param rawData modified blocks, in order of bitmask
+ * @return 0 on success, -1 on error, or a desired throttle in seconds to
+ * forward to client
+ */
+ private int writeBlock(long blockIndex, byte[] rawData, int readArrayStart) {
+ if (status == Status.ERROR)
+ return -1;
+
+ long filePos = blockIndex * Cow.BLOCK_SIZE;
+ long missing = filePos + Cow.BLOCK_SIZE - fileCopyPosition;
+ if (status == Status.COPYING && missing > 0) {
+ int delay = 30;
+ if (estimatedSpeedKbs > 0) {
+ delay = (int) ((missing / 1000) / estimatedSpeedKbs);
+ }
+ LOGGER.info("Throttling client - Missing: " + Util.formatBytes(missing) + ", Speed: "
+ + Util.formatBytes(estimatedSpeedKbs * 1000) + "/s, Wait: " + delay);
+ return delay;
+ }
+ try {
+ destinationFile.seek(filePos);
+ destinationFile.write(rawData, readArrayStart, Cow.BLOCK_SIZE);
+ } catch (IOException e) {
+ setError("Cannot write changed cluster to destination file, aborting CoW session", e);
+ Util.safeClose(destinationFile);
+ destinationFile = null;
+ return -1;
+ }
+ return 0;
+ }
+
+ /**
+ * Copy file from source to dest in the background
+ */
+ private void startCopying() {
+ Thread t = new Thread() {
+ @Override
+ public void run() {
+ long lastTime = Util.tickCount();
+ long byteCount = 0;
+ int[] history = new int[10];
+ int historySlot = 0;
+ try {
+ byte[] chunk = new byte[COPY_BLOCK_SIZE];
+ sourceFile.seek(0);
+ while (fileCopyPosition < sourceFileSize) {
+ int num = sourceFile.read(chunk);
+ if (num == -1) {
+ setError("Unexpected end of file while copying CoW file"
+ + " (" + fileCopyPosition + "/" + sourceFileSize + ")", null);
+ return;
+ }
+ synchronized (destFileLock) {
+ // Might be null if we aborted, or an error occurred
+ if (destinationFile == null)
+ return;
+ destinationFile.seek(fileCopyPosition);
+ destinationFile.write(chunk, 0, num);
+ }
+ fileCopyPosition += num;
+ byteCount += num;
+ if (byteCount > COPY_BLOCK_SIZE * 5) {
+ long now = Util.tickCount();
+ long delta = now - lastTime;
+ if (delta > 1000) {
+ history[historySlot++ % history.length] = (int) (byteCount / delta);
+ byteCount = 0;
+ lastTime = now;
+ updateSpeedEstimate(history);
+ }
+ }
+ }
+ synchronized (varLock) {
+ if (!transition(Status.WAITING_FOR_COPYING_DONE, Status.UPLOAD_DONE)
+ && !transition(Status.COPYING, Status.WAITING_FOR_UPLOAD_DONE)) {
+ LOGGER.warn("Unexpected state after copying finished: " + status);
+ }
+ }
+ } catch (IOException e) {
+ setError("Error copying original file to new destination", e);
+ } finally {
+ Util.safeClose(sourceFile);
+ sourceFile = null;
+ }
+ synchronized (varLock) {
+ copyThread = null;
+ }
+ }
+
+ private void updateSpeedEstimate(int[] values) {
+ int sum = 0;
+ for (int i = 0; i < values.length; ++i) {
+ // Some slots might still be 0 in the beginning, so for the first 10+ seconds
+ // we underestimate. But that shouldn't matter since background upload on the
+ // client only starts 60 seconds in.
+ sum += values[i];
+ }
+ // This is effectively KB/s, as we divided by milliseconds, not seconds
+ estimatedSpeedKbs = sum;
+ }
+ };
+ synchronized (varLock) {
+ copyThread = t;
+ copyThread.setDaemon(true);
+ copyThread.start();
+ }
+ }
+
+ public static class IllegalTransitionException extends Exception {
+
+ private static final long serialVersionUID = -6792998975872772519L;
+
+ public IllegalTransitionException(String message) {
+ super(message);
+ }
+ }
+
+ @SuppressWarnings("unused")
+ private static class ProgressItem {
+ public final String title;
+ public final int percent;
+ public final String error;
+
+ public ProgressItem(String title, int percent, String error) {
+ this.title = title;
+ this.percent = percent;
+ this.error = error;
+ }
+ }
+
+ private static class JsonStatus
+ {
+ @SuppressWarnings("unused")
+ String state;
+ List<ProgressItem> tasks = new ArrayList<>();
+ }
+
+}
diff --git a/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowSessionData.java b/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowSessionData.java
new file mode 100644
index 00000000..58a12e44
--- /dev/null
+++ b/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowSessionData.java
@@ -0,0 +1,47 @@
+package org.openslx.bwlp.sat.fileserv.cow;
+
+import java.io.File;
+
+import org.openslx.bwlp.thrift.iface.UserInfo;
+
+public class CowSessionData {
+
+ public final String imageBaseId;
+
+ public final boolean restricted;
+
+ public final File temporaryImageFile;
+
+ public final File destinationFile;
+
+ public final UserInfo owner;
+
+ public final byte[] machineDescription;
+
+ private long newFileSize = -1;
+
+ public final String sessionType;
+
+ public CowSessionData(String imageBaseId, boolean restricted, File tmpFile, File destFile,
+ UserInfo owner, byte[] machineDescription, String sessionType) {
+ this.imageBaseId = imageBaseId;
+ this.restricted = restricted;
+ this.temporaryImageFile = tmpFile;
+ this.destinationFile = destFile;
+ this.owner = owner;
+ this.machineDescription = machineDescription;
+ this.sessionType = sessionType;
+
+ }
+
+ public void setFinalSize(long newFileSize) {
+ if (this.newFileSize != -1)
+ throw new IllegalStateException("Cannot set new filesize twice!");
+ this.newFileSize = newFileSize;
+ }
+
+ public long newFileSize() {
+ return this.newFileSize;
+ }
+
+}
diff --git a/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowSessionManager.java b/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowSessionManager.java
new file mode 100644
index 00000000..679e2551
--- /dev/null
+++ b/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/fileserv/cow/CowSessionManager.java
@@ -0,0 +1,87 @@
+package org.openslx.bwlp.sat.fileserv.cow;
+
+import java.util.HashMap;
+import java.util.Iterator;
+import java.util.Map;
+import java.util.UUID;
+import java.util.concurrent.locks.Lock;
+import java.util.concurrent.locks.ReadWriteLock;
+import java.util.concurrent.locks.ReentrantReadWriteLock;
+
+import org.openslx.bwlp.sat.database.mappers.DbLecture.LaunchData;
+import org.openslx.bwlp.sat.thrift.SessionManager;
+import org.openslx.bwlp.thrift.iface.UserInfo;
+import org.openslx.util.QuickTimer;
+import org.openslx.util.QuickTimer.Task;
+
+public class CowSessionManager {
+
+ private static final ReadWriteLock SESSION_LOCK = new ReentrantReadWriteLock();
+
+ private static final Map<String, CowSession> SESSIONS = new HashMap<>();
+
+ static {
+ QuickTimer.scheduleAtFixedDelay(new Task() {
+ @Override
+ public void fire() {
+ Lock lock = SESSION_LOCK.writeLock();
+ lock.lock();
+ try {
+ for (Iterator<CowSession> iterator = SESSIONS.values().iterator(); iterator.hasNext();) {
+ CowSession s = iterator.next();
+ if (s.timedout()) {
+ s.abort();
+ iterator.remove();
+ }
+ }
+ } finally {
+ lock.unlock();
+ }
+ }
+ }, 3600_577, 3601_010);
+ }
+
+ public static CowSession get(String id) {
+ Lock lock = SESSION_LOCK.readLock();
+ lock.lock();
+ try {
+ return SESSIONS.get(id);
+ } finally {
+ lock.unlock();
+ }
+ }
+
+ public static boolean add(String id, CowSession session) {
+ Lock lock = SESSION_LOCK.writeLock();
+ lock.lock();
+ try {
+ if (SESSIONS.containsKey(id))
+ return false;
+ SESSIONS.put(id, session);
+ return true;
+ } finally {
+ lock.unlock();
+ }
+ }
+
+ /**
+ * Create a new cow session for the given image. Returns an according session id.
+ * On error, an exception is thrown, this will never return null.
+ * @param sessionType
+ * @throws RuntimeException
+ */
+ public static String create(String cowid, LaunchData ld, String sessionType) throws RuntimeException {
+ UserInfo user = SessionManager.get(cowid);
+ if (user == null)
+ throw new RuntimeException("Unknown user");
+ //
+ String sessionId = UUID.randomUUID().toString();
+ CowSession session = new CowSession(ld.imagePath, ld.configuration, ld.imageBaseId, ld.vmName, ld.restricted, user, sessionType);
+ if (session.getError() != null) {
+ throw new RuntimeException(session.getError());
+ }
+ add(sessionId, session);
+ return sessionId;
+ }
+
+}
diff --git a/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/util/BashVars.java b/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/util/BashVars.java
new file mode 100644
index 00000000..e3f3996b
--- /dev/null
+++ b/dozentenmodulserver/src/main/java/org/openslx/bwlp/sat/util/BashVars.java
@@ -0,0 +1,46 @@
+package org.openslx.bwlp.sat.util;
+
+import java.util.HashMap;
+import java.util.Map;
+import java.util.Map.Entry;
+
+/**
+ * Class for generating a bash file declaring
+ * a list of variables, properly escaping.
+ */
+public class BashVars {
+
+ private final Map<String, String> vars = new HashMap<>();
+
+ public void addVar(String variable, String value) {
+ vars.put(variable, value);
+ }
+
+ @Override
+ public String toString() {
+ StringBuilder sb = new StringBuilder();
+ for (Entry<String, String> kvp : vars.entrySet()) {
+ sb.append(kvp.getKey());
+ sb.append('=');
+ sb.append(escape(kvp.getValue()));
+ sb.append('\n');
+ }
+ return sb.toString();
+ }
+
+ /**
+ * Escape a string and put it in quotes.
+ */
+ private String escape(String value) {
+ boolean hasAp = value.contains("'");
+ if (hasAp && !value.contains("!!") && !value.contains("$")) {
+ if (value.contains("\""))
+ return '"' + value.replace("\"", "\\\"") + '"';
+ return '"' + value + '"';
+ }
+ if (hasAp)
+ return "'" + value.replace("'", "'\\''") + "'";
+ return "'" + value + "'";
+ }
+
+}