You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@asterixdb.apache.org by am...@apache.org on 2016/02/22 23:34:54 UTC

[06/34] incubator-asterixdb git commit: Enabled Feed Tests and Added External Library tests

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/ac683db0/asterix-external-data/src/test/java/org/apache/asterix/external/parser/test/ADMDataParserTest.java
----------------------------------------------------------------------
diff --git a/asterix-external-data/src/test/java/org/apache/asterix/external/parser/test/ADMDataParserTest.java b/asterix-external-data/src/test/java/org/apache/asterix/external/parser/test/ADMDataParserTest.java
new file mode 100644
index 0000000..4303442
--- /dev/null
+++ b/asterix-external-data/src/test/java/org/apache/asterix/external/parser/test/ADMDataParserTest.java
@@ -0,0 +1,116 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you 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 org.apache.asterix.external.parser.test;
+
+import java.io.ByteArrayOutputStream;
+import java.io.DataOutput;
+import java.io.DataOutputStream;
+import java.util.concurrent.atomic.AtomicInteger;
+
+import org.apache.asterix.external.parser.ADMDataParser;
+import org.apache.asterix.om.base.AMutableDate;
+import org.apache.asterix.om.base.AMutableDateTime;
+import org.apache.asterix.om.base.AMutableTime;
+import org.junit.Assert;
+import org.junit.Test;
+
+import junit.extensions.PA;
+
+public class ADMDataParserTest {
+
+    @Test
+    public void test() {
+        String[] dates = { "-9537-08-04", "9656-06-03", "-9537-04-04", "9656-06-04", "-9537-10-04", "9626-09-05" };
+        AMutableDate[] parsedDates = new AMutableDate[] { new AMutableDate(-4202630), new AMutableDate(2807408),
+                new AMutableDate(-4202752), new AMutableDate(2807409), new AMutableDate(-4202569),
+                new AMutableDate(2796544), };
+
+        String[] times = { "12:04:45.689Z", "12:41:59.002Z", "12:10:45.169Z", "15:37:48.736Z", "04:16:42.321Z",
+                "12:22:56.816Z" };
+        AMutableTime[] parsedTimes = new AMutableTime[] { new AMutableTime(43485689), new AMutableTime(45719002),
+                new AMutableTime(43845169), new AMutableTime(56268736), new AMutableTime(15402321),
+                new AMutableTime(44576816), };
+
+        String[] dateTimes = { "-2640-10-11T17:32:15.675Z", "4104-02-01T05:59:11.902Z", "0534-12-08T08:20:31.487Z",
+                "6778-02-16T22:40:21.653Z", "2129-12-12T13:18:35.758Z", "8647-07-01T13:10:19.691Z" };
+        AMutableDateTime[] parsedDateTimes = new AMutableDateTime[] { new AMutableDateTime(-145452954464325L),
+                new AMutableDateTime(67345192751902L), new AMutableDateTime(-45286270768513L),
+                new AMutableDateTime(151729886421653L), new AMutableDateTime(5047449515758L),
+                new AMutableDateTime(210721439419691L) };
+
+        Thread[] threads = new Thread[16];
+        AtomicInteger errorCount = new AtomicInteger(0);
+        for (int i = 0; i < threads.length; ++i) {
+            threads[i] = new Thread(new Runnable() {
+                ADMDataParser parser = new ADMDataParser();
+                ByteArrayOutputStream bos = new ByteArrayOutputStream();
+                DataOutput dos = new DataOutputStream(bos);
+
+                @Override
+                public void run() {
+                    try {
+                        int round = 0;
+                        while (round++ < 10000) {
+                            // Test parseDate.
+                            for (int index = 0; index < dates.length; ++index) {
+                                PA.invokeMethod(parser, "parseDate(java.lang.String, java.io.DataOutput)",
+                                        dates[index], dos);
+                                AMutableDate aDate = (AMutableDate) PA.getValue(parser, "aDate");
+                                Assert.assertTrue(aDate.equals(parsedDates[index]));
+                            }
+
+                            // Tests parseTime.
+                            for (int index = 0; index < times.length; ++index) {
+                                PA.invokeMethod(parser, "parseTime(java.lang.String, java.io.DataOutput)",
+                                        times[index], dos);
+                                AMutableTime aTime = (AMutableTime) PA.getValue(parser, "aTime");
+                                Assert.assertTrue(aTime.equals(parsedTimes[index]));
+                            }
+
+                            // Tests parseDateTime.
+                            for (int index = 0; index < dateTimes.length; ++index) {
+                                PA.invokeMethod(parser, "parseDateTime(java.lang.String, java.io.DataOutput)",
+                                        dateTimes[index], dos);
+                                AMutableDateTime aDateTime = (AMutableDateTime) PA.getValue(parser, "aDateTime");
+                                Assert.assertTrue(aDateTime.equals(parsedDateTimes[index]));
+                            }
+                        }
+                    } catch (Exception e) {
+                        errorCount.incrementAndGet();
+                        e.printStackTrace();
+                    }
+                }
+            });
+            // Kicks off test threads.
+            threads[i].start();
+        }
+
+        // Joins all the threads.
+        try {
+            for (int i = 0; i < threads.length; ++i) {
+                threads[i].join();
+            }
+        } catch (InterruptedException e) {
+            throw new IllegalStateException(e);
+        }
+        // Asserts no failure.
+        Assert.assertTrue(errorCount.get() == 0);
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/ac683db0/asterix-external-data/src/test/java/org/apache/asterix/runtime/operator/file/ADMDataParserTest.java
----------------------------------------------------------------------
diff --git a/asterix-external-data/src/test/java/org/apache/asterix/runtime/operator/file/ADMDataParserTest.java b/asterix-external-data/src/test/java/org/apache/asterix/runtime/operator/file/ADMDataParserTest.java
deleted file mode 100644
index c6939c9..0000000
--- a/asterix-external-data/src/test/java/org/apache/asterix/runtime/operator/file/ADMDataParserTest.java
+++ /dev/null
@@ -1,116 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you 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 org.apache.asterix.runtime.operator.file;
-
-import java.io.ByteArrayOutputStream;
-import java.io.DataOutput;
-import java.io.DataOutputStream;
-import java.util.concurrent.atomic.AtomicInteger;
-
-import org.apache.asterix.external.parser.ADMDataParser;
-import org.apache.asterix.om.base.AMutableDate;
-import org.apache.asterix.om.base.AMutableDateTime;
-import org.apache.asterix.om.base.AMutableTime;
-import org.junit.Assert;
-import org.junit.Test;
-
-import junit.extensions.PA;
-
-public class ADMDataParserTest {
-
-    @Test
-    public void test() {
-        String[] dates = { "-9537-08-04", "9656-06-03", "-9537-04-04", "9656-06-04", "-9537-10-04", "9626-09-05" };
-        AMutableDate[] parsedDates = new AMutableDate[] { new AMutableDate(-4202630), new AMutableDate(2807408),
-                new AMutableDate(-4202752), new AMutableDate(2807409), new AMutableDate(-4202569),
-                new AMutableDate(2796544), };
-
-        String[] times = { "12:04:45.689Z", "12:41:59.002Z", "12:10:45.169Z", "15:37:48.736Z", "04:16:42.321Z",
-                "12:22:56.816Z" };
-        AMutableTime[] parsedTimes = new AMutableTime[] { new AMutableTime(43485689), new AMutableTime(45719002),
-                new AMutableTime(43845169), new AMutableTime(56268736), new AMutableTime(15402321),
-                new AMutableTime(44576816), };
-
-        String[] dateTimes = { "-2640-10-11T17:32:15.675Z", "4104-02-01T05:59:11.902Z", "0534-12-08T08:20:31.487Z",
-                "6778-02-16T22:40:21.653Z", "2129-12-12T13:18:35.758Z", "8647-07-01T13:10:19.691Z" };
-        AMutableDateTime[] parsedDateTimes = new AMutableDateTime[] { new AMutableDateTime(-145452954464325L),
-                new AMutableDateTime(67345192751902L), new AMutableDateTime(-45286270768513L),
-                new AMutableDateTime(151729886421653L), new AMutableDateTime(5047449515758L),
-                new AMutableDateTime(210721439419691L) };
-
-        Thread[] threads = new Thread[16];
-        AtomicInteger errorCount = new AtomicInteger(0);
-        for (int i = 0; i < threads.length; ++i) {
-            threads[i] = new Thread(new Runnable() {
-                ADMDataParser parser = new ADMDataParser();
-                ByteArrayOutputStream bos = new ByteArrayOutputStream();
-                DataOutput dos = new DataOutputStream(bos);
-
-                @Override
-                public void run() {
-                    try {
-                        int round = 0;
-                        while (round++ < 10000) {
-                            // Test parseDate.
-                            for (int index = 0; index < dates.length; ++index) {
-                                PA.invokeMethod(parser, "parseDate(java.lang.String, java.io.DataOutput)",
-                                        dates[index], dos);
-                                AMutableDate aDate = (AMutableDate) PA.getValue(parser, "aDate");
-                                Assert.assertTrue(aDate.equals(parsedDates[index]));
-                            }
-
-                            // Tests parseTime.
-                            for (int index = 0; index < times.length; ++index) {
-                                PA.invokeMethod(parser, "parseTime(java.lang.String, java.io.DataOutput)",
-                                        times[index], dos);
-                                AMutableTime aTime = (AMutableTime) PA.getValue(parser, "aTime");
-                                Assert.assertTrue(aTime.equals(parsedTimes[index]));
-                            }
-
-                            // Tests parseDateTime.
-                            for (int index = 0; index < dateTimes.length; ++index) {
-                                PA.invokeMethod(parser, "parseDateTime(java.lang.String, java.io.DataOutput)",
-                                        dateTimes[index], dos);
-                                AMutableDateTime aDateTime = (AMutableDateTime) PA.getValue(parser, "aDateTime");
-                                Assert.assertTrue(aDateTime.equals(parsedDateTimes[index]));
-                            }
-                        }
-                    } catch (Exception e) {
-                        errorCount.incrementAndGet();
-                        e.printStackTrace();
-                    }
-                }
-            });
-            // Kicks off test threads.
-            threads[i].start();
-        }
-
-        // Joins all the threads.
-        try {
-            for (int i = 0; i < threads.length; ++i) {
-                threads[i].join();
-            }
-        } catch (InterruptedException e) {
-            throw new IllegalStateException(e);
-        }
-        // Asserts no failure.
-        Assert.assertTrue(errorCount.get() == 0);
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/ac683db0/asterix-external-data/src/test/resources/August16-20-long.txt
----------------------------------------------------------------------
diff --git a/asterix-external-data/src/test/resources/August16-20-long.txt b/asterix-external-data/src/test/resources/August16-20-long.txt
new file mode 100644
index 0000000..7a1abd7
--- /dev/null
+++ b/asterix-external-data/src/test/resources/August16-20-long.txt
@@ -0,0 +1,1106 @@
+MaxWallTimeMins_RAW = 1315
+CRAB_ASOTimeout = 86400
+MaxHosts = 1
+RequestMemory_RAW = 2000
+CRAB_TFileOutputFiles = {  }
+User = "uscms5616@cms"
+JobFinishedHookDone = 1439847319
+DAG_NodesReady = 0
+OnExitHold = ( ExitCode =!= undefined && ExitCode != 0 )
+CoreSize = -1
+CRAB_DashboardTaskType = "analysis"
+DAG_NodesDone = 25
+CRAB_Attempt = 0
+LastHoldReason = "Spooling input data files"
+WantRemoteSyscalls = false
+MyType = "Job"
+CumulativeSuspensionTime = 0
+MinHosts = 1
+ReleaseReason = "Data files spooled"
+PeriodicHold = false
+PeriodicRemove = ( JobStatus == 5 ) && ( time() - EnteredCurrentStatus > 30 * 86400 )
+Err = "_condor_stderr"
+CRAB_AdditionalOutputFiles = { "combine_output.tar" }
+ProcId = 0
+CRAB_UserGroup = "dcms"
+CRAB_ASOURL = "https://cmsweb.cern.ch/couchdb"
+EnteredCurrentStatus = 1439847319
+CRAB_SiteWhitelist = {  }
+NumJobStarts = 1
+AutoClusterAttrs = "CheckpointPlatform,DESIRED_Gatekeepers,DESIRED_Sites,MaxWallTimeMins,RequestMemory,REQUIRED_OS,JobUniverse,LastCheckpointPlatform,NumCkpts,x509userproxyfirstfqan,x509userproxysubject,MachineLastMatchTime,DynamicSlot,PartitionableSlot,Slot1_ExpectedMachineGracefulDrainingCompletion,Slot1_JobStarts,Slot1_SelfMonitorAge,Slot1_TotalTimeClaimedBusy,Slot1_TotalTimeUnclaimedIdle,CMS_ALLOW_OVERFLOW,CRAB_UserRole,DESIRED_Overflow_Region,WMAgent_AgentName,CMSGroups,_condor_RequestCpus,_condor_RequestDisk,_condor_RequestMemory,RequestCpus,RequestDisk,WithinResourceLimits,opportunistic_job,ConcurrencyLimits,NiceUser,Rank,Requirements,DiskUsage"
+JobUniverse = 7
+AutoClusterId = 10378
+In = "/dev/null"
+SUBMIT_TransferOutputRemaps = "_condor_stdout=/data/srv/tmp/_150816_222636:agilbert_crab_prefit_cms_asimov_A1_5DYpFxP9/request.out;_condor_stderr=/data/srv/tmp/_150816_222636:agilbert_crab_prefit_cms_asimov_A1_5DYpFxP9/request.err"
+CRAB_UserWebDir = "http://submit-5.t2.ucsd.edu/CSstoragePath/73/uscms5616/150816_222636:agilbert_crab_prefit_cms_asimov_A1_5D"
+Requirements = true || false && TARGET.OPSYS == "LINUX" && TARGET.ARCH == "X86_64" && TARGET.HasFileTransfer && TARGET.Disk >= RequestDisk && TARGET.Memory >= RequestMemory
+CRAB_SplitAlgo = "EventBased"
+CRAB_UserDN = "/C=DE/O=GermanGrid/OU=KIT/CN=Andrew Gilbert"
+ClusterId = 1217455
+WhenToTransferOutput = "ON_EXIT"
+CRAB_AsyncDest = "T2_CH_CERN"
+CompletionDate = 1439847319
+OtherJobRemoveRequirements = DAGManJobId =?= ClusterId
+CRAB_FailedNodeLimit = -1
+BufferSize = 524288
+CRAB_RestURInoAPI = "/crabserver/prod"
+Environment = strcat("PATH=/usr/bin:/bin CRAB3_VERSION=3.3.0-pre1 CONDOR_ID=",ClusterId,".",ProcId," CRAB_RUNTIME_TARBALL=local CRAB_TASKMANAGER_TARBALL=local")
+TargetType = "Machine"
+LeaveJobInQueue = JobStatus == 4 && ( CompletionDate =?= UNDDEFINED || CompletionDate == 0 || ( ( time() - CompletionDate ) < 864000 ) )
+CRAB_UserRole = undefined
+JobNotification = 0
+Owner = "uscms5616"
+CondorPlatform = "$CondorPlatform: X86_64-ScientificLinux_6.6 $"
+CRAB_UserHN = "agilbert"
+CommittedTime = 0
+X509UserProxy = "63f0c4d862d8b4e4ddcfd29ed85b6b5899660759"
+QDate = 1439764883
+ExitStatus = 0
+DAG_NodesFailed = 0
+RootDir = "/"
+JobCurrentStartDate = 1439764892
+CurrentHosts = 0
+GlobalJobId = "crab3-1@submit-5.t2.ucsd.edu#1217455.0#1439764883"
+CRAB_DBSURL = "https://cmsweb.cern.ch/dbs/prod/global/DBSReader"
+RemoteSysCpu = 0.0
+TotalSuspensions = 0
+WantCheckpoint = false
+CRAB_RestHost = "cmsweb.cern.ch"
+CRAB_RetryOnASOFailures = 1
+Args = "RunJobs.dag"
+TransferInput = "gWMS-CMSRunAnalysis.sh, CMSRunAnalysis.sh, cmscp.py, RunJobs.dag, Job.submit, dag_bootstrap.sh, AdjustSites.py, site.ad, site.ad.json, run_and_lumis.tar.gz, sandbox.tar.gz, CMSRunAnalysis.tar.gz, TaskManagerRun.tar.gz"
+CRAB_JobArch = "slc6_amd64_gcc491"
+PeriodicRelease = false
+CRAB_TaskWorker = "vocms052"
+NumCkpts_RAW = 0
+CondorVersion = "$CondorVersion: 8.3.1 Jun 19 2015 $"
+RemoteCondorSetup = ""
+Out = "_condor_stdout"
+ShouldTransferFiles = "YES"
+DAG_NodesPrerun = 0
+DiskUsage = 1
+JobRunCount = 1
+CumulativeSlotTime = 82427.0
+CommittedSlotTime = 0
+LocalUserCpu = 0.0
+CRAB_SiteBlacklist = { "T2_FR_CCIN2P3","T1_IT_CNAF","T1_ES_PIC","T1_UK_RAL","T2_FI_HIP","T2_US_Nebraska" }
+DAG_NodesQueued = 0
+CRAB_JobCount = 25
+JobStartDate = 1439764892
+DAG_Status = 0
+CRAB_AlgoArgs = "{\"splitOnRun\": false, \"events_per_job\": {\"halt_job_on_file_boundaries\": false, \"events_per_lumi\": 100, \"algorithm\": \"EventBased\", \"applyLumiCorrection\": true, \"runs\": [], \"lumis\": [], \"splitOnRun\": false, \"events_per_job\": 1}, \"halt_job_on_file_boundaries\": false}"
+CRAB_SaveLogsFlag = 0
+CRAB_JobType = "analysis"
+CRAB_TransferOutputs = 1
+ExitBySignal = false
+StreamErr = false
+RemoveKillSig = "SIGUSR1"
+CRAB_ISB = "https://cmsweb.cern.ch/crabcache"
+NumRestarts = 0
+NumSystemHolds = 0
+RequestDisk = DiskUsage
+OrigMaxHosts = 1
+JobPrio = 10
+NumCkpts = 0
+BufferBlockSize = 32768
+StageInStart = 1439764886
+ImageSize = 100
+MaxWallTimeMins = 1400
+DiskUsage_RAW = 1
+DAG_NodesUnready = 0
+CommittedSuspensionTime = 0
+CRAB_NumAutomJobRetries = 2
+CRAB_UserVO = "cms"
+CRAB_EDMOutputFiles = {  }
+Cmd = "dag_bootstrap_startup.sh"
+LocalSysCpu = 0.0
+Iwd = "/data/condor_local/spool/7455/0/cluster1217455.proc0.subproc0"
+LastHoldReasonCode = 16
+CRAB_PublishName = "prefit_cms_asimov_A1_5D-59ffde2b5d41be5f0c401d0a6a8a0194"
+CRAB_LumiMask = "{}"
+DAG_InRecovery = 0
+CRAB_MaxPost = 20
+TaskType = "ROOT"
+CRAB_PublishDBSURL = "https://cmsweb.cern.ch/dbs/prod/phys03/DBSWriter"
+LastSuspensionTime = 0
+CRAB_PublishGroupName = 0
+TransferOutputRemaps = undefined
+TransferOutput = "RunJobs.dag.dagman.out, RunJobs.dag.rescue.001"
+CRAB_Workflow = "150816_222636:agilbert_crab_prefit_cms_asimov_A1_5D"
+CRAB_JobSW = "CMSSW_7_4_0_pre9"
+DAG_NodesPostrun = 0
+ExitCode = 0
+JobStatus = 4
+RemoteWallClockTime = 82427.0
+ImageSize_RAW = 100
+OnExitRemove = ( ExitSignal =?= 11 || ( ExitCode =!= undefined && ExitCode >= 0 && ExitCode <= 2 ) )
+DAG_NodesTotal = 25
+CRAB_InputData = "/MinBias"
+SUBMIT_x509userproxy = "/data/certs/creds/63f0c4d862d8b4e4ddcfd29ed85b6b5899660759"
+StreamOut = false
+CRAB_ReqName = "150816_222636:agilbert_crab_prefit_cms_asimov_A1_5D"
+CurrentTime = time()
+HoldKillSig = "SIGUSR1"
+RequestMemory = 2000
+NiceUser = false
+RemoteUserCpu = 0.0
+CRAB_Publish = 0
+RequestCpus = 1
+SUBMIT_Iwd = "/data/srv/tmp/_150816_222636:agilbert_crab_prefit_cms_asimov_A1_5DYpFxP9"
+WantRemoteIO = true
+CRAB_BlacklistT1 = 0
+StageInFinish = 1439764891
+LastJobStatus = 2
+
+MaxWallTimeMins_RAW = 1315
+CRAB_ASOTimeout = 86400
+MaxHosts = 1
+RequestMemory_RAW = 2000
+CRAB_TFileOutputFiles = {  }
+User = "uscms5050@cms"
+JobFinishedHookDone = 1439773907
+DAG_NodesReady = 0
+OnExitHold = ( ExitCode =!= undefined && ExitCode != 0 )
+CoreSize = -1
+CRAB_DashboardTaskType = "analysis"
+DAG_NodesDone = 30
+CRAB_Attempt = 0
+LastHoldReason = "Spooling input data files"
+WantRemoteSyscalls = false
+MyType = "Job"
+CumulativeSuspensionTime = 0
+MinHosts = 1
+ReleaseReason = "Data files spooled"
+PeriodicHold = false
+PeriodicRemove = ( JobStatus == 5 ) && ( time() - EnteredCurrentStatus > 30 * 86400 )
+Err = "_condor_stderr"
+CRAB_AdditionalOutputFiles = {  }
+ProcId = 0
+CRAB_UserGroup = undefined
+CRAB_ASOURL = "https://cmsweb.cern.ch/couchdb"
+EnteredCurrentStatus = 1439773907
+CRAB_SiteWhitelist = { "T3_US_FNALLPC","T2_US_Purdue","T2_US_Nebraska" }
+NumJobStarts = 1
+AutoClusterAttrs = "CheckpointPlatform,DESIRED_Gatekeepers,DESIRED_Sites,MaxWallTimeMins,RequestMemory,REQUIRED_OS,JobUniverse,LastCheckpointPlatform,NumCkpts,x509userproxyfirstfqan,x509userproxysubject,MachineLastMatchTime,DynamicSlot,PartitionableSlot,Slot1_ExpectedMachineGracefulDrainingCompletion,Slot1_JobStarts,Slot1_SelfMonitorAge,Slot1_TotalTimeClaimedBusy,Slot1_TotalTimeUnclaimedIdle,CMS_ALLOW_OVERFLOW,CRAB_UserRole,DESIRED_Overflow_Region,WMAgent_AgentName,CMSGroups,_condor_RequestCpus,_condor_RequestDisk,_condor_RequestMemory,RequestCpus,RequestDisk,WithinResourceLimits,opportunistic_job,ConcurrencyLimits,NiceUser,Rank,Requirements,DiskUsage"
+JobUniverse = 7
+AutoClusterId = 10378
+In = "/dev/null"
+SUBMIT_TransferOutputRemaps = "_condor_stdout=/data/srv/tmp/_150815_044810:ferencek_crab_Stop2ToStop1H_Stop1M200_TuneCUETP8M1_13TeV-madgraph-pythia8_LHEF9C8tB/request.out;_condor_stderr=/data/srv/tmp/_150815_044810:ferencek_crab_Stop2ToStop1H_Stop1M200_TuneCUETP8M1_13TeV-madgraph-pythia8_LHEF9C8tB/request.err"
+CRAB_UserWebDir = "http://submit-5.t2.ucsd.edu/CSstoragePath/67/uscms5050/150815_044810:ferencek_crab_Stop2ToStop1H_Stop1M200_TuneCUETP8M1_13TeV-madgraph-pythia8_LHE"
+Requirements = true || false && TARGET.OPSYS == "LINUX" && TARGET.ARCH == "X86_64" && TARGET.HasFileTransfer && TARGET.Disk >= RequestDisk && TARGET.Memory >= RequestMemory
+CRAB_SplitAlgo = "EventBased"
+CRAB_UserDN = "/DC=ch/DC=cern/OU=Organic Units/OU=Users/CN=ferencek/CN=650164/CN=Dinko Ferencek"
+ClusterId = 1206367
+WhenToTransferOutput = "ON_EXIT"
+CRAB_AsyncDest = "T3_US_FNALLPC"
+CompletionDate = 1439773907
+OtherJobRemoveRequirements = DAGManJobId =?= ClusterId
+CRAB_FailedNodeLimit = -1
+BufferSize = 524288
+CRAB_RestURInoAPI = "/crabserver/prod"
+Environment = strcat("PATH=/usr/bin:/bin CRAB3_VERSION=3.3.0-pre1 CONDOR_ID=",ClusterId,".",ProcId," CRAB_RUNTIME_TARBALL=local CRAB_TASKMANAGER_TARBALL=local")
+TargetType = "Machine"
+LeaveJobInQueue = JobStatus == 4 && ( CompletionDate =?= UNDDEFINED || CompletionDate == 0 || ( ( time() - CompletionDate ) < 864000 ) )
+x509userproxyexpiration = 1440294044
+CRAB_UserRole = undefined
+JobNotification = 0
+Owner = "uscms5050"
+CondorPlatform = "$CondorPlatform: X86_64-ScientificLinux_6.6 $"
+CRAB_UserHN = "ferencek"
+CommittedTime = 0
+X509UserProxy = "3a7798796bc24a800001338917ec45991bcf0a96"
+QDate = 1439615565
+ExitStatus = 0
+DAG_NodesFailed = 0
+RootDir = "/"
+JobCurrentStartDate = 1439615574
+CurrentHosts = 0
+GlobalJobId = "crab3-1@submit-5.t2.ucsd.edu#1206367.0#1439615565"
+CRAB_DBSURL = "https://cmsweb.cern.ch/dbs/prod/global/DBSReader"
+RemoteSysCpu = 0.0
+TotalSuspensions = 0
+WantCheckpoint = false
+CRAB_RestHost = "cmsweb.cern.ch"
+CRAB_RetryOnASOFailures = 1
+Args = "RunJobs.dag"
+TransferInput = "gWMS-CMSRunAnalysis.sh, CMSRunAnalysis.sh, cmscp.py, RunJobs.dag, Job.submit, dag_bootstrap.sh, AdjustSites.py, site.ad, site.ad.json, run_and_lumis.tar.gz, sandbox.tar.gz, CMSRunAnalysis.tar.gz, TaskManagerRun.tar.gz"
+CRAB_JobArch = "slc6_amd64_gcc481"
+PeriodicRelease = false
+CRAB_TaskWorker = "vocms052"
+NumCkpts_RAW = 0
+CondorVersion = "$CondorVersion: 8.3.1 Jun 19 2015 $"
+RemoteCondorSetup = ""
+Out = "_condor_stdout"
+ShouldTransferFiles = "YES"
+DAG_NodesPrerun = 0
+DiskUsage = 1
+JobRunCount = 1
+CumulativeSlotTime = 158333.0
+CommittedSlotTime = 0
+LocalUserCpu = 0.0
+CRAB_SiteBlacklist = {  }
+DAG_NodesQueued = 0
+CRAB_JobCount = 30
+JobStartDate = 1439615574
+DAG_Status = 0
+CRAB_AlgoArgs = "{\"splitOnRun\": false, \"events_per_job\": {\"halt_job_on_file_boundaries\": false, \"events_per_lumi\": 100, \"algorithm\": \"EventBased\", \"applyLumiCorrection\": true, \"runs\": [], \"lumis\": [], \"lheInputFiles\": true, \"splitOnRun\": false, \"events_per_job\": 50000}, \"halt_job_on_file_boundaries\": false}"
+CRAB_SaveLogsFlag = 0
+CRAB_JobType = "analysis"
+CRAB_TransferOutputs = 1
+ExitBySignal = false
+StreamErr = false
+RemoveKillSig = "SIGUSR1"
+CRAB_ISB = "https://cmsweb.cern.ch/crabcache"
+NumRestarts = 0
+NumSystemHolds = 0
+RequestDisk = DiskUsage
+OrigMaxHosts = 1
+JobPrio = 10
+NumCkpts = 0
+BufferBlockSize = 32768
+StageInStart = 1439615569
+ImageSize = 100
+MaxWallTimeMins = 1400
+DiskUsage_RAW = 1
+DAG_NodesUnready = 0
+CommittedSuspensionTime = 0
+CRAB_NumAutomJobRetries = 2
+CRAB_UserVO = "cms"
+CRAB_EDMOutputFiles = { "Stop2ToStop1H_Stop1M200_TuneCUETP8M1_13TeV-madgraph-pythia8_LHE.root" }
+Cmd = "dag_bootstrap_startup.sh"
+LocalSysCpu = 0.0
+Iwd = "/data/condor_local/spool/6367/0/cluster1206367.proc0.subproc0"
+LastHoldReasonCode = 16
+CRAB_PublishName = "LHE-17521057f93ed9cadf21dd45b3505145"
+CRAB_LumiMask = "{}"
+DAG_InRecovery = 0
+CRAB_MaxPost = 20
+TaskType = "ROOT"
+CRAB_PublishDBSURL = "https://cmsweb.cern.ch/dbs/prod/phys03/DBSWriter"
+LastSuspensionTime = 0
+CRAB_PublishGroupName = 0
+TransferOutputRemaps = undefined
+TransferOutput = "RunJobs.dag.dagman.out, RunJobs.dag.rescue.001"
+CRAB_Workflow = "150815_044810:ferencek_crab_Stop2ToStop1H_Stop1M200_TuneCUETP8M1_13TeV-madgraph-pythia8_LHE"
+CRAB_JobSW = "CMSSW_7_1_18"
+DAG_NodesPostrun = 0
+ExitCode = 0
+JobStatus = 4
+RemoteWallClockTime = 158333.0
+ImageSize_RAW = 100
+OnExitRemove = ( ExitSignal =?= 11 || ( ExitCode =!= undefined && ExitCode >= 0 && ExitCode <= 2 ) )
+DAG_NodesTotal = 30
+CRAB_InputData = "/Stop2ToStop1H_Stop1M200_TuneCUETP8M1_13TeV-madgraph-pythia8"
+SUBMIT_x509userproxy = "/data/certs/creds/3a7798796bc24a800001338917ec45991bcf0a96"
+StreamOut = false
+CRAB_ReqName = "150815_044810:ferencek_crab_Stop2ToStop1H_Stop1M200_TuneCUETP8M1_13TeV-madgraph-pythia8_LHE"
+CurrentTime = time()
+HoldKillSig = "SIGUSR1"
+RequestMemory = 2000
+NiceUser = false
+RemoteUserCpu = 0.0
+CRAB_Publish = 1
+RequestCpus = 1
+SUBMIT_Iwd = "/data/srv/tmp/_150815_044810:ferencek_crab_Stop2ToStop1H_Stop1M200_TuneCUETP8M1_13TeV-madgraph-pythia8_LHEF9C8tB"
+WantRemoteIO = true
+CRAB_BlacklistT1 = 0
+StageInFinish = 1439615572
+LastJobStatus = 2
+
+MaxWallTimeMins_RAW = 2800
+StatsLifetimeStarter = 165949
+CRAB_SaveLogsFlag = 1
+JOB_GLIDEIN_ProcId = "$$(GLIDEIN_ProcId:Unknown)"
+StreamOut = false
+JOB_GLIDEIN_Entry_Name = "$$(GLIDEIN_Entry_Name:Unknown)"
+CRAB_ReqName = "150810_122536:kbutanov_crab_25ns_WJetsToLNu_HT600_800"
+use_x509userproxy = true
+JOB_CMSSite = "$$(GLIDEIN_CMSSite:Unknown)"
+CRAB_SiteBlacklist = {  }
+CRAB_UserRole = undefined
+MATCH_EXP_JOB_GLIDEIN_SiteWMS_Queue = "grid_cms"
+TaskType = "Job"
+NumRestarts = 0
+MATCH_GLIDEIN_Schedd = "schedd_glideins3@cmsgwms-factory.fnal.gov"
+SubmitEventNotes = "DAG Node: Job53"
+x509UserProxyVOName = "cms"
+RecentBlockWriteKbytes = 0
+DAGParentNodeNames = ""
+MATCH_GLIDEIN_Site = "CERN"
+RecentBlockReadKbytes = 0
+LocalUserCpu = 0.0
+RemoteUserCpu = 163084.0
+MATCH_GLIDEIN_Max_Walltime = 603000
+MATCH_EXP_JOB_GLIDEIN_ClusterId = "59069"
+JOB_GLIDEIN_SiteWMS_Queue = "$$(GLIDEIN_SiteWMS_Queue:Unknown)"
+CRAB_StageoutPolicy = "local,remote"
+CRAB_Workflow = "150810_122536:kbutanov_crab_25ns_WJetsToLNu_HT600_800"
+RecentBlockWrites = 0
+CurrentHosts = 0
+MATCH_GLIDEIN_ProcId = 1
+x509UserProxyExpiration = 1440397268
+Iwd = "/data/condor_local/spool/5690/0/cluster1035690.proc0.subproc0"
+MATCH_EXP_JOB_GLIDEIN_Entry_Name = "CMS_T2_CH_CERN_ce302"
+NumShadowStarts = 1
+JobPrio = 10
+DiskUsage = 75000
+CRAB_ASOTimeout = 86400
+StartdPrincipal = "execute-side@matchsession/128.142.45.103"
+JOB_GLIDEIN_ToDie = "$$(GLIDEIN_ToDie:Unknown)"
+JobRunCount = 1
+MachineAttrSlotWeight0 = 1
+JOB_Site = "$$(GLIDEIN_Site:Unknown)"
+WantCheckpoint = false
+BlockWriteKbytes = 0
+MATCH_EXP_JOB_GLIDEIN_SiteWMS_JobId = "689255460"
+RequestDisk = 100000
+TotalSuspensions = 0
+DAGNodeName = "Job53"
+LastPublicClaimId = "<128.142.45.103:55332>#1439963327#3#..."
+RequestDisk_RAW = 1
+PeriodicRemove = ( ( JobStatus =?= 5 ) && ( time() - EnteredCurrentStatus > 7 * 60 ) ) || ( ( JobStatus =?= 2 ) && ( ( MemoryUsage > RequestMemory ) || ( MaxWallTimeMins * 60 < time() - EnteredCurrentStatus ) || ( DiskUsage > 100000000 ) ) ) || ( ( JobStatus =?= 1 ) && ( time() > ( x509UserProxyExpiration + 86400 ) ) )
+JOBGLIDEIN_CMSSite = "$$([ifThenElse(GLIDEIN_CMSSite is undefined, \"Unknown\", GLIDEIN_CMSSite)])"
+MATCH_GLIDEIN_CMSSite = "T2_CH_CERN"
+RemoteSysCpu = 1963.0
+CRAB_Retry = 2
+MyType = "Job"
+CRAB_JobType = "analysis"
+PeriodicHold = false
+ResidentSetSize_RAW = 1238992
+JOB_GLIDEIN_Job_Max_Time = "$$(GLIDEIN_Job_Max_Time:Unknown)"
+EnvDelim = ";"
+MATCH_EXP_JOB_GLIDEIN_Memory = "2800"
+CRAB_RestHost = "cmsweb.cern.ch"
+Owner = "uscms5111"
+JOB_GLIDEIN_SiteWMS_JobId = "$$(GLIDEIN_SiteWMS_JobId:Unknown)"
+MATCH_GLIDEIN_Entry_Name = "CMS_T2_CH_CERN_ce302"
+LastJobLeaseRenewal = 1440131524
+MATCH_EXP_JOB_GLIDEIN_CMSSite = "T2_CH_CERN"
+CRAB_AdditionalOutputFiles = {  }
+OnExitHold = false
+CRAB_ASOURL = "https://cmsweb.cern.ch/couchdb"
+MATCH_EXP_JOB_GLIDECLIENT_Name = "CMSG-v1_0.main"
+CRAB_NumAutomJobRetries = 2
+AccountingGroup = "analysis.kbutanov"
+MATCH_GLIDEIN_SiteWMS_Slot = "Unknown"
+WantRemoteSyscalls = false
+ExitStatus = 0
+User = "uscms5111@cms"
+JobLeaseDuration = 1200
+MATCH_GLIDEIN_SEs = "srm-eoscms.cern.ch"
+JOB_Gatekeeper = ifthenelse(substr(Used_Gatekeeper,0,1) =!= "$",Used_Gatekeeper,ifthenelse(MATCH_GLIDEIN_Gatekeeper =!= undefined,MATCH_GLIDEIN_Gatekeeper,"Unknown"))
+MATCH_Memory = 2800
+DESIRED_OpSyses = "LINUX"
+CompletionDate = 1440131525
+WhenToTransferOutput = "ON_EXIT_OR_EVICT"
+RequestCpus = 1
+ExecutableSize = 7
+x509UserProxyFirstFQAN = "/cms/Role=NULL/Capability=NULL"
+CommittedSuspensionTime = 0
+PreJobPrio1 = 1
+MATCH_GLIDEIN_Factory = "gfactory_service"
+GlobalJobId = "crab3-1@submit-5.t2.ucsd.edu#1233705.0#1439964847"
+CRAB_ISB = "https://cmsweb.cern.ch/crabcache"
+StreamErr = false
+TerminationPending = true
+DAGManNodesLog = "/data/condor_local/spool/5690/0/cluster1035690.proc0.subproc0/RunJobs.dag.nodes.log"
+Rank = 0.0
+JOB_GLIDEIN_SiteWMS = "$$(GLIDEIN_SiteWMS:Unknown)"
+TransferInput = "CMSRunAnalysis.sh,cmscp.py,CMSRunAnalysis.tar.gz,sandbox.tar.gz,run_and_lumis.tar.gz"
+JobUniverse = 5
+MATCH_GLIDEIN_ClusterId = 59069
+PeriodicRelease = ( HoldReasonCode == 28 ) || ( HoldReasonCode == 30 ) || ( HoldReasonCode == 13 ) || ( HoldReasonCode == 6 )
+MATCH_EXP_JOB_GLIDEIN_Job_Max_Time = "34800"
+JobCurrentStartExecutingDate = 1439965573
+CRAB_oneEventMode = 0
+x509userproxy = "/data/condor_local/spool/5690/0/cluster1035690.proc0.subproc0/8123da6528ec4abd24562a99b4f2b0ec556bed0b"
+MATCH_EXP_JOB_GLIDEIN_ToRetire = "1440530096"
+MATCH_EXP_JOB_GLIDEIN_Factory = "gfactory_service"
+JOB_GLIDEIN_SEs = "$$(GLIDEIN_SEs:Unknown)"
+JobNotification = 0
+CRAB_DBSURL = "https://cmsweb.cern.ch/dbs/prod/global/DBSReader"
+ProcId = 0
+JOB_GLIDEIN_MaxMemMBs = "$$(GLIDEIN_MaxMemMBs:Unknown)"
+MATCH_GLIDECLIENT_Name = "CMSG-v1_0.main"
+Used_Gatekeeper = "$$(GLIDEIN_Gatekeeper:Unknown)"
+CondorVersion = "$CondorVersion: 8.3.5 Apr 16 2015 BuildID: 315103 $"
+BlockReadKbytes = 0
+BytesRecvd = 2128005.0
+Arguments = "-a sandbox.tar.gz --sourceURL=https://cmsweb.cern.ch/crabcache --jobNumber=53 --cmsswVersion=CMSSW_7_4_7 --scramArch=slc6_amd64_gcc491 --inputFile=[\"/store/mc/RunIISpring15DR74/WJetsToLNu_HT-600To800_TuneCUETP8M1_13TeV-madgraphMLM-pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v2/50000/6E2F932B-633B-E511-A7AE-F04DA23BCE4C.root\"] --runAndLumis=job_lumis_53.json --lheInputFiles=False --firstEvent=None --firstLumi=None --lastEvent=None --firstRun=None --seeding=AutomaticSeeding --scriptExe=None --eventsPerLumi=None --scriptArgs=[] -o {}"
+ShouldTransferFiles = "YES"
+Out = "job_out.53"
+JOB_GLIDEIN_Memory = "$$(Memory:Unknown)"
+NumJobMatches = 1
+CumulativeSlotTime = 165965.0
+OnExitRemove = true
+ResidentSetSize = 1250000
+SpoolOnEvict = false
+JOB_GLIDEIN_Max_Walltime = "$$(GLIDEIN_Max_Walltime:Unknown)"
+JobAdInformationAttrs = "MATCH_EXP_JOBGLIDEIN_CMSSite, JOBGLIDEIN_CMSSite, RemoteSysCpu, RemoteUserCpu"
+In = "/dev/null"
+LastJobStatus = 2
+CumulativeSuspensionTime = 0
+MemoryUsage = ( ( ResidentSetSize + 1023 ) / 1024 )
+MATCH_EXP_JOB_CMSSite = "T2_CH_CERN"
+CRAB_TaskWorker = "vocms052"
+OrigMaxHosts = 1
+TransferIn = false
+CRAB_Id = 53
+JOB_GLIDEIN_Name = "$$(GLIDEIN_Name:Unknown)"
+WantRemoteIO = true
+MATCH_EXP_JOB_GLIDEIN_MaxMemMBs = "2800"
+MATCH_GLIDEIN_ToRetire = 1440530096
+ImageSize = 4250000
+JobCurrentStartDate = 1439965560
+ExecutableSize_RAW = 6
+x509userproxysubject = "/DC=ch/DC=cern/OU=Organic Units/OU=Users/CN=kbutanov/CN=727362/CN=Khakimjan Butanov"
+NumJobStarts = 1
+DESIRED_Overflow_Region = regexps("T[12]_US_",DESIRED_Sites,"US")
+AutoClusterAttrs = "CheckpointPlatform,DESIRED_Gatekeepers,DESIRED_Sites,MaxWallTimeMins,RequestMemory,REQUIRED_OS,JobUniverse,LastCheckpointPlatform,NumCkpts,x509userproxyfirstfqan,x509userproxysubject,MachineLastMatchTime,DynamicSlot,PartitionableSlot,Slot1_ExpectedMachineGracefulDrainingCompletion,Slot1_JobStarts,Slot1_SelfMonitorAge,Slot1_TotalTimeClaimedBusy,Slot1_TotalTimeUnclaimedIdle,CMS_ALLOW_OVERFLOW,CRAB_UserRole,DESIRED_Overflow_Region,WMAgent_AgentName,CMSGroups,_condor_RequestCpus,_condor_RequestDisk,_condor_RequestMemory,RequestCpus,RequestDisk,WithinResourceLimits,opportunistic_job,ConcurrencyLimits,NiceUser,Rank,Requirements"
+Cmd = "/data/condor_local/spool/5690/0/cluster1035690.proc0.subproc0/gWMS-CMSRunAnalysis.sh"
+BlockReads = 0
+JobStartDate = 1439965560
+LastMatchTime = 1439965560
+MATCH_EXP_JOB_GLIDEIN_ToDie = "1440564896"
+JOB_GLIDEIN_CMSSite = "$$(GLIDEIN_CMSSite:Unknown)"
+NumJobReconnects = 2
+CoreSize = -1
+MATCH_EXP_JOB_GLIDEIN_Schedd = "schedd_glideins3@cmsgwms-factory.fnal.gov"
+SpooledOutputFiles = "jobReport.json.53"
+TargetType = "Machine"
+TransferOutput = "jobReport.json.53"
+job_ad_information_attrs = MATCH_GLIDEIN_Gatekeeper
+CommittedSlotTime = 165965.0
+JobStatus = 4
+x509UserProxyEmail = "khakimjan.butanov@cern.ch"
+DAGManJobId = 1035690
+RemoteWallClockTime = 165965.0
+NumSystemHolds = 0
+CRAB_UserDN = "/DC=ch/DC=cern/OU=Organic Units/OU=Users/CN=kbutanov/CN=727362/CN=Khakimjan Butanov"
+LastRemoteHost = "glidein_9757_931570227@b635ef6906.cern.ch"
+MATCH_EXP_JOB_GLIDEIN_Name = "gfactory_instance"
+JOB_GLIDEIN_Site = "$$(GLIDEIN_Site:Unknown)"
+AcctGroup = "analysis"
+Requirements = ( ( ( target.IS_GLIDEIN =!= true ) || ( target.GLIDEIN_CMSSite =!= undefined ) ) && ( GLIDEIN_REQUIRED_OS =?= "rhel6" || OpSysMajorVer =?= 6 ) ) && ( ( Memory >= 1 ) && ( Disk >= 1 ) ) && ( TARGET.Arch == "X86_64" ) && ( TARGET.OpSys == "LINUX" ) && ( TARGET.Disk >= RequestDisk ) && ( TARGET.Memory >= RequestMemory ) && ( TARGET.HasFileTransfer )
+CRAB_EDMOutputFiles = {  }
+RecentBlockReads = 0
+DESIRED_SITES = "T1_DE_KIT,T2_UK_London_IC,T2_CH_CERN"
+NumCkpts = 0
+CMS_ALLOW_OVERFLOW = "True"
+RequestMemory_RAW = 2000
+DiskUsage_RAW = 61434
+DAGManNodesMask = "0,1,2,4,5,7,9,10,11,12,13,16,17,24,27"
+MATCH_EXP_JOB_GLIDEIN_ProcId = "1"
+CRAB_localOutputFiles = "stepB_MC.root=stepB_MC_53.root"
+MaxHosts = 1
+CRAB_UserHN = "kbutanov"
+MATCH_EXP_JOB_GLIDEIN_Max_Walltime = "603000"
+MATCH_EXP_JOB_GLIDEIN_SEs = "srm-eoscms.cern.ch"
+JOB_GLIDEIN_SiteWMS_Slot = "$$(GLIDEIN_SiteWMS_Slot:Unknown)"
+CRAB_InputData = "/WJetsToLNu_HT-600To800_TuneCUETP8M1_13TeV-madgraphMLM-pythia8/RunIISpring15DR74-Asympt25ns_MCRUN2_74_V9-v2/MINIAODSIM"
+CondorPlatform = "$CondorPlatform: X86_64-RedHat_6.6 $"
+BlockWrites = 0
+AcctGroupUser = "uscms5111"
+MATCH_GLIDEIN_Job_Max_Time = 34800
+ImageSize_RAW = 4095188
+MATCH_EXP_Used_Gatekeeper = "ce302.cern.ch:8443/cream-lsf-grid_cms"
+JOB_GLIDECLIENT_Name = "$$(GLIDECLIENT_Name:Unknown)"
+LocalSysCpu = 0.0
+LastSuspensionTime = 0
+MATCH_GLIDEIN_SiteWMS_Queue = "grid_cms"
+MATCH_GLIDEIN_Gatekeeper = "ce302.cern.ch:8443/cream-lsf-grid_cms"
+RecentStatsLifetimeStarter = 1200
+MATCH_EXP_JOB_GLIDEIN_Site = "CERN"
+UserLog = "/data/condor_local/spool/5690/0/cluster1035690.proc0.subproc0/job_log"
+CRAB_TransferOutputs = 1
+CRAB_DataBlock = "/WJetsToLNu_HT-600To800_TuneCUETP8M1_13TeV-madgraphMLM-pythia8/RunIISpring15DR74-Asympt25ns_MCRUN2_74_V9-v2/MINIAODSIM#85bfee36-3b82-11e5-be34-001e67abf518"
+Env = "CRAB_TASKMANAGER_TARBALL=local;SCRAM_ARCH=slc6_amd64_gcc491;CRAB_RUNTIME_TARBALL=local"
+CRAB_BlacklistT1 = 0
+JOB_GLIDEIN_Factory = "$$(GLIDEIN_Factory:Unknown)"
+TransferInputSizeMB = 2
+MachineAttrCpus0 = 1
+CRAB_RestURInoAPI = "/crabserver/prod"
+CRAB_JobArch = "slc6_amd64_gcc491"
+QDate = 1439964847
+CRAB_PublishGroupName = 0
+CRAB_PublishDBSURL = "https://cmsweb.cern.ch/dbs/prod/phys03/DBSWriter"
+x509UserProxyFQAN = "/DC=ch/DC=cern/OU=Organic Units/OU=Users/CN=kbutanov/CN=727362/CN=Khakimjan Butanov,/cms/Role=NULL/Capability=NULL"
+Err = "job_err.53"
+CRAB_SiteWhitelist = {  }
+CRAB_Destination = "srm://cluster142.knu.ac.kr:8443/srm/managerv2?SFN=/pnfs/knu.ac.kr/data/cms/store/user/kbutanov/HWWwidthRun2/LatinoTrees_V4/WJetsToLNu_HT-600To800_TuneCUETP8M1_13TeV-madgraphMLM-pythia8/crab_25ns_WJetsToLNu_HT600_800/150810_122536/0000/log/cmsRun_53.log.tar.gz, srm://cluster142.knu.ac.kr:8443/srm/managerv2?SFN=/pnfs/knu.ac.kr/data/cms/store/user/kbutanov/HWWwidthRun2/LatinoTrees_V4/WJetsToLNu_HT-600To800_TuneCUETP8M1_13TeV-madgraphMLM-pythia8/crab_25ns_WJetsToLNu_HT600_800/150810_122536/0000/stepB_MC_53.root"
+CRAB_RetryOnASOFailures = 1
+CRAB_TFileOutputFiles = { "stepB_MC.root" }
+AutoClusterId = 16275
+ExitCode = 0
+accounting_group = analysis
+PostJobPrio1 = -1439209593
+ExitBySignal = false
+CRAB_UserGroup = undefined
+PostJobPrio2 = 2
+PeriodicRemoveReason = ifThenElse(MemoryUsage > RequestMemory,"Removed due to memory use",ifThenElse(MaxWallTimeMins * 60 < time() - EnteredCurrentStatus,"Removed due to wall clock limit",ifThenElse(DiskUsage > 100000000,"Removed due to disk usage",ifThenElse(time() > x509UserProxyExpiration,"Removed job due to proxy expiration","Removed due to job being held"))))
+MATCH_EXP_JOB_Site = "CERN"
+BufferBlockSize = 32768
+CRAB_AsyncDest = "T2_KR_KNU"
+ClusterId = 1233705
+BytesSent = 119952.0
+CRAB_PublishName = "crab_25ns_WJetsToLNu_HT600_800-9da7f68dc2032d8626d7e7822bb10506"
+CRAB_Publish = 1
+CRAB_Dest = "/store/temp/user/kbutanov.03af76ad04ddc195ee96e6a5469f1bbb1777390d/HWWwidthRun2/LatinoTrees_V4/WJetsToLNu_HT-600To800_TuneCUETP8M1_13TeV-madgraphMLM-pythia8/crab_25ns_WJetsToLNu_HT600_800/150810_122536"
+MATCH_EXP_JOBGLIDEIN_CMSSite = "T2_CH_CERN"
+MATCH_GLIDEIN_MaxMemMBs = 2800
+RequestMemory = 2000
+EnteredCurrentStatus = 1440131525
+MATCH_GLIDEIN_SiteWMS = "LSF"
+CRAB_UserWebDir = "http://submit-5.t2.ucsd.edu/CSstoragePath/68/uscms5111/150810_122536:kbutanov_crab_25ns_WJetsToLNu_HT600_800"
+JOB_GLIDEIN_ToRetire = "$$(GLIDEIN_ToRetire:Unknown)"
+MATCH_GLIDEIN_SiteWMS_JobId = "689255460"
+CRAB_JobSW = "CMSSW_7_4_7"
+BufferSize = 524288
+JOB_GLIDEIN_Schedd = "$$(GLIDEIN_Schedd:Unknown)"
+MaxWallTimeMins = 2800
+LeaveJobInQueue = false
+MATCH_EXP_JOB_GLIDEIN_SiteWMS_Slot = "Unknown"
+EncryptExecuteDirectory = false
+NumCkpts_RAW = 0
+DESIRED_Archs = "X86_64"
+JobFinishedHookDone = 1440131525
+DESIRED_OpSysMajorVers = "6"
+MinHosts = 1
+MATCH_GLIDEIN_Name = "gfactory_instance"
+JOB_GLIDEIN_ClusterId = "$$(GLIDEIN_ClusterId:Unknown)"
+MATCH_GLIDEIN_ToDie = 1440564896
+NiceUser = false
+RootDir = "/"
+CommittedTime = 165965
+MATCH_EXP_JOB_GLIDEIN_SiteWMS = "LSF"
+
+MaxWallTimeMins_RAW = 1400
+StatsLifetimeStarter = 33352
+CRAB_SaveLogsFlag = 1
+JOB_GLIDEIN_ProcId = "$$(GLIDEIN_ProcId:Unknown)"
+StreamOut = false
+JOB_GLIDEIN_Entry_Name = "$$(GLIDEIN_Entry_Name:Unknown)"
+CRAB_ReqName = "150814_111316:mrodozov_crab_QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8"
+use_x509userproxy = true
+JOB_CMSSite = "$$(GLIDEIN_CMSSite:Unknown)"
+CRAB_SiteBlacklist = {  }
+CRAB_UserRole = undefined
+MATCH_EXP_JOB_GLIDEIN_SiteWMS_Queue = "red.unl.edu"
+TaskType = "Job"
+NumRestarts = 0
+MATCH_GLIDEIN_Schedd = "schedd_glideins6@glidein.grid.iu.edu"
+SubmitEventNotes = "DAG Node: Job4"
+x509UserProxyVOName = "cms"
+RecentBlockWriteKbytes = 0
+MATCH_GLIDEIN_Site = "Nebraska"
+RecentBlockReadKbytes = 0
+LocalUserCpu = 0.0
+RemoteUserCpu = 28513.0
+MATCH_GLIDEIN_Max_Walltime = 603000
+MATCH_EXP_JOB_GLIDEIN_ClusterId = "2561111"
+JOB_GLIDEIN_SiteWMS_Queue = "$$(GLIDEIN_SiteWMS_Queue:Unknown)"
+CRAB_StageoutPolicy = "local,remote"
+CRAB_Workflow = "150814_111316:mrodozov_crab_QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8"
+CurrentHosts = 0
+RecentBlockWrites = 0
+MATCH_GLIDEIN_ProcId = 8
+x509UserProxyExpiration = 1440171330
+Iwd = "/data/condor_local/spool/3604/0/cluster1183604.proc0.subproc0"
+MATCH_EXP_JOB_GLIDEIN_Entry_Name = "CMS_T2_US_Nebraska_Red_long"
+NumShadowStarts = 1
+JobPrio = 10
+DiskUsage = 3750000
+CRAB_ASOTimeout = 86400
+StartdPrincipal = "execute-side@matchsession/129.93.182.12"
+JOB_GLIDEIN_ToDie = "$$(GLIDEIN_ToDie:Unknown)"
+JobRunCount = 1
+MachineAttrSlotWeight0 = 1
+JOB_Site = "$$(GLIDEIN_Site:Unknown)"
+WantCheckpoint = false
+BlockWriteKbytes = 0
+MATCH_EXP_JOB_GLIDEIN_SiteWMS_JobId = "5092137.0"
+RequestDisk = 100000
+TotalSuspensions = 0
+DAGNodeName = "Job4"
+LastPublicClaimId = "<129.93.182.12:42491>#1440048812#7#..."
+RequestDisk_RAW = 1
+PeriodicRemove = ( ( JobStatus =?= 5 ) && ( time() - EnteredCurrentStatus > 7 * 60 ) ) || ( ( JobStatus =?= 2 ) && ( ( MemoryUsage > RequestMemory ) || ( MaxWallTimeMins * 60 < time() - EnteredCurrentStatus ) || ( DiskUsage > 100000000 ) ) ) || ( ( JobStatus =?= 1 ) && ( time() > ( x509UserProxyExpiration + 86400 ) ) )
+JOBGLIDEIN_CMSSite = "$$([ifThenElse(GLIDEIN_CMSSite is undefined, \"Unknown\", GLIDEIN_CMSSite)])"
+MATCH_GLIDEIN_CMSSite = "T2_US_Nebraska"
+RemoteSysCpu = 616.0
+CRAB_Retry = 3
+MyType = "Job"
+CRAB_JobType = "analysis"
+PeriodicHold = false
+ResidentSetSize_RAW = 1148372
+JOB_GLIDEIN_Job_Max_Time = "$$(GLIDEIN_Job_Max_Time:Unknown)"
+EnvDelim = ";"
+MATCH_EXP_JOB_GLIDEIN_Memory = "2500"
+CRAB_RestHost = "cmsweb.cern.ch"
+Owner = "uscms3850"
+JOB_GLIDEIN_SiteWMS_JobId = "$$(GLIDEIN_SiteWMS_JobId:Unknown)"
+MATCH_GLIDEIN_Entry_Name = "CMS_T2_US_Nebraska_Red_long"
+LastJobLeaseRenewal = 1440115142
+MATCH_EXP_JOB_GLIDEIN_CMSSite = "T2_US_Nebraska"
+CRAB_AdditionalOutputFiles = {  }
+OnExitHold = false
+CRAB_ASOURL = "https://cmsweb.cern.ch/couchdb"
+MATCH_EXP_JOB_GLIDECLIENT_Name = "CMSG-v1_0.overflow"
+CRAB_NumAutomJobRetries = 2
+AccountingGroup = "analysis.mrodozov"
+MATCH_GLIDEIN_SiteWMS_Slot = "slot1_6@red-d8n12.unl.edu"
+WantRemoteSyscalls = false
+ExitStatus = 0
+User = "uscms3850@cms"
+JobLeaseDuration = 1200
+MATCH_GLIDEIN_SEs = "srm.unl.edu"
+JOB_Gatekeeper = ifthenelse(substr(Used_Gatekeeper,0,1) =!= "$",Used_Gatekeeper,ifthenelse(MATCH_GLIDEIN_Gatekeeper =!= undefined,MATCH_GLIDEIN_Gatekeeper,"Unknown"))
+MATCH_Memory = 2500
+DESIRED_OpSyses = "LINUX"
+CompletionDate = 1440115142
+WhenToTransferOutput = "ON_EXIT_OR_EVICT"
+RequestCpus = 1
+ExecutableSize = 7
+x509UserProxyFirstFQAN = "/cms/Role=NULL/Capability=NULL"
+CommittedSuspensionTime = 0
+PreJobPrio1 = 0
+MATCH_GLIDEIN_Factory = "OSGGOC"
+GlobalJobId = "crab3-1@submit-5.t2.ucsd.edu#1235992.0#1440081300"
+CRAB_ISB = "https://cmsweb.cern.ch/crabcache"
+StreamErr = false
+TerminationPending = true
+DAGManNodesLog = "/data/condor_local/spool/3604/0/cluster1183604.proc0.subproc0/RunJobs.dag.nodes.log"
+Rank = 0.0
+JOB_GLIDEIN_SiteWMS = "$$(GLIDEIN_SiteWMS:Unknown)"
+TransferInput = "CMSRunAnalysis.sh,cmscp.py,CMSRunAnalysis.tar.gz,sandbox.tar.gz,run_and_lumis.tar.gz"
+JobUniverse = 5
+MATCH_GLIDEIN_ClusterId = 2561111
+PeriodicRelease = ( HoldReasonCode == 28 ) || ( HoldReasonCode == 30 ) || ( HoldReasonCode == 13 ) || ( HoldReasonCode == 6 )
+MATCH_EXP_JOB_GLIDEIN_Job_Max_Time = "34800"
+JobCurrentStartExecutingDate = 1440081789
+CRAB_oneEventMode = 0
+x509userproxy = "/data/condor_local/spool/3604/0/cluster1183604.proc0.subproc0/3adf46df379a2324bc159ae74f147ae01ca238c9"
+MATCH_EXP_JOB_GLIDEIN_ToRetire = "1440616411"
+MATCH_EXP_JOB_GLIDEIN_Factory = "OSGGOC"
+JOB_GLIDEIN_SEs = "$$(GLIDEIN_SEs:Unknown)"
+JobNotification = 0
+CRAB_DBSURL = "https://cmsweb.cern.ch/dbs/prod/global/DBSReader"
+ProcId = 0
+JOB_GLIDEIN_MaxMemMBs = "$$(GLIDEIN_MaxMemMBs:Unknown)"
+MATCH_GLIDECLIENT_Name = "CMSG-v1_0.overflow"
+Used_Gatekeeper = "$$(GLIDEIN_Gatekeeper:Unknown)"
+CondorVersion = "$CondorVersion: 8.3.5 Apr 16 2015 BuildID: 315103 $"
+BlockReadKbytes = 0
+BytesRecvd = 44879356.0
+Arguments = "-a sandbox.tar.gz --sourceURL=https://cmsweb.cern.ch/crabcache --jobNumber=4 --cmsswVersion=CMSSW_7_4_7_patch2 --scramArch=slc6_amd64_gcc491 --inputFile=[\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/9A89CA60-69FC-E411-9661-0025905C42B8.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/60000/34F8B66A-D4FB-E411-8F89-842B2B29273C.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/70000/7CE6B848-F5FB-E411-A605-0025905A60A8.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/9E842AA8-54FC-E411-8BC7-000F53273500.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/60000/C44AD465-D4FB-E411-8704-002590200A40.root\",' '\"/store/m
 c/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/90B6CB1B-07FD-E411-BD52-001E67397CBA.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/183FB65F-69FC-E411-A5A8-0025904B7C26.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/50000/5A0A9A0E-EDFB-E411-B95F-00266CF330B8.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/3E3768F1-61FC-E411-B163-002618943956.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/70000/08DB9DDE-F4FB-E411-9BC9-52540001DACD.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/CE293F9B-54FC-E411-83E8-AC853D9DACD3.root\",' '\"/store/mc/RunIISpring
 15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/A4479F5F-69FC-E411-B0B5-0025904C6378.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/60000/0419455F-D4FB-E411-AEFA-00261894394A.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/E6BD6C76-54FC-E411-A1F2-AC853D9DACD7.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/70000/AC15F863-F5FB-E411-8F07-002590DB9286.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/70000/CC9B7EE2-F4FB-E411-BCD9-52540001DACD.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/60000/5844575F-D4FB-E411-81F5-003048FFD732.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt
 _300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/60000/6EC5205E-D4FB-E411-9885-001E67396BB7.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/B63200E8-69FC-E411-B949-0025904C51FC.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/14554A42-54FC-E411-86D2-0025905A605E.root\"] --runAndLumis=job_lumis_4.json --lheInputFiles=False --firstEvent=None --firstLumi=None --lastEvent=None --firstRun=None --seeding=AutomaticSeeding --scriptExe=None --eventsPerLumi=None --scriptArgs=[] -o {}"
+ShouldTransferFiles = "YES"
+Out = "job_out.4"
+JOB_GLIDEIN_Memory = "$$(Memory:Unknown)"
+NumJobMatches = 1
+CumulativeSlotTime = 33360.0
+OnExitRemove = true
+ResidentSetSize = 1250000
+SpoolOnEvict = false
+JOB_GLIDEIN_Max_Walltime = "$$(GLIDEIN_Max_Walltime:Unknown)"
+JobAdInformationAttrs = "MATCH_EXP_JOBGLIDEIN_CMSSite, JOBGLIDEIN_CMSSite, RemoteSysCpu, RemoteUserCpu"
+In = "/dev/null"
+LastJobStatus = 2
+CumulativeSuspensionTime = 0
+MemoryUsage = ( ( ResidentSetSize + 1023 ) / 1024 )
+MATCH_EXP_JOB_CMSSite = "T2_US_Nebraska"
+CRAB_TaskWorker = "vocms052"
+OrigMaxHosts = 1
+TransferIn = false
+CRAB_Id = 4
+JOB_GLIDEIN_Name = "$$(GLIDEIN_Name:Unknown)"
+WantRemoteIO = true
+MATCH_EXP_JOB_GLIDEIN_MaxMemMBs = "2500"
+MATCH_GLIDEIN_ToRetire = 1440616411
+ImageSize = 1750000
+JobCurrentStartDate = 1440081782
+ExecutableSize_RAW = 6
+x509userproxysubject = "/DC=ch/DC=cern/OU=Organic Units/OU=Users/CN=mrodozov/CN=692532/CN=Mircho Nikolaev Rodozov"
+NumJobStarts = 1
+DESIRED_Overflow_Region = regexps("T[12]_US_",DESIRED_Sites,"US")
+AutoClusterAttrs = "CheckpointPlatform,DESIRED_Gatekeepers,DESIRED_Sites,MaxWallTimeMins,RequestMemory,REQUIRED_OS,JobUniverse,LastCheckpointPlatform,NumCkpts,x509userproxyfirstfqan,x509userproxysubject,MachineLastMatchTime,DynamicSlot,PartitionableSlot,Slot1_ExpectedMachineGracefulDrainingCompletion,Slot1_JobStarts,Slot1_SelfMonitorAge,Slot1_TotalTimeClaimedBusy,Slot1_TotalTimeUnclaimedIdle,CMS_ALLOW_OVERFLOW,CRAB_UserRole,DESIRED_Overflow_Region,WMAgent_AgentName,CMSGroups,_condor_RequestCpus,_condor_RequestDisk,_condor_RequestMemory,RequestCpus,RequestDisk,WithinResourceLimits,opportunistic_job,ConcurrencyLimits,NiceUser,Rank,Requirements"
+Cmd = "/data/condor_local/spool/3604/0/cluster1183604.proc0.subproc0/gWMS-CMSRunAnalysis.sh"
+BlockReads = 0
+JobStartDate = 1440081782
+LastMatchTime = 1440081782
+MATCH_EXP_JOB_GLIDEIN_ToDie = "1440651211"
+JOB_GLIDEIN_CMSSite = "$$(GLIDEIN_CMSSite:Unknown)"
+CoreSize = -1
+MATCH_EXP_JOB_GLIDEIN_Schedd = "schedd_glideins6@glidein.grid.iu.edu"
+SpooledOutputFiles = "jobReport.json.4"
+TargetType = "Machine"
+TransferOutput = "jobReport.json.4"
+job_ad_information_attrs = MATCH_GLIDEIN_Gatekeeper
+CommittedSlotTime = 33360.0
+JobStatus = 4
+x509UserProxyEmail = "mircho.nikolaev.rodozov@cern.ch"
+DAGManJobId = 1183604
+RemoteWallClockTime = 33360.0
+NumSystemHolds = 0
+CRAB_UserDN = "/DC=ch/DC=cern/OU=Organic Units/OU=Users/CN=mrodozov/CN=692532/CN=Mircho Nikolaev Rodozov"
+LastRemoteHost = "glidein_1936_57194584@red-d8n12.unl.edu"
+MATCH_EXP_JOB_GLIDEIN_Name = "gfactory_instance"
+JOB_GLIDEIN_Site = "$$(GLIDEIN_Site:Unknown)"
+AcctGroup = "analysis"
+Requirements = ( ( ( target.IS_GLIDEIN =!= true ) || ( target.GLIDEIN_CMSSite =!= undefined ) ) && ( GLIDEIN_REQUIRED_OS =?= "rhel6" || OpSysMajorVer =?= 6 ) ) && ( ( Memory >= 1 ) && ( Disk >= 1 ) ) && ( TARGET.Arch == "X86_64" ) && ( TARGET.OpSys == "LINUX" ) && ( TARGET.Disk >= RequestDisk ) && ( TARGET.Memory >= RequestMemory ) && ( TARGET.HasFileTransfer )
+CRAB_EDMOutputFiles = {  }
+RecentBlockReads = 0
+DESIRED_SITES = "T2_US_UCSD,T2_DE_DESY,T2_CH_CSCS,T2_US_MIT,T2_IT_Legnaro,T2_UK_London_Brunel,T2_CH_CERN,T2_UK_London_IC,T3_CH_PSI,T1_UK_RAL"
+NumCkpts = 0
+CMS_ALLOW_OVERFLOW = "True"
+RequestMemory_RAW = 2000
+DiskUsage_RAW = 3661158
+DAGManNodesMask = "0,1,2,4,5,7,9,10,11,12,13,16,17,24,27"
+MATCH_EXP_JOB_GLIDEIN_ProcId = "8"
+CRAB_localOutputFiles = "results.root=results_4.root"
+MaxHosts = 1
+CRAB_UserHN = "mrodozov"
+MATCH_EXP_JOB_GLIDEIN_Max_Walltime = "603000"
+MATCH_EXP_JOB_GLIDEIN_SEs = "srm.unl.edu"
+JOB_GLIDEIN_SiteWMS_Slot = "$$(GLIDEIN_SiteWMS_Slot:Unknown)"
+CRAB_InputData = "/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/RunIISpring15DR74-Asympt25ns_MCRUN2_74_V9-v1/MINIAODSIM"
+CondorPlatform = "$CondorPlatform: X86_64-RedHat_6.6 $"
+BlockWrites = 0
+AcctGroupUser = "uscms3850"
+MATCH_GLIDEIN_Job_Max_Time = 34800
+ImageSize_RAW = 1727056
+MATCH_EXP_Used_Gatekeeper = "red.unl.edu red.unl.edu:9619"
+JOB_GLIDECLIENT_Name = "$$(GLIDECLIENT_Name:Unknown)"
+LocalSysCpu = 0.0
+LastSuspensionTime = 0
+MATCH_GLIDEIN_SiteWMS_Queue = "red.unl.edu"
+MATCH_GLIDEIN_Gatekeeper = "red.unl.edu red.unl.edu:9619"
+RecentStatsLifetimeStarter = 1200
+MATCH_EXP_JOB_GLIDEIN_Site = "Nebraska"
+UserLog = "/data/condor_local/spool/3604/0/cluster1183604.proc0.subproc0/job_log"
+CRAB_TransferOutputs = 1
+CRAB_DataBlock = "/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/RunIISpring15DR74-Asympt25ns_MCRUN2_74_V9-v1/MINIAODSIM#242b435c-fc56-11e4-bda5-001e67abef8c"
+Env = "CRAB_TASKMANAGER_TARBALL=local;SCRAM_ARCH=slc6_amd64_gcc491;CRAB_RUNTIME_TARBALL=local"
+CRAB_BlacklistT1 = 0
+JOB_GLIDEIN_Factory = "$$(GLIDEIN_Factory:Unknown)"
+TransferInputSizeMB = 42
+MachineAttrCpus0 = 1
+CRAB_RestURInoAPI = "/crabserver/prod"
+CRAB_JobArch = "slc6_amd64_gcc491"
+QDate = 1440081300
+CRAB_PublishGroupName = 0
+CRAB_PublishDBSURL = "https://cmsweb.cern.ch/dbs/prod/phys03/DBSWriter"
+x509UserProxyFQAN = "/DC=ch/DC=cern/OU=Organic Units/OU=Users/CN=mrodozov/CN=692532/CN=Mircho Nikolaev Rodozov,/cms/Role=NULL/Capability=NULL"
+Err = "job_err.4"
+CRAB_SiteWhitelist = {  }
+CRAB_Destination = "srm://srm-eoscms.cern.ch:8443/srm/v2/server?SFN=/eos/cms/store/group/phys_b2g/BprimeKit_ntuple_747_1_MC/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/crab_QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/150814_111316/0000/log/cmsRun_4.log.tar.gz, srm://srm-eoscms.cern.ch:8443/srm/v2/server?SFN=/eos/cms/store/group/phys_b2g/BprimeKit_ntuple_747_1_MC/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/crab_QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/150814_111316/0000/results_4.root"
+CRAB_RetryOnASOFailures = 1
+CRAB_TFileOutputFiles = { "results.root" }
+AutoClusterId = 16278
+ExitCode = 0
+accounting_group = analysis
+PostJobPrio1 = -1439550850
+ExitBySignal = false
+CRAB_UserGroup = undefined
+PostJobPrio2 = 3
+PeriodicRemoveReason = ifThenElse(MemoryUsage > RequestMemory,"Removed due to memory use",ifThenElse(MaxWallTimeMins * 60 < time() - EnteredCurrentStatus,"Removed due to wall clock limit",ifThenElse(DiskUsage > 100000000,"Removed due to disk usage",ifThenElse(time() > x509UserProxyExpiration,"Removed job due to proxy expiration","Removed due to job being held"))))
+MATCH_EXP_JOB_Site = "Nebraska"
+BufferBlockSize = 32768
+CRAB_AsyncDest = "T2_CH_CERN"
+ClusterId = 1235992
+BytesSent = 597241.0
+CRAB_PublishName = "crab_QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8-025cf8039fdddfc0e0037d5a7ca660ac"
+CRAB_Publish = 1
+CRAB_Dest = "/store/temp/group/phys_b2g/BprimeKit_ntuple_747_1_MC/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/crab_QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/150814_111316"
+MATCH_EXP_JOBGLIDEIN_CMSSite = "T2_US_Nebraska"
+MATCH_GLIDEIN_MaxMemMBs = 2500
+RequestMemory = 2000
+EnteredCurrentStatus = 1440115142
+MATCH_GLIDEIN_SiteWMS = "HTCondor"
+CRAB_UserWebDir = "http://submit-5.t2.ucsd.edu/CSstoragePath/54/uscms3850/150814_111316:mrodozov_crab_QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8"
+JOB_GLIDEIN_ToRetire = "$$(GLIDEIN_ToRetire:Unknown)"
+MATCH_GLIDEIN_SiteWMS_JobId = "5092137.0"
+CRAB_JobSW = "CMSSW_7_4_7_patch2"
+BufferSize = 524288
+JOB_GLIDEIN_Schedd = "$$(GLIDEIN_Schedd:Unknown)"
+MaxWallTimeMins = 1400
+LeaveJobInQueue = false
+MATCH_EXP_JOB_GLIDEIN_SiteWMS_Slot = "slot1_6@red-d8n12.unl.edu"
+EncryptExecuteDirectory = false
+NumCkpts_RAW = 0
+DESIRED_Archs = "X86_64"
+JobFinishedHookDone = 1440115142
+DESIRED_OpSysMajorVers = "6"
+MinHosts = 1
+MATCH_GLIDEIN_Name = "gfactory_instance"
+JOB_GLIDEIN_ClusterId = "$$(GLIDEIN_ClusterId:Unknown)"
+MATCH_GLIDEIN_ToDie = 1440651211
+NiceUser = false
+RootDir = "/"
+CommittedTime = 33360
+MATCH_EXP_JOB_GLIDEIN_SiteWMS = "HTCondor"
+
+MaxWallTimeMins_RAW = 1400
+StatsLifetimeStarter = 31968
+CRAB_SaveLogsFlag = 1
+JOB_GLIDEIN_ProcId = "$$(GLIDEIN_ProcId:Unknown)"
+StreamOut = false
+JOB_GLIDEIN_Entry_Name = "$$(GLIDEIN_Entry_Name:Unknown)"
+CRAB_ReqName = "150814_111316:mrodozov_crab_QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8"
+use_x509userproxy = true
+JOB_CMSSite = "$$(GLIDEIN_CMSSite:Unknown)"
+CRAB_SiteBlacklist = {  }
+CRAB_UserRole = undefined
+MATCH_EXP_JOB_GLIDEIN_SiteWMS_Queue = "red-gw1.unl.edu"
+TaskType = "Job"
+NumRestarts = 0
+MATCH_GLIDEIN_Schedd = "schedd_glideins5@gfactory-1.t2.ucsd.edu"
+SubmitEventNotes = "DAG Node: Job3"
+x509UserProxyVOName = "cms"
+RecentBlockWriteKbytes = 0
+MATCH_GLIDEIN_Site = "Nebraska"
+RecentBlockReadKbytes = 0
+LocalUserCpu = 0.0
+RemoteUserCpu = 27257.0
+MATCH_GLIDEIN_Max_Walltime = 603000
+MATCH_EXP_JOB_GLIDEIN_ClusterId = "3043383"
+JOB_GLIDEIN_SiteWMS_Queue = "$$(GLIDEIN_SiteWMS_Queue:Unknown)"
+CRAB_StageoutPolicy = "local,remote"
+CRAB_Workflow = "150814_111316:mrodozov_crab_QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8"
+CurrentHosts = 0
+RecentBlockWrites = 0
+MATCH_GLIDEIN_ProcId = 14
+x509UserProxyExpiration = 1440171330
+Iwd = "/data/condor_local/spool/3604/0/cluster1183604.proc0.subproc0"
+MATCH_EXP_JOB_GLIDEIN_Entry_Name = "CMS_T2_US_Nebraska_Red_gw1_long"
+NumShadowStarts = 1
+JobPrio = 10
+DiskUsage = 4250000
+CRAB_ASOTimeout = 86400
+StartdPrincipal = "execute-side@matchsession/129.93.183.127"
+JOB_GLIDEIN_ToDie = "$$(GLIDEIN_ToDie:Unknown)"
+JobRunCount = 1
+MachineAttrSlotWeight0 = 1
+JOB_Site = "$$(GLIDEIN_Site:Unknown)"
+WantCheckpoint = false
+BlockWriteKbytes = 0
+MATCH_EXP_JOB_GLIDEIN_SiteWMS_JobId = "5096573.0"
+RequestDisk = 100000
+TotalSuspensions = 0
+DAGNodeName = "Job3"
+LastPublicClaimId = "<129.93.183.127:56441>#1440063351#7#..."
+RequestDisk_RAW = 1
+PeriodicRemove = ( ( JobStatus =?= 5 ) && ( time() - EnteredCurrentStatus > 7 * 60 ) ) || ( ( JobStatus =?= 2 ) && ( ( MemoryUsage > RequestMemory ) || ( MaxWallTimeMins * 60 < time() - EnteredCurrentStatus ) || ( DiskUsage > 100000000 ) ) ) || ( ( JobStatus =?= 1 ) && ( time() > ( x509UserProxyExpiration + 86400 ) ) )
+JOBGLIDEIN_CMSSite = "$$([ifThenElse(GLIDEIN_CMSSite is undefined, \"Unknown\", GLIDEIN_CMSSite)])"
+MATCH_GLIDEIN_CMSSite = "T2_US_Nebraska"
+RemoteSysCpu = 621.0
+CRAB_Retry = 3
+MyType = "Job"
+CRAB_JobType = "analysis"
+PeriodicHold = false
+ResidentSetSize_RAW = 1174388
+JOB_GLIDEIN_Job_Max_Time = "$$(GLIDEIN_Job_Max_Time:Unknown)"
+EnvDelim = ";"
+MATCH_EXP_JOB_GLIDEIN_Memory = "2500"
+CRAB_RestHost = "cmsweb.cern.ch"
+Owner = "uscms3850"
+JOB_GLIDEIN_SiteWMS_JobId = "$$(GLIDEIN_SiteWMS_JobId:Unknown)"
+MATCH_GLIDEIN_Entry_Name = "CMS_T2_US_Nebraska_Red_gw1_long"
+LastJobLeaseRenewal = 1440113502
+MATCH_EXP_JOB_GLIDEIN_CMSSite = "T2_US_Nebraska"
+CRAB_AdditionalOutputFiles = {  }
+OnExitHold = false
+CRAB_ASOURL = "https://cmsweb.cern.ch/couchdb"
+MATCH_EXP_JOB_GLIDECLIENT_Name = "CMSG-v1_0.overflow"
+CRAB_NumAutomJobRetries = 2
+AccountingGroup = "analysis.mrodozov"
+MATCH_GLIDEIN_SiteWMS_Slot = "slot1_32@red-d23n7.unl.edu"
+WantRemoteSyscalls = false
+ExitStatus = 0
+User = "uscms3850@cms"
+JobLeaseDuration = 1200
+MATCH_GLIDEIN_SEs = "srm.unl.edu"
+JOB_Gatekeeper = ifthenelse(substr(Used_Gatekeeper,0,1) =!= "$",Used_Gatekeeper,ifthenelse(MATCH_GLIDEIN_Gatekeeper =!= undefined,MATCH_GLIDEIN_Gatekeeper,"Unknown"))
+MATCH_Memory = 2500
+DESIRED_OpSyses = "LINUX"
+CompletionDate = 1440113503
+WhenToTransferOutput = "ON_EXIT_OR_EVICT"
+RequestCpus = 1
+ExecutableSize = 7
+x509UserProxyFirstFQAN = "/cms/Role=NULL/Capability=NULL"
+CommittedSuspensionTime = 0
+PreJobPrio1 = 0
+MATCH_GLIDEIN_Factory = "SDSC"
+GlobalJobId = "crab3-1@submit-5.t2.ucsd.edu#1235991.0#1440081300"
+CRAB_ISB = "https://cmsweb.cern.ch/crabcache"
+StreamErr = false
+TerminationPending = true
+DAGManNodesLog = "/data/condor_local/spool/3604/0/cluster1183604.proc0.subproc0/RunJobs.dag.nodes.log"
+Rank = 0.0
+JOB_GLIDEIN_SiteWMS = "$$(GLIDEIN_SiteWMS:Unknown)"
+TransferInput = "CMSRunAnalysis.sh,cmscp.py,CMSRunAnalysis.tar.gz,sandbox.tar.gz,run_and_lumis.tar.gz"
+JobUniverse = 5
+MATCH_GLIDEIN_ClusterId = 3043383
+PeriodicRelease = ( HoldReasonCode == 28 ) || ( HoldReasonCode == 30 ) || ( HoldReasonCode == 13 ) || ( HoldReasonCode == 6 )
+MATCH_EXP_JOB_GLIDEIN_Job_Max_Time = "34800"
+JobCurrentStartExecutingDate = 1440081533
+CRAB_oneEventMode = 0
+x509userproxy = "/data/condor_local/spool/3604/0/cluster1183604.proc0.subproc0/3adf46df379a2324bc159ae74f147ae01ca238c9"
+MATCH_EXP_JOB_GLIDEIN_ToRetire = "1440630710"
+MATCH_EXP_JOB_GLIDEIN_Factory = "SDSC"
+JOB_GLIDEIN_SEs = "$$(GLIDEIN_SEs:Unknown)"
+JobNotification = 0
+CRAB_DBSURL = "https://cmsweb.cern.ch/dbs/prod/global/DBSReader"
+ProcId = 0
+JOB_GLIDEIN_MaxMemMBs = "$$(GLIDEIN_MaxMemMBs:Unknown)"
+MATCH_GLIDECLIENT_Name = "CMSG-v1_0.overflow"
+Used_Gatekeeper = "$$(GLIDEIN_Gatekeeper:Unknown)"
+CondorVersion = "$CondorVersion: 8.3.5 Apr 16 2015 BuildID: 315103 $"
+BlockReadKbytes = 0
+BytesRecvd = 44879356.0
+Arguments = "-a sandbox.tar.gz --sourceURL=https://cmsweb.cern.ch/crabcache --jobNumber=3 --cmsswVersion=CMSSW_7_4_7_patch2 --scramArch=slc6_amd64_gcc491 --inputFile=[\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/60000/06DE7D5F-D4FB-E411-9C85-00261894394A.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/E29E093E-54FC-E411-8AE5-0025905A60FE.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/50000/F0FDF730-EDFB-E411-842B-00261834B51D.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/70000/FECCF363-F5FB-E411-85A3-002590DBDFE0.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/50000/0E4CEBFE-ECFB-E411-9F0C-842B2B29273C.root\",' '\"/store/m
 c/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/ECF66DCC-F0FB-E411-84CF-00259074AE32.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/60000/96F29C69-D4FB-E411-9028-842B2B292627.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/50000/6E887F0F-EDFB-E411-875B-BCAEC54B303A.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/70000/0C788712-F5FB-E411-AA0E-AC853D9DAC29.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/70000/723A41AE-F4FB-E411-BAA3-0025905C431A.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/70000/DA4EA0F5-F4FB-E411-B2AD-00259073E31C.root\",' '\"/store/mc/RunIISpring
 15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/70000/98C8F097-F7FB-E411-9A1F-52540006FB8D.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/DE4F8235-5FFC-E411-80CD-0025905A6088.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/70000/EA5D6151-F5FB-E411-99F0-0026B92E0C74.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/70000/205D0CF9-F4FB-E411-934D-000F532734AC.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/24BCAED9-F0FB-E411-A35B-00259074AE54.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/70000/A4C160C1-F4FB-E411-A66D-B083FED76C6C.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt
 _300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/80000/E86B536C-54FC-E411-8787-AC853D9DACE1.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/50000/2E68E42D-EDFB-E411-8027-001E67397CC9.root\",' '\"/store/mc/RunIISpring15DR74/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/MINIAODSIM/Asympt25ns_MCRUN2_74_V9-v1/50000/A056D12B-EDFB-E411-9E51-52540006FDD6.root\"] --runAndLumis=job_lumis_3.json --lheInputFiles=False --firstEvent=None --firstLumi=None --lastEvent=None --firstRun=None --seeding=AutomaticSeeding --scriptExe=None --eventsPerLumi=None --scriptArgs=[] -o {}"
+ShouldTransferFiles = "YES"
+Out = "job_out.3"
+JOB_GLIDEIN_Memory = "$$(Memory:Unknown)"
+NumJobMatches = 1
+CumulativeSlotTime = 31976.0
+OnExitRemove = true
+ResidentSetSize = 1250000
+SpoolOnEvict = false
+JOB_GLIDEIN_Max_Walltime = "$$(GLIDEIN_Max_Walltime:Unknown)"
+JobAdInformationAttrs = "MATCH_EXP_JOBGLIDEIN_CMSSite, JOBGLIDEIN_CMSSite, RemoteSysCpu, RemoteUserCpu"
+In = "/dev/null"
+LastJobStatus = 2
+CumulativeSuspensionTime = 0
+MemoryUsage = ( ( ResidentSetSize + 1023 ) / 1024 )
+MATCH_EXP_JOB_CMSSite = "T2_US_Nebraska"
+CRAB_TaskWorker = "vocms052"
+OrigMaxHosts = 1
+TransferIn = false
+CRAB_Id = 3
+JOB_GLIDEIN_Name = "$$(GLIDEIN_Name:Unknown)"
+WantRemoteIO = true
+MATCH_EXP_JOB_GLIDEIN_MaxMemMBs = "2500"
+MATCH_GLIDEIN_ToRetire = 1440630710
+ImageSize = 2000000
+JobCurrentStartDate = 1440081527
+ExecutableSize_RAW = 6
+x509userproxysubject = "/DC=ch/DC=cern/OU=Organic Units/OU=Users/CN=mrodozov/CN=692532/CN=Mircho Nikolaev Rodozov"
+NumJobStarts = 1
+DESIRED_Overflow_Region = regexps("T[12]_US_",DESIRED_Sites,"US")
+AutoClusterAttrs = "CheckpointPlatform,DESIRED_Gatekeepers,DESIRED_Sites,MaxWallTimeMins,RequestMemory,REQUIRED_OS,JobUniverse,LastCheckpointPlatform,NumCkpts,x509userproxyfirstfqan,x509userproxysubject,MachineLastMatchTime,DynamicSlot,PartitionableSlot,Slot1_ExpectedMachineGracefulDrainingCompletion,Slot1_JobStarts,Slot1_SelfMonitorAge,Slot1_TotalTimeClaimedBusy,Slot1_TotalTimeUnclaimedIdle,CMS_ALLOW_OVERFLOW,CRAB_UserRole,DESIRED_Overflow_Region,WMAgent_AgentName,CMSGroups,_condor_RequestCpus,_condor_RequestDisk,_condor_RequestMemory,RequestCpus,RequestDisk,WithinResourceLimits,opportunistic_job,ConcurrencyLimits,NiceUser,Rank,Requirements"
+Cmd = "/data/condor_local/spool/3604/0/cluster1183604.proc0.subproc0/gWMS-CMSRunAnalysis.sh"
+BlockReads = 0
+JobStartDate = 1440081527
+LastMatchTime = 1440081527
+MATCH_EXP_JOB_GLIDEIN_ToDie = "1440665510"
+JOB_GLIDEIN_CMSSite = "$$(GLIDEIN_CMSSite:Unknown)"
+CoreSize = -1
+MATCH_EXP_JOB_GLIDEIN_Schedd = "schedd_glideins5@gfactory-1.t2.ucsd.edu"
+SpooledOutputFiles = "jobReport.json.3"
+TargetType = "Machine"
+TransferOutput = "jobReport.json.3"
+job_ad_information_attrs = MATCH_GLIDEIN_Gatekeeper
+CommittedSlotTime = 31976.0
+JobStatus = 4
+x509UserProxyEmail = "mircho.nikolaev.rodozov@cern.ch"
+DAGManJobId = 1183604
+RemoteWallClockTime = 31976.0
+NumSystemHolds = 0
+CRAB_UserDN = "/DC=ch/DC=cern/OU=Organic Units/OU=Users/CN=mrodozov/CN=692532/CN=Mircho Nikolaev Rodozov"
+LastRemoteHost = "glidein_11321_920434792@red-d23n7.unl.edu"
+MATCH_EXP_JOB_GLIDEIN_Name = "gfactory_instance"
+JOB_GLIDEIN_Site = "$$(GLIDEIN_Site:Unknown)"
+AcctGroup = "analysis"
+Requirements = ( ( ( target.IS_GLIDEIN =!= true ) || ( target.GLIDEIN_CMSSite =!= undefined ) ) && ( GLIDEIN_REQUIRED_OS =?= "rhel6" || OpSysMajorVer =?= 6 ) ) && ( ( Memory >= 1 ) && ( Disk >= 1 ) ) && ( TARGET.Arch == "X86_64" ) && ( TARGET.OpSys == "LINUX" ) && ( TARGET.Disk >= RequestDisk ) && ( TARGET.Memory >= RequestMemory ) && ( TARGET.HasFileTransfer )
+CRAB_EDMOutputFiles = {  }
+RecentBlockReads = 0
+DESIRED_SITES = "T2_US_UCSD,T2_DE_DESY,T2_CH_CSCS,T2_US_MIT,T2_IT_Legnaro,T2_UK_London_Brunel,T2_CH_CERN,T2_UK_London_IC,T3_CH_PSI,T1_UK_RAL"
+NumCkpts = 0
+CMS_ALLOW_OVERFLOW = "True"
+RequestMemory_RAW = 2000
+DiskUsage_RAW = 4111436
+DAGManNodesMask = "0,1,2,4,5,7,9,10,11,12,13,16,17,24,27"
+MATCH_EXP_JOB_GLIDEIN_ProcId = "14"
+CRAB_localOutputFiles = "results.root=results_3.root"
+MaxHosts = 1
+CRAB_UserHN = "mrodozov"
+MATCH_EXP_JOB_GLIDEIN_Max_Walltime = "603000"
+MATCH_EXP_JOB_GLIDEIN_SEs = "srm.unl.edu"
+JOB_GLIDEIN_SiteWMS_Slot = "$$(GLIDEIN_SiteWMS_Slot:Unknown)"
+CRAB_InputData = "/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/RunIISpring15DR74-Asympt25ns_MCRUN2_74_V9-v1/MINIAODSIM"
+CondorPlatform = "$CondorPlatform: X86_64-RedHat_6.6 $"
+BlockWrites = 0
+AcctGroupUser = "uscms3850"
+MATCH_GLIDEIN_Job_Max_Time = 34800
+ImageSize_RAW = 1756756
+MATCH_EXP_Used_Gatekeeper = "red-gw1.unl.edu red-gw1.unl.edu:9619"
+JOB_GLIDECLIENT_Name = "$$(GLIDECLIENT_Name:Unknown)"
+LocalSysCpu = 0.0
+LastSuspensionTime = 0
+MATCH_GLIDEIN_SiteWMS_Queue = "red-gw1.unl.edu"
+MATCH_GLIDEIN_Gatekeeper = "red-gw1.unl.edu red-gw1.unl.edu:9619"
+RecentStatsLifetimeStarter = 1200
+MATCH_EXP_JOB_GLIDEIN_Site = "Nebraska"
+UserLog = "/data/condor_local/spool/3604/0/cluster1183604.proc0.subproc0/job_log"
+CRAB_TransferOutputs = 1
+CRAB_DataBlock = "/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/RunIISpring15DR74-Asympt25ns_MCRUN2_74_V9-v1/MINIAODSIM#242b435c-fc56-11e4-bda5-001e67abef8c"
+Env = "CRAB_TASKMANAGER_TARBALL=local;SCRAM_ARCH=slc6_amd64_gcc491;CRAB_RUNTIME_TARBALL=local"
+CRAB_BlacklistT1 = 0
+JOB_GLIDEIN_Factory = "$$(GLIDEIN_Factory:Unknown)"
+TransferInputSizeMB = 42
+MachineAttrCpus0 = 1
+CRAB_RestURInoAPI = "/crabserver/prod"
+CRAB_JobArch = "slc6_amd64_gcc491"
+QDate = 1440081300
+CRAB_PublishGroupName = 0
+CRAB_PublishDBSURL = "https://cmsweb.cern.ch/dbs/prod/phys03/DBSWriter"
+x509UserProxyFQAN = "/DC=ch/DC=cern/OU=Organic Units/OU=Users/CN=mrodozov/CN=692532/CN=Mircho Nikolaev Rodozov,/cms/Role=NULL/Capability=NULL"
+Err = "job_err.3"
+CRAB_SiteWhitelist = {  }
+CRAB_Destination = "srm://srm-eoscms.cern.ch:8443/srm/v2/server?SFN=/eos/cms/store/group/phys_b2g/BprimeKit_ntuple_747_1_MC/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/crab_QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/150814_111316/0000/log/cmsRun_3.log.tar.gz, srm://srm-eoscms.cern.ch:8443/srm/v2/server?SFN=/eos/cms/store/group/phys_b2g/BprimeKit_ntuple_747_1_MC/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/crab_QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/150814_111316/0000/results_3.root"
+CRAB_RetryOnASOFailures = 1
+CRAB_TFileOutputFiles = { "results.root" }
+AutoClusterId = 16278
+ExitCode = 0
+accounting_group = analysis
+PostJobPrio1 = -1439550850
+ExitBySignal = false
+CRAB_UserGroup = undefined
+PostJobPrio2 = 3
+PeriodicRemoveReason = ifThenElse(MemoryUsage > RequestMemory,"Removed due to memory use",ifThenElse(MaxWallTimeMins * 60 < time() - EnteredCurrentStatus,"Removed due to wall clock limit",ifThenElse(DiskUsage > 100000000,"Removed due to disk usage",ifThenElse(time() > x509UserProxyExpiration,"Removed job due to proxy expiration","Removed due to job being held"))))
+MATCH_EXP_JOB_Site = "Nebraska"
+BufferBlockSize = 32768
+CRAB_AsyncDest = "T2_CH_CERN"
+ClusterId = 1235991
+BytesSent = 604821.0
+CRAB_PublishName = "crab_QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8-025cf8039fdddfc0e0037d5a7ca660ac"
+CRAB_Publish = 1
+CRAB_Dest = "/store/temp/group/phys_b2g/BprimeKit_ntuple_747_1_MC/QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/crab_QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8/150814_111316"
+MATCH_EXP_JOBGLIDEIN_CMSSite = "T2_US_Nebraska"
+MATCH_GLIDEIN_MaxMemMBs = 2500
+RequestMemory = 2000
+EnteredCurrentStatus = 1440113503
+MATCH_GLIDEIN_SiteWMS = "HTCondor"
+CRAB_UserWebDir = "http://submit-5.t2.ucsd.edu/CSstoragePath/54/uscms3850/150814_111316:mrodozov_crab_QCD_Pt_300to470_TuneCUETP8M1_13TeV_pythia8"
+JOB_GLIDEIN_ToRetire = "$$(GLIDEIN_ToRetire:Unknown)"
+MATCH_GLIDEIN_SiteWMS_JobId = "5096573.0"
+CRAB_JobSW = "CMSSW_7_4_7_patch2"
+BufferSize = 524288
+JOB_GLIDEIN_Schedd = "$$(GLIDEIN_Schedd:Unknown)"
+MaxWallTimeMins = 1400
+LeaveJobInQueue = false
+MATCH_EXP_JOB_GLIDEIN_SiteWMS_Slot = "slot1_32@red-d23n7.unl.edu"
+EncryptExecuteDirectory = false
+NumCkpts_RAW = 0
+DESIRED_Archs = "X86_64"
+JobFinishedHookDone = 1440113503
+DESIRED_OpSysMajorVers = "6"
+MinHosts = 1
+MATCH_GLIDEIN_Name = "gfactory_instance"
+JOB_GLIDEIN_ClusterId = "$$(GLIDEIN_ClusterId:Unknown)"
+MATCH_GLIDEIN_ToDie = 1440665510
+NiceUser = false
+RootDir = "/"
+CommittedTime = 31976
+MATCH_EXP_JOB_GLIDEIN_SiteWMS = "HTCondor"
+

http://git-wip-us.apache.org/repos/asf/incubator-asterixdb/blob/ac683db0/asterix-external-data/src/test/resources/functional_tests.txt
----------------------------------------------------------------------
diff --git a/asterix-external-data/src/test/resources/functional_tests.txt b/asterix-external-data/src/test/resources/functional_tests.txt
new file mode 100644
index 0000000..42c0e95
--- /dev/null
+++ b/asterix-external-data/src/test/resources/functional_tests.txt
@@ -0,0 +1,362 @@
+/////////////////////////////////
+echo Testing basic math...
+eval x = (1 + 2)
+same $x, 3
+eval x = (3 - 1) 
+same $x, 2
+eval x = (2 * 3)
+same $x, 6
+eval x = (8 / 2)
+same $x, 4
+
+echo Testing extreme numbers...
+same string(real("INF")), "real(\"INF\")"
+same string(real("-INF")), "real(\"-INF\")"
+same string(real("NaN")), "real(\"NaN\")"
+diff real("NaN"), real("NaN")
+same real("INF"), real("INF")
+same real("-INF"), real("-INF")
+diff real("INF"), real("-INF")
+same 0.0, -(0.0)
+same 0.0, real("-0.0")
+same string(0.0), "0.0"
+same string(-0.0), "-0.0"
+
+/////////////////////////////////
+echo Testing basic attributes in a ClassAd...
+eval x = [
+            a = 1;
+            b = 2.0;
+            c = "alain";
+            d = true;
+            atime = absTime("2004-01-01");
+            rtime = relTime("2+25:14:16.123");
+            l = {1, 1, 2, 3, 5};
+            e = error;
+            u = undefined;
+         ]
+same $x.a, 1
+same $x.b, 2.0
+same $x.c, "alain"
+same $x.d, true
+same $x.atime, absTime("2004-01-01");
+same $x.rtime, relTime("2+25:14:16.123");
+same $x.l, {1, 1, 2, 3, 5}
+same $x.l[4], 5
+same $x.e, error
+same $x.u, undefined
+same isinteger($x.a), true
+same isinteger($x.b), false
+same isreal($x.b), true
+same isreal($x.c), false
+same isstring($x.c), true
+same isstring($x.d), false
+same isboolean($x.d), true
+same isboolean($x.c), false
+same isabstime($x.atime), true
+same isabstime($x.rtime), false
+same isreltime($x.rtime), true
+same isreltime($x.atime), false
+same islist($x.l), true
+same islist($x.a), false
+same iserror($x.e), true
+same iserror($x.u), false
+same isundefined($x.u), true
+same isundefined($x.e), false
+
+// Note that testing XML relies on the ClassAd from
+// the above testing.
+// echo Testing XML...
+// eval y = [ a = 2; b = "Lisp rocks"; ]
+// writexml tmp.xml {$x, $y}
+// readxml z tmp.xml
+// same $x, $z[0]
+// same $y, $z[1]
+
+/////////////////////////////////
+echo Testing select on lists...
+eval x = {
+           [a = 3; b = "I see London"],
+           [a = 2; b = "I see France"],
+           [a = 1; b = "I see Alain's funky pants"]
+         }
+same $x.a, {3, 2, 1}
+same $x.b, {"I see London", "I see France", "I see Alain's funky pants"}
+same $x.c, {undefined, undefined, undefined}
+same {}.a, {}
+
+/////////////////////////////////
+echo Testing subscripts
+eval x = [
+           a = 3;
+           b = "alain";
+           ab = 4;
+         ]
+same $x["a"], 3
+same $x["b"], "alain"
+same $x["c"], error
+eval d = $x["c"]
+same $x[strcat("a", "b")], 4
+eval x = {"a", "b", "c"}
+same $x[0], "a"
+same $x[1], "b"
+same $x[2], "c"
+same $x[3], error
+
+/////////////////////////////////
+echo Testing multiple semicolons...
+eval x = [
+           ;;
+           a = 3;;
+           b = 4;;
+         ]
+
+/////////////////////////////////
+echo Testing functions...
+same int(3), 3
+same int(3.9), 3
+same int("3.9"), 3
+same int(absTime("1970-01-01T:00:00:01Z")), 1
+same int(reltime("01:00:01")), 3601
+eval y = int(absTime("1970-01-01T:00:00:01Z"))
+same $y, 1
+
+same real(3), 3.0
+same real(3.9), 3.9
+same real("3.9"), 3.9
+same real(absTime("1970-01-01T:00:00:01Z")), 1.0
+same real(reltime("01:00:01")), 3601.0
+
+same string("alain"), "alain"
+same string(1), "1"
+
+same floor(3.9), 3
+same floor("3.9"), 3
+
+same ceiling(3.9), 4
+same ceiling("3.9"), 4
+
+same round(3.1), 3
+same round(3.9), 4
+
+same strcat("", "roy"), "roy"
+same strcat("alain", ""), "alain"
+same strcat("alain", "roy"), "alainroy"
+same strcat(14, " bottles of root beer"), "14 bottles of root beer"
+
+same substr("abcde", 1), "bcde"
+same substr("abcde", 4), "e"
+same substr("abcde", 5), ""
+same substr("abcde", 1, 2), "bc"
+same substr("abcde", 4, 2), "e"
+
+same strcmp("alain", "roy") < 0, true
+same strcmp("roy", "alain") > 0, true
+same strcmp("alain", "alain"), 0
+
+same stricmp("alain", "ALAIN"), 0
+same stricmp("alain", "roy") < 0, true
+
+same tolower("ALAIN"), "alain")
+same toupper("alain"), "ALAIN")
+same tolower(true), "true")
+same toupper(true), "TRUE")
+
+same member(1, {1, 2, 3}), true
+same member(4, {1, 2, 3}), false
+
+same regexp("Alain.*Roy", "Alain Aslag Roy"), true
+same regexp("alain.*roy", "Alain Aslag Roy"), false
+same regexp("alain.*roy", "Alain Aslag Roy", "i"), true
+
+//same regexpMember("b.*", {}), false
+//same regexpMember("b.*", {"aa"}), false
+//same regexpMember("b.*", {"aa", "bb"}), true
+//same regexpMember("b.*", {"bb", "aa"}), true
+//same regexpMember("b.*", {1, "bb"} ), error
+
+
+eval t = absTime("1970-01-02T:03:04:05Z")
+same splitTime($t).year, 1970
+same splitTime($t).month, 1
+same splitTime($t).day, 2
+same splitTime($t).hours, 3
+same splitTime($t).minutes, 4
+same splitTime($t).seconds, 5
+same splitTime($t).offset, 0
+
+
+
+eval t = absTime("1970-01-02T:03:04:05-06:00")
+eval tt = splitTime($t)
+same splitTime($t).year, 1970
+same splitTime($t).month, 1
+same splitTime($t).day, 2
+same splitTime($t).hours, 3
+same splitTime($t).minutes, 4
+same splitTime($t).seconds, 5
+same splitTime($t).offset, -21600
+
+
+
+eval t = relTime("1d2h3m4.5s")
+eval tt = splitTime($t)
+same splitTime($t).days, 1
+same splitTime($t).hours, 2
+same splitTime($t).minutes, 3
+same splittime($t).seconds, 4.5
+eval tt = splitTime($t)
+
+
+eval t = absTime("1997-08-30T16:04:05-0500")
+eval f = formatTime($t, "%m %d %Y")
+same $f, "08 30 1997"
+eval f = formatTime($t, "%H %M %S")
+same $f, "16 04 05"
+eval f = formatTime($t, "%A %a")
+same $f, "Saturday Sat"
+eval f = formatTime($t, "%B %b")
+same $f, "August Aug"
+eval f = formatTime(splitTime($t), "%H:%M:%S")
+same $f, "16:04:05"
+eval f = formatTime($t)
+same $f, "Sat Aug 30 16:04:05 1997"
+
+same size({}), 0
+same size({1}), 1
+same size({1, 2, 3, 4, 5}), 5
+same size([]), 0
+same size([a = 1;]), 1
+same size([a = 1; b = 2;]), 2
+same size(""), 0
+same size("a"), 1
+same size("ab"), 2
+same size(3), error
+same size(3.4), error
+
+eval list0 = {}
+eval list1 = {1}
+eval list5 = {1, 2, 3, 4, 5}
+
+same sum($list0), undefined
+same avg($list0), undefined
+same min($list0), undefined
+same max($list0), undefined
+// #### Do we really want these to be false and true?
+same anycompare("<", $list0, 3), false
+same allcompare("<", $list0, 3), true
+
+same sum($list1), 1
+same avg($list1), 1.0
+same min($list1), 1
+same max($list1), 1
+same anycompare("<", $list1, 3), true
+same allcompare("<", $list1, 3), true
+
+same sum($list5), 15
+same avg($list5), 3.0
+same min($list5), 1
+same max($list5), 5
+same anycompare("<", $list5, 3), true
+same allcompare("<", $list5, 3), false
+
+same ifThenElse(1+1==2, 3, 4), 3
+same ifThenElse(1+1==3,3,4), 4
+same ifThenElse(ERROR,3,4), ERROR
+same ifThenElse(UNDEFINED,3,4), UNDEFINED
+
+same interval(1), "1"
+same interval(60*2 + 1), "2:01"
+same interval(3600*3 + 60*2 + 1), "3:02:01"
+same interval(3600*24*4 + 3600*3 + 60*2 + 1), "4+03:02:01"
+
+//same regexps("[abc]*([def]*)[ghi]*","aaaabbbbcccccdddeeefffggghhhiii","\\1"), "dddeeefff"
+//same regexps("[abc]*([def]*)[ghi]*","abcdefghi","\\0"), "abcdefghi"
+//same regexps("[abc]*([def]*)[ghi]*","abcdefghi","\\2"), error
+//same regexps("[abc]*([def]*)[ghi]*","NO","\\0"), ""
+
+
+echo Testing eval
+same eval("1+1"), 2
+same eval(1+1), 2
+same eval("1+"), ERROR
+eval x = [ A = 1; B = 2; C = eval("A+B"); ]
+same $x.C, 3
+
+echo Testing boolean expressions
+echo Testing && operator
+same false, false && false
+same false, false && undefined
+same false, false && true
+same false, false && error
+
+same false, undefined && false
+same undefined, undefined && undefined
+same undefined, undefined && true
+same error, undefined && error
+
+same false, true && false
+same undefined, true && undefined
+same true, true && true
+same error, true && error
+
+same error, error && false
+same error, error && undefined
+same error, error && true
+same error, error && error
+
+
+echo Testing || operator
+same false, false || false
+same undefined, false || undefined
+same true, false || true
+same error, false || error
+
+same undefined, undefined || false
+same undefined, undefined || undefined
+same true, undefined || true
+same error, undefined || error
+
+same true, true || false
+same true, true || undefined
+same true, true || true
+same true, true || error
+
+same error, error || false
+same error, error || undefined
+same error, error || true
+same error, error || error
+
+
+echo Testing ! operator
+same true, !false
+same undefined, !undefined
+same false, !true
+same error, !error
+
+
+echo Testing ? operator
+same false, false ? true : false
+same true, false ? false : true
+same undefined, false ? true : undefined
+same true, false ? undefined : true
+
+same true, true ? true : false
+same false, true ? false : true
+same true, true ? true : undefined
+same undefined, true ? undefined : true
+
+echo Testing characters with negative ascii values
+// # the following used to not even parse on some systems
+same "–", "–"
+
+echo Testing stringListsIntersect()
+same true, stringListsIntersect("one,two","two,three")
+same false, stringListsIntersect("one,two","three,four")
+same false, stringListsIntersect("one,two","three,four",";")
+same true, stringListsIntersect("one,two","one")
+same true, stringListsIntersect("one, two","two, three")
+same true, stringListsIntersect("one,two","two,three",",")
+same true, stringListsIntersect("one;two","two;three",";")
+same undefined, stringListsIntersect("one,two",undefined)
+same undefined, stringListsIntersect(undefined,"one,two" )