Exemplo n.º 1
0
def GetAugmentedWorkflow(workflowId):
    worflowJson = WorkflowRepsitory.getWorkflow(workflowId)
    workflow = json.loads(worflowJson, object_hook=object_decoder)

    blocks = workflow["blocks"]
    for b in range(len(blocks)):
        blockType = blocks[b]["blockType"]
        block = BlockRepository.getBlockFromType(blockType)

        if block is None:
            LogWriter.logError("Could get block from Repository: " +
                               str(blockType))
            blocks[b]["Status"] = "not found"
            continue

        inputs = block.Inputs
        inputsList = []
        for i in range(len(inputs)):
            inputsList.append(inputs[i].Id)

        outputs = block.Outputs
        outputList = []
        for i in range(len(outputs)):
            outputList.append(outputs[i].Id)

        blocks[b]["Inputs"] = inputsList
        blocks[b]["Outputs"] = outputList

    return workflow
 def StoreWorkflowFile(ids, unmodiviedParams, workflowAndParameterDic):
     workflowAndParameterDic["parameters"] = unmodiviedParams
     tmpfile = WorkflowExecutor.WriteToFile(workflowAndParameterDic)
     LogWriter.logDebug("File :" + tmpfile.name)
     resultAnnotationId = WorkflowExecutor.AnnotateImagesWithFile(
         ids, tmpfile.name)
     os.remove(tmpfile.name)
     return resultAnnotationId
Exemplo n.º 3
0
 def getBlocks():
     with open(BlockRepository.getRepoPath()) as data_file:
         try:
             return json.load(data_file, object_hook=object_decoder)
         except Exception as e:
             LogWriter.logError(e.message)
             return []
     pass
 def AnnotateDataSetsWithFiles(datasetIds, fileList):
     fileIds = []
     for filename in fileList:
         try:
             fileIds.append(
                 WorkflowExecutor.AnnotateDataSetsWithFile(
                     datasetIds, filename))
         except Exception as e:
             LogWriter.logError("+ Error annotating " + e.message)
             LogWriter.logError(traceback.format_exc())
     return fileIds
    def WriteWorkflowFileToCluster(cls, workflowAndParameterDic,
                                   fullWorkingFolderOnCluster):
        LogWriter.logInfo("ParameterDir: " + str(workflowAndParameterDic))

        localTempfolder = WorkflowExecutor.CreateTempLocalFolder()
        parameterFile = localTempfolder + "/" + WorkflowExecutor.jsonParameterFileName
        LogWriter.logDebug("Temp Workflow file : " + parameterFile)
        with open(parameterFile, 'w') as outfile:
            json.dump(workflowAndParameterDic, outfile)

        WorkflowExecutor.serverInterface.CopyToServer(
            fullWorkingFolderOnCluster, parameterFile)
    def ToFileList(path):
        files = []
        if (os.path.isdir(path)):
            filesNames = os.listdir(path)
            for file in filesNames:
                files.append(path + file)

        elif (os.path.isfile(path)):
            files = [path]
        else:
            LogWriter.logError("Path is neither directory nor file: " + path)
        return files
 def PrefixFiles(fileList, prefix):
     renamedFiles = []
     for fullPath in fileList:
         try:
             directoryname, filename = os.path.split(fullPath)
             renamedFileFull = directoryname + "/" + prefix + filename
             os.rename(fullPath, renamedFileFull)
             renamedFiles.append(renamedFileFull)
         except Exception as e:
             LogWriter.logError("+ Error renaming " + e.message + " " +
                                fullPath + " => " + renamedFileFull)
             LogWriter.logError(traceback.format_exc())
     return renamedFiles
Exemplo n.º 8
0
    def getFileFromRevision(git_url, file_path, rev):
        if (platform.system() == 'Windows'):
            return GitHelper.getWindowsFallback(file_path)

        repo_dir = tempfile.mkdtemp()
        git_url = GitHelper.checkAndModifyGitUrl(git_url)
        repo = git.Repo.clone_from(git_url, repo_dir)
        repo.git.checkout(rev)

        #name = GitHelper.repoNameFromUrl(git_url)
        #pathToFile = repo.git.working_dir + "/" + name  + "/" + file_path
        pathToFile = repo.git.working_dir + "/" + file_path
        LogWriter.logDebug("Path to local file from git: " + pathToFile)
        return pathToFile
    def CreateTempFileNamesForUploadsAndModifyParameters(
            self, filesToUpLoad, extension):
        result = []
        if (len(filesToUpLoad) == 0):
            LogWriter.logInfo("no files to upload")
            return result

        for i in range(len(filesToUpLoad)):
            tempFileName = str(uuid.uuid4()) + extension
            result.append([tempFileName, filesToUpLoad[i][2]])
            filesToUpLoad[i][1] = "Value"
            filesToUpLoad[i][2] = tempFileName
            filesToUpLoad[i][3] = "out"
        return result
 def GetAnnotationFileFromServer(self, fileId):
     data = None
     name = ""
     try:
         ann = self.connection.getObject("FileAnnotation", fileId)
         name=ann.getFileName()
         for chunk in ann.getFileInChunks():
             if data is None:
                 data = chunk
             else:
                 data += chunk
         LogWriter.logDebug("Downloaded " + str(name) + " " + str(len(data)) + " size")
     except:
         LogWriter.logError("Could not load file annotation" + str(traceback.format_exc()))
     return name, data
    def AnnotateImagesWithFile(self,ids, filePath):
        if not isinstance(ids, collections.Sequence):
            ids = [ids]

        fileAnn = self.connection.createFileAnnfromLocalFile(filePath, mimetype="text/plain", ns=self.namespace, desc=None)
        for i in range(len(ids)):
            try:
                image = self.connection.getObject("Image", ids[i])
                if image is None:
                    LogWriter.logError("DataSet " + ids[i] + " not found")
                    continue
                image.linkAnnotation(fileAnn)
            except :
                LogWriter.logError("Could not annotate id " + str(ids[i]) + str(traceback.format_exc()))
        return fileAnn.getId()
Exemplo n.º 12
0
    def getCompileShellScript():
        defaultScript = "compileJar.sh"
        if (platform.system() == 'Windows'):
            defaultScript = "compileJar.bat"

        LogWriter.logDebug("Absolut Path to Compile Script: " +
                           str(os.path.abspath(defaultScript)))
        if os.path.isfile(defaultScript) and os.path.exists(defaultScript):
            return os.path.abspath(defaultScript)

        LogWriter.logError("could not find compile script. Create it: " +
                           defaultScript)
        file = open(defaultScript, 'w+')
        file.close()
        return None
Exemplo n.º 13
0
    def GetAndStoreStatistics(fullWorkingFolderOnCluster, intermediateDataSet,
                              runId):
        tempStatisticsPath = tempfile.mkdtemp()
        LogWriter.logInfo("+ Copy Statistics to " + str(tempStatisticsPath))
        WorkflowExecutor.DownloadFilesFromClusterToHere(
            fullWorkingFolderOnCluster + "statistics/statistics.txt",
            tempStatisticsPath, True)
        tempIntermediatePath = tempStatisticsPath + "/statistics.txt"
        RunRepository.updateStatusRun(runId, "Upload Statistics")

        files = WorkflowExecutor.ToFileList(tempIntermediatePath)
        renamedFiles = WorkflowExecutor.PrefixFiles(
            files, "statistics_" + str(runId) + "_")
        WorkflowExecutor.AnnotateDataSetsWithFiles([intermediateDataSet],
                                                   renamedFiles)
        WorkflowExecutor.RemoveFilesOrFolder(tempIntermediatePath)
Exemplo n.º 14
0
    def AnnotateImagesWithResultFiles(annotationDatasetIds,
                                      fullWorkingFolderOnCluster):
        for annotate in annotationDatasetIds:
            annotationFileName = annotate[0]
            WorkflowExecutor.DownloadFilesFromClusterToHere(
                fullWorkingFolderOnCluster + annotationFileName,
                annotationFileName)

            if not os.path.exists(annotationFileName):
                LogWriter.logError(
                    "Result file was not found => could not be annotated (" +
                    annotationFileName + ")")
            else:
                WorkflowExecutor.AnnotateImagesWithFile([annotate[1]],
                                                        annotationFileName)
                os.remove(annotationFileName)
    def UploadFiles(self, fileNamesWithDatasetIds, fullWorkingFolderOnCluster):
        ids = []
        for i in range(len(fileNamesWithDatasetIds)):
            command = CommandFactory.GetUploadCommand(fileNamesWithDatasetIds[i][0], fileNamesWithDatasetIds[i][1],
                                                      fullWorkingFolderOnCluster, self.hostName, self.sessionId)

            # can't use return code, since linux return code is mod 256
            # => cli will output  "Return with code: 720 " in its last line
            output = self.ExecuteCommandOnServerOutput(command)
            lines = output.splitlines()
            lastline = lines[len(lines)-1]
            LogWriter.logDebug("Last Line of Upload "+ str(lastline))
            splitted = lastline.split(":")
            idString = (splitted[len(splitted)-1])
            ids.append(int(idString))
        return ids;
Exemplo n.º 16
0
 def getServerInterface(omeroHost,
                        clusterUserAndAddress,
                        sessionId,
                        homepath,
                        mpipath,
                        additionalRunparameter=None):
     if InterfaceFactory.interfaceToUse == None:
         if InterfaceFactory.useOmero:
             LogWriter.logInfo("Create OmeroInterface ")
             InterfaceFactory.interfaceToUse = SshDeploymentInterface(
                 omeroHost, clusterUserAndAddress, sessionId, homepath,
                 mpipath, additionalRunparameter)
         else:
             LogWriter.logInfo("Create Dummy OmeroInterface ")
             InterfaceFactory.interfaceToUse = DummyDeploymentInterface(
                 omeroHost, clusterUserAndAddress, sessionId, homepath,
                 mpipath, additionalRunparameter)
     return InterfaceFactory.interfaceToUse
Exemplo n.º 17
0
    def getCommitsInternal(concatPath):
        tmp = concatPath.split(GitHelper.seperatro,2)
        git_url = tmp[0]
        file_path = tmp[1]
        LogWriter.logInfo("System:  " + str(platform.system()))
        if (platform.system() == 'Windows'):
            # under my windows debug environment git does not work, since it does not use ssh
            #  return debug fill stuff
            return [[1,"just a test"],[2, "bar"],[3, "foo"]]

        try :
            repo_dir = tempfile.mkdtemp()
            git_url = GitHelper.checkAndModifyGitUrl(git_url)
            repo = git.Repo.clone_from(git_url, repo_dir)

            g = git.Git(repo_dir)
            commits = g.log("--follow", '--pretty=format:"%H - %an, %ar : %s', file_path).split("\n")
            result = []
            for c in commits:
                rev = c.split("-")[0].strip().replace("\"", "")
                other = c.split("-")[1].strip().replace("\"", "")
                result.append([rev, other])

            return result
        except Exception as e:
            LogWriter.logError("getCommits failed: " + e.message)
            LogWriter.logError(traceback.format_exc())
            return []
Exemplo n.º 18
0
def ExecuteRun(request, workflowId, conn=None, **kwargs):
    LogWriter.logInfo(
        "####################################################################")
    LogWriter.logInfo("Run Workflow " + workflowId)

    blockPortSeperator = WorkFlowAnalyser.getBlockPortSeperator()

    parameters = []
    versions = []
    recordIntermediates = False
    #for key, value in request.GET.iteritems():
    for key, value in request.GET.items():
        if key == "intermediates":
            recordIntermediates = value == "record"
            continue

        blockPort = key.split(blockPortSeperator, 2)

        if (blockPort[1] == "Version"):
            versions.append([blockPort[0], value])
            continue
        parameters.append([blockPort[0], blockPort[1], value, "in"])

    workflow = GetAugmentedWorkflow(workflowId)
    workflow["parameters"] = parameters
    workflow["intermediates"] = recordIntermediates
    workflow["versions"] = versions

    #create own session because the given one will be disconnected
    myConn = JoinSession(conn)
    WorkflowExecutor.SetConnectionObject(myConn)

    try:
        execution_thread = threading.Thread(
            target=WorkflowExecutor.StartExcutionOnCluster, args=[workflow])
        execution_thread.start()
        work.append(execution_thread)
        return HttpResponse("started")
    except Exception as inst:
        return HttpResponse("start failed " + str(inst.message))
Exemplo n.º 19
0
    def checkForToolDependencies(jarPath):
        cliTool = "GetSourceControlInfo.jar"
        if not os.path.isfile(cliTool):
            return None

        LogWriter.logDebug("Absolut Path to tool tool: " +
                           str(os.path.abspath(cliTool)))

        import subprocess
        consoleOut = check_output(['java', '-jar', cliTool, jarPath])
        lines = consoleOut.strip().split("\n")

        LogWriter.logDebug("Tool Console out: " + str(consoleOut))

        result = []
        for line in lines:
            parts = line.strip().split("::", 5)
            if (len(parts) < 4):
                continue

            result.append(parts)
        return result
 def CopyToServer(self, fullDeploymentFolderName, localFile):
     LogWriter.logDebug("scp " + localFile + " " + self.clusterUserAndAddress + ":" + fullDeploymentFolderName)
     try:
         consoleOut = check_output(["scp", localFile, self.clusterUserAndAddress + ":" + fullDeploymentFolderName])
         LogWriter.logDebug("Console out: \n " + str(consoleOut))
         return 0
     except CalledProcessError, e:
         LogWriter.logDebug("Console out (" + str(e.returncode) + ") : \n" + str(e.output))
         return e.returncode
 def ExecuteCommandOnServerOutput2(self, command):
     LogWriter.logInfo("ssh " + self.clusterUserAndAddress + " " + command)
     try:
         consoleOut = check_output(["ssh", self.clusterUserAndAddress, command])
         LogWriter.logDebug("Console out :\n" + str(consoleOut))
         return consoleOut
     except CalledProcessError, e:
         LogWriter.logDebug("Console out (" + str(e.returncode) + "):\n" + str(e.output))
         return str(e.output)
    def CopyFromServer(self, pathOnCluster, localPath , recursive):
        if (recursive):
            LogWriter.logDebug(
            "scp -r " + self.clusterUserAndAddress + ":" + pathOnCluster + " " + localPath + " ")
        else:
            LogWriter.logDebug(
                "scp " + self.clusterUserAndAddress + ":" + pathOnCluster + " " + localPath + " ")

        try:
            if (recursive):
                consoleOut = check_output(["scp","-r", self.clusterUserAndAddress + ":" + pathOnCluster, localPath])
            else:
                consoleOut = check_output(["scp", self.clusterUserAndAddress + ":" + pathOnCluster, localPath])
            LogWriter.logDebug("Console out: \n " + str(consoleOut))
            return 0
        except CalledProcessError, e:
            LogWriter.logDebug("Console out (" + str(e.returncode) + ") : \n" + str(e.output))
Exemplo n.º 23
0
def GetGitVersions(request, gitUrl, gitPath):

    LogWriter.logInfo("GetGitVersions    " + str(gitUrl) + " " + str(gitPath))
    res = {}
    try:
        commits = GitHelper.getCommits(gitUrl, gitPath)
    except Exception as e:
        import traceback
        LogWriter.logError(e.message)
        LogWriter.logError(traceback.format_exc())
    res["commits"] = commits
    return HttpResponse(json.dumps(res), content_type="application/json")
    def AnnotateDataSetsWithFile(self,ids, filePath):
        if not isinstance(ids, collections.Sequence):
            ids = [ids]

        fileAnn = self.connection.createFileAnnfromLocalFile(filePath, mimetype="text/plain", ns=self.namespace, desc=None)
        for i in range(len(ids)):
            LogWriter.logDebug("Annotate Dataset " + str(ids[i]) + "with " + str(filePath))

            try:
                ds = self.connection.getObject("DataSet", ids[i])
                if ds is None:
                    LogWriter.logError("DataSet " + ids[i] + " not found")
                    continue

                ds.linkAnnotation(fileAnn)

                LogWriter.logDebug("Annotate Dataset " + str(ids[i]) + "with " + str(filePath) + " Succsessfull")
            except :
                LogWriter.logError("Could not annotate id " + str(ids[i]) + str(traceback.format_exc()))
        return fileAnn.getId()
Exemplo n.º 25
0
def JoinSession(conn):
    try:
        LogWriter.logDebug("Connect To:" + str(conn.host) + " " +
                           str(conn.port) + " " + str(conn._getSessionId()))
        connection = BlitzGateway('OMERO.script',
                                  host=conn.host,
                                  port=conn.port)
        connection.connect(sUuid=conn._getSessionId())
        return connection
    except Exception as inst:
        LogWriter.logError("Connecting own session failed " +
                           str(inst.message))
        LogWriter.logError(traceback.format_exc())
        return None
Exemplo n.º 26
0
    def DownloadFilesToTempFolderOnCluster(workingFolderOnCluster, fileIds):
        if (len(fileIds) == 0):
            LogWriter.logInfo("no other files to download")

        for i in range(len(fileIds)):
            # blockId | portName | value
            id = fileIds[i][2]
            WorkflowExecutor.DownloadFileToFolderOnCluster(
                workingFolderOnCluster, id)
            LogWriter.logDebug("Download finished " + str(id))
            LogWriter.logDebug("FileName finished " +
                               WorkflowExecutor.GetFileName(id))

            # change parameter for graph transformatoni
            fileIds[i][1] = "Value"
            fileIds[i][2] = (WorkflowExecutor.GetFileName(id))
            fileIds[i][3] = "out"
            fileIds[i].append(
                WorkflowExecutor.GetFileInformation(workingFolderOnCluster +
                                                    fileIds[i][2]))

            LogWriter.logDebug("Created Parameter " + str(fileIds[i]))
Exemplo n.º 27
0
    def DownloadImageFilesToTempFolderOnCluster(workingFolderOnCluster,
                                                imageIds):
        if (len(imageIds) == 0):
            LogWriter.logInfo("no images to download")

        for i in range(len(imageIds)):
            # blockId | portName | value
            id = imageIds[i][2]
            WorkflowExecutor.DownloadImgeToFolderOnCluster(
                workingFolderOnCluster, id)
            LogWriter.logDebug("Download finished " + str(id))
            LogWriter.logDebug("ImageName finished " +
                               WorkflowExecutor.GetImageName(id))

            # change parameter for graph transformatoni
            imageIds[i][1] = "Value"
            imageIds[i][2] = (WorkflowExecutor.GetImageName(id))
            imageIds[i][3] = "out"
            imageIds[i].append(
                WorkflowExecutor.GetFileInformation(workingFolderOnCluster +
                                                    imageIds[i][2]))
            imageIds[i].append("OMERO ID:" + str(id))
            LogWriter.logDebug("Created Parameter " + str(imageIds[i]))
Exemplo n.º 28
0
    def CheckOrDeployDeployment(fullDeploymentFolderName,
                                fullWorkingFolderOnCluster):
        LogWriter.logInfo("Check if deployment exists")
        deploymentFile = "aDeployment.tgz"
        deploymentFolderExists = not WorkflowExecutor.serverInterface.isDeploymentExists(
            fullDeploymentFolderName)
        if not deploymentFolderExists:
            LogWriter.logInfo("No Deployment found: copy new")
            WorkflowExecutor.serverInterface.DeployDeployment(
                fullDeploymentFolderName, deploymentFile)
        else:
            LogWriter.logInfo("Deployment found")

        WorkflowExecutor.serverInterface.LinkFolderOnServer(
            fullDeploymentFolderName + "*", fullWorkingFolderOnCluster)
        # remap icy plugin folder for plugin detection to work
        WorkflowExecutor.serverInterface.LinkFolderOnServer(
            fullDeploymentFolderName + "Libs/Icy/plugins",
            fullWorkingFolderOnCluster)
    def GetResultFromServer(self, fileId):
        data = ""
        try:
            ann = self.connection.getObject("FileAnnotation", fileId)

            if ann is None :
                LogWriter.logError("Could not get file annotation with id " + fileId)
                return None

            tf = tempfile.NamedTemporaryFile(prefix="workflow", suffix=".json", delete=False)
            f = open(str(tf.name), 'w')
            try:
                for chunk in ann.getFileInChunks():
                    f.write(chunk)
            finally:
                f.close()

            with open(tf.name, 'r') as myfile:
                data = myfile.read().replace('\n', '')
                LogWriter.logDebug(data)
        except:
            LogWriter.logError("Could not load file annotation" + str(traceback.format_exc()))
        return data
Exemplo n.º 30
0
    def StartExcutionOnCluster(workflowAndParameterDic):
        try:
            hadErrors = False

            runId = str(uuid.uuid4())
            intermediateDataSet = 751
            workflowAndParameterDic["runId"] = runId
            workflowAndParameterDic[
                "intermediateDataSet"] = intermediateDataSet
            unmodiviedParams = copy.deepcopy(
                workflowAndParameterDic["parameters"])

            name = ""
            if ("name" in workflowAndParameterDic):
                name = workflowAndParameterDic["name"]

            RunRepository.registerRun(runId, name)

            workingFolderName = runId  # create a temp folder on the cluster with this id
            workingFolderOnCluster = "omeroEnv/" + workingFolderName + "/"

            fullWorkingFolderOnCluster = WorkflowExecutor.serverInterface.GetHomePath(
            ) + workingFolderOnCluster
            fullDeploymentFolderName = WorkflowExecutor.serverInterface.GetHomePath(
            ) + "omeroEnv/deployment/"

            RunRepository.updateStatusRun(runId, "Deploy environment")
            WorkflowExecutor.CreateTempFolderOnServer(
                fullWorkingFolderOnCluster)
            WorkflowExecutor.CreateTempFolderOnServer(
                fullWorkingFolderOnCluster + "PluginDeploy/")
            WorkflowExecutor.CreateTempFolderOnServer(
                fullWorkingFolderOnCluster + "Tool/")
            LogWriter.logInfo("+ Check deployment and create deployment ")
            WorkflowExecutor.CheckOrDeployDeployment(
                fullDeploymentFolderName, fullWorkingFolderOnCluster)

            versions = workflowAndParameterDic["versions"]
            blocks = workflowAndParameterDic["blocks"]
            for i in range(0, len(versions)):
                correspondingBlock = None
                for j in range(0, len(blocks)):
                    if (blocks[j]["elementId"] == versions[i][0]):
                        correspondingBlock = blocks[j]
                        break

                if not correspondingBlock is None:
                    git = correspondingBlock["GitRepo"]
                    path = correspondingBlock["GitFilePath"]
                    try:
                        pathToJar = JavaHelper.compileOrGetFromCache(
                            git, path, versions[i][1], path)
                        if not pathToJar is None:
                            WorkflowExecutor.serverInterface.CopyToServer(
                                fullWorkingFolderOnCluster + "PluginDeploy/",
                                pathToJar)

                            toolStuff = JavaHelper.checkForToolDependencies(
                                pathToJar)
                            if not toolStuff is None and len(toolStuff) > 0:
                                LogWriter.logInfo("ToolStuff " +
                                                  str(toolStuff))
                                tool_file = JavaHelper.getToolFromVersionControl(
                                    toolStuff[0][0], toolStuff[0][1],
                                    toolStuff[0][2], toolStuff[0][3],
                                    toolStuff[0][4])
                                if not tool_file is None:
                                    WorkflowExecutor.serverInterface.CopyToServer(
                                        fullWorkingFolderOnCluster + "Tool/",
                                        tool_file)
                                else:
                                    LogWriter.logDebug(
                                        "No Tool file downloaded")

                        else:
                            LogWriter.logError("No compiled file created")
                    except Exception as e:
                        LogWriter.logError(e.message)
                        LogWriter.logError(traceback.format_exc())

            LogWriter.logInfo("+ Download Input files ")
            RunRepository.updateStatusRun(runId, "Download Inputs")
            imageIds = WorkFlowAnalyser.GetRequiredImageIdsFromWorkflow(
                workflowAndParameterDic)
            WorkflowExecutor.DownloadImageFilesToTempFolderOnCluster(
                fullWorkingFolderOnCluster, imageIds)

            fileIds = WorkFlowAnalyser.GetRequiredFileIdsFromWorkflow(
                workflowAndParameterDic)
            WorkflowExecutor.DownloadFilesToTempFolderOnCluster(
                fullWorkingFolderOnCluster, fileIds)

            # find Result images => import into Data Set
            imagesToUpLoadToDataSet = WorkFlowAnalyser.GetImageUploadsFromWorkflow(
                workflowAndParameterDic)
            imageNamesWithDatasetIds = WorkflowExecutor.CreateTempFileNamesForUploadsAndModifyParameters(
                imagesToUpLoadToDataSet, ".tiff")

            # find result file => image annotation
            dataFilesToAnnotate = WorkFlowAnalyser.GetImagesToAnnotateFromWorkflow(
                workflowAndParameterDic)
            dataFileNamesWithImageIds = WorkflowExecutor.CreateTempFileNamesForUploadsAndModifyParameters(
                dataFilesToAnnotate, ".txt")

            LogWriter.logInfo("+ Write Workflow file ")
            WorkflowExecutor.WriteWorkflowFileToCluster(
                workflowAndParameterDic, fullWorkingFolderOnCluster)

            #####################################################################################################
            #####################################################################################################
            #####################################################################################################
            #####################################################################################################
            #####################################################################################################
            #####################################################################################################
            #return

            #####################################################################################################
            #####################################################################################################

            LogWriter.logInfo("+ Start execution ")
            RunRepository.updateStatusRun(runId, "Execute Workflow")
            errorcode = WorkflowExecutor.StartWorkflowExecution(
                fullWorkingFolderOnCluster)
            if (errorcode > 0):
                LogWriter.logInfo("+ Error starting execution: ErrorCode " +
                                  str(errorcode))
                RunRepository.updateStatusRun(
                    runId,
                    "Failed to execute Workflow Manager with error code : " +
                    str(errorcode))
                return

            LogWriter.logInfo("+ Upload Results")
            RunRepository.updateStatusRun(runId, "Upload results")
            try:
                ids = WorkflowExecutor.UploadFiles(imageNamesWithDatasetIds,
                                                   fullWorkingFolderOnCluster)
                LogWriter.logDebug("+ Uploaded Created files as:" + str(ids))
            except:
                LogWriter.logDebug("+ Upload results faild")
                ids = []
                hadErrors = True

            WorkflowExecutor.AnnotateImagesWithResultFiles(
                dataFileNamesWithImageIds, fullWorkingFolderOnCluster)

            # annotate uploaded files with workflow description
            WorkFlowAnalyser.MergeReproducibilityParameters(
                unmodiviedParams, imageIds)
            resultAnnotationId = WorkflowExecutor.StoreWorkflowFile(
                ids, unmodiviedParams, workflowAndParameterDic)

            # get Intermediates from cluster
            RunRepository.updateStatusRun(runId, "Collect Intermediates")
            WorkflowExecutor.GetAndStoreIntermediates(
                fullWorkingFolderOnCluster, intermediateDataSet, runId)

            # get Statistics from cluster
            RunRepository.updateStatusRun(runId, "Collect Statistics")
            WorkflowExecutor.GetAndStoreStatistics(fullWorkingFolderOnCluster,
                                                   intermediateDataSet, runId)

            # Cleanup
            #todo

            LogWriter.logInfo("+ Finished Execution ")
            RunRepository.FinishRun(runId, resultAnnotationId, hadErrors)

        except Exception as e:
            RunRepository.updateStatusRun(runId, "Failed with " + e.message)
            LogWriter.logError(e.message)
            LogWriter.logError(traceback.format_exc())