diff --git a/.gitattributes b/.gitattributes index ab9b8a75aa5c991e14e42196c03c30b3d381346d..b0dfd153a02cc8bddbc473169ebc74115d52224c 100644 --- a/.gitattributes +++ b/.gitattributes @@ -1230,6 +1230,9 @@ CEP/Pipeline/framework/lofarpipe/CMakeLists.txt eol=lf CEP/Pipeline/framework/lofarpipe/GRIDInterface/docs/Design[!!-~]Lofar[!!-~]Batch[!!-~]scheduler.docx -text CEP/Pipeline/framework/lofarpipe/GRIDInterface/docs/LOFAR[!!-~]batch[!!-~]scheduler[!!-~]interface.docx -text CEP/Pipeline/framework/lofarpipe/GRIDInterface/docs/Presentation[!!-~]LOFAR[!!-~]DPU[!!-~]XML[!!-~]interface.pptx -text +CEP/Pipeline/framework/lofarpipe/GRIDInterface/src/dpu_xml_interface.py -text +CEP/Pipeline/framework/lofarpipe/GRIDInterface/src/pipeline_job.py -text +CEP/Pipeline/framework/lofarpipe/GRIDInterface/src/tar_cal.xml -text CEP/Pipeline/framework/lofarpipe/__init__.py eol=lf CEP/Pipeline/framework/lofarpipe/cuisine/COPYING eol=lf CEP/Pipeline/framework/lofarpipe/cuisine/README eol=lf diff --git a/CEP/Pipeline/framework/lofarpipe/GRIDInterface/src/dpu_xml_interface.py b/CEP/Pipeline/framework/lofarpipe/GRIDInterface/src/dpu_xml_interface.py new file mode 100644 index 0000000000000000000000000000000000000000..7e01bf664f6189aa5afb60ade401afb80f59b49c --- /dev/null +++ b/CEP/Pipeline/framework/lofarpipe/GRIDInterface/src/dpu_xml_interface.py @@ -0,0 +1,436 @@ +""" +Interface to the DPU that converts a XML input file into a batch of DPU jobs. +""" + +import os +import sys +import time + +from xml.dom import minidom +from xml.parsers.expat import ExpatError + +from common.net.dpu_client_test import dpu_IO +from common.config.Environment import Env +from awlofar.toolbox.msss.pipeline_job import cep_pipeline_job +from lofar.parameterset import parameterset +from lofarpipe.support.data_map import * + +class pipeline: + """ + The pipeline class stores and interprets the information about the pipeline + that was read from the XML file. + """ + + def __init__(self, id, predecessors='', inputs='', outputs='', parset=''): + self.id = id + self.predecessors_as_str = predecessors + self.inputs = inputs + self.output = outputs + self.parset_as_str = str(parset) + self.parset = parameterset() + + def read_parset(self): + """ + Convert the string containing a parset into parameterset object. + """ + self.parset.adoptArgv(str(self.parset_as_str).split('\n')) + + def get_predecessors(self): + """ + Convert the string containing the pipeline's predecessors into + a Python list by splitting on the comma symbol. + An empty list is returned if the pipeline does not have any predecessors. + """ + if self.predecessors_as_str: + return self.predecessors_as_str.split(',') + else: + # In this case, the predecessors_as_str attribute was an empty string. + return [] + + def get_command(self): + """ + Read the pipeline's top-level Python script, used to start the pipeline, from its parset. + """ + return self.parset.getString('ObsSW.Observation.ObservationControl.PythonControl.pythonProgram', '') + + def get_tasks(self): + """ + Convert the pipeline into DPU tasks. We assume that the pipeline can be parallelized by + creating independent tasks for all its input files. Furthermore, we do take into account + that there might be dependencies between different pipelines. In that case, task number i + for input file i of the next pipeline will start when task number i for input file i of the + previous pipeline has finished. + + As an example, the following shows how a calibration pipeline followed by a target pipeline + (which should wait for the calibration pipeline to finish) are parallelized: + + Tasks + 0 1 ... N + Pipeline 0: SB000 SB001 SB00N (all executed independently) + (calibration) + + Pipeline 1: SB000 SB001 SB00N (horizontally independent, but vertically depending on the previous task) + (target) + + The dependencies between the pipelines will be handled at a later stage. + """ + + # First, interpret the parset and get all the information about the + # input and output files as was defined in the XML. + self.read_parset() + inputs_filenames_keys = map(lambda input: str( input['filenames']), self.inputs.values()) + inputs_locations_keys = map(lambda input: str( input['locations']), self.inputs.values()) + inputs_skip_keys = map(lambda input: str( input['skip']), self.inputs.values()) + outputs_filenames_keys = map(lambda output: str(output['filenames']), self.outputs.values()) + outputs_locations_keys = map(lambda output: str(output['locations']), self.outputs.values()) + outputs_skip_keys = map(lambda output: str(output['skip']), self.outputs.values()) + + input_map_list = [] + output_map_list = [] + # Combine the information about each input and output into tuples. + # Note that the order of these keys are used when creating the individual jobs: + # filenames, locations, skip values + input_map_keys = zip(inputs_filenames_keys, inputs_locations_keys, inputs_skip_keys ) + output_map_keys = zip(outputs_filenames_keys, outputs_locations_keys, outputs_skip_keys ) + + # Create a DataMap for each input and each output. + for filename, location, skip in input_map_keys: + input_map_list.append( + DataMap([ + tuple(os.path.join(location, filename).split(':')) + (skip,) + for filename, location, skip in zip( + self.parset.getStringVector(filename), + self.parset.getStringVector(location), + self.parset.getBoolVector(skip)) + ]) + ) + + for filename, location, skip in output_map_keys: + output_map_list.append( + DataMap([ + tuple(os.path.join(location, filename).split(':')) + (skip,) + for filename, location, skip in zip( + self.parset.getStringVector(filename), + self.parset.getStringVector(location), + self.parset.getBoolVector(skip)) + ]) + ) + + # Align the data maps in order to validate them and set the skip values + # in the same way for each input and output. + align_data_maps(*(input_map_list+output_map_list)) + + # Finally, convert everything into individual tasks. + pipeline_jobs = [] + job_data_product_keys = input_map_keys + output_map_keys + for idx, job_data_products in enumerate(zip(*(input_map_list+ output_map_list))): + job = cep_pipeline_job() + # Clone the parset by creating another instance. + job_parset = parameterset() + job_parset.adoptArgv(str(self.parset_as_str).split('\n')) + job_should_be_skipped = False + + # Now replace all input and output information by the (single) data + # element that should be processed by this task. + for [job_data_product, job_data_product_key] in zip(job_data_products, job_data_product_keys): + job_should_be_skipped = job_data_product.skip + job.host = job_data_product.host + # We assume that the job will be launched on the node where the + # data is stored. + host = 'localhost' + filename = os.path.basename(job_data_product.file) + file_location = os.path.dirname(job_data_product.file) + skip = job_data_product.skip + # Remember that the key order is determined in a previous zip. + job_parset.replace(job_data_product_key[0], str([filename])) + job_parset.replace(job_data_product_key[1], str([host + ":" + file_location])) + job_parset.replace(job_data_product_key[2], str([skip])) + + if job_should_be_skipped : + # If skip was True for either one of the input/output elements, + # we should skip this job but increase the job index. + continue + + job.parset_as_dict = job_parset.dict() + job.command = self.get_command() + job.name = self.id + "_" + str(idx) + pipeline_jobs.append(job) + + return pipeline_jobs + + +class pipeline_xml_parser: + """ + This class can be used to parse a XML input file that should be converted + into DPU jobs. + """ + + def parse(self, xmlfile): + """ + Try to parse the XML file into a XML Document object. This will also + check if the input file is a valid XML file. + """ + + try: + self.xml = minidom.parse(xmlfile).documentElement + return True + except ExpatError as e: + self.parse_error = e + return False + + def get_child_text(self, tagname, node=None): + """ + Try to find a child with a given tag name and return its (text) + value. If no parent node was specified, the root node of the XML + document will be used, i.e. the entire document will be searched. + If no child with the given tag name can be found, an empty string + is returned. + """ + if node == None: + node = self.xml + children = node.getElementsByTagName(tagname) + if len(children) > 0 and len(children[0].childNodes) > 0: + return children[0].firstChild.data + else: + return '' + + def get_child_cdata(self, tagname, node): + """ + For a given node, try to find a descendant with a given tag name and that + contains a CDATA section. This CDATA, if found, will be returned as a + string. Otherwise, an empty string is returned. + """ + elements = node.getElementsByTagName(tagname) + result = '' + for el in elements: + for child in el.childNodes: + if child.nodeType == self.xml.CDATA_SECTION_NODE: + result = child.data + return result + + def node_to_dict(self, node): + """ + Convert the XML subtree starting at the specified node into a Python + dictionary. All branches (element nodes) are used as dictionary keys, + while the leaves are used as values. Note that the function is + recursive and, hence, the resulting dictionary itself can contain + other dictionaries again. + """ + d = {} + for child in node.childNodes: + if child.nodeType == self.xml.ELEMENT_NODE: + d[child.nodeName] = self.node_to_dict(child) + if child.nodeType == self.xml.TEXT_NODE and not child.nodeValue.strip() == '': + return child.nodeValue + return d + + + def get_inputs(self, pipeline): + """ + Return the inputs of a pipeline node as a dictionary. + """ + inputs_node = pipeline.getElementsByTagName("inputs") + if len(inputs_node) > 0: + return self.node_to_dict(inputs_node[0]) + else: + return {} + + def get_outputs(self, pipeline): + """ + Return the outputs of a pipeline node as a dictionary. + """ + outputs_node = pipeline.getElementsByTagName("outputs") + if len(outputs_node) > 0: + return self.node_to_dict(outputs_node[0]) + else: + return {} + + def get_pipeline_block_id(self): + """ + Return the block id of the pipeline node. + """ + idtags = self.xml.getElementsByTagName('pipeline_block_id'); + if len(idtags) > 0: + return idtags[0].firstChild.data + + def get_pipelines(self): + """ + Find all pipelines described in the XML file, convert them into + pipeline objects that store all the corresponding information + and return them as a list. + The function assumes that all pipelines at least have a pipeline_id, + so it uses this to find pipelines in the XML file. + """ + pipelines = [] + pipeline_ids = self.xml.getElementsByTagName('pipeline_id') + for id_elem in pipeline_ids: + id = id_elem.firstChild.data + pipeline_node = id_elem.parentNode + pipeline_obj = pipeline(id) + pipeline_obj.predecessors_as_str = self.get_child_text('predecessors', pipeline_node) + pipeline_obj.inputs = self.get_inputs(pipeline_node) + pipeline_obj.outputs = self.get_outputs(pipeline_node) + pipeline_obj.parset_as_str = self.get_child_cdata('config', pipeline_node) + pipelines.append(pipeline_obj) + return pipelines + + +class dpu_xml_interface: + """ + The dpu_xml_interface class starts the DPU XML interface application and + performs the following steps: + + - parse the arguments, make sure that a XML file is passed as argument; + - parse the XML file and get all the pipeline objects stored in it; + - determine a suitable order for the pipelines, based on their predecessors; + - cut the pipeline into individual, independent tasks; + - submit the these individual tasks in the correct way and order to the DPU; + - keep polling the job statuses until all jobs have finished. + + """ + + # DPU client object + dpu = dpu_IO(dpu_name=Env['dpu_name'], dbinfo=('dummy', 'awdummy', 'dummy', 'dummy')) + + def usage(self): + """ + Display usage. + """ + exit("Usage: %s [options] <xml file>" % sys.argv[0]) + + def exit(self, error, code=1): + """ + Print an error and exit. + """ + print >> sys.stderr, "Error!\n", error + sys.exit(code) + + def parse_arguments(self): + """ + Parse the input arguments and return the name of the given XML file. + """ + if len(sys.argv) < 2: + return self.usage() + + xml_filename = sys.argv[1] + if not os.path.exists(xml_filename): + self.exit("The specified XML file cannot be found: %s." % xml_filename) + + return xml_filename + + def order_pipelines(self, pipelines_unsorted): + """ + Order the pipelines based on the dependecies that are specified with + the predecessors information. Each pipeline can have one or more + predecessors that have to complete before the pipeline itself can run. + + We determine the order by iteratively going over all pipelines and + moving pipelines into a new (ordered) list if they either do not have + any predecessor or if all their predecessors are already in the new + list. We keep doing this until the original list is empty, meaning + that all dependencies were handled correctly. + If during a single iteration nothing changes, it means we have a + circular dependency that cannot be met. + """ + pipelines = [] + pipelines_ids = [] + #TODO: how to run/store multiple independent pipelines? + while len(pipelines_unsorted) > 0: + changed = False + for pipeline in pipelines_unsorted: + if all(predecessor in pipelines_ids for predecessor in pipeline.get_predecessors()): + # The above will also evaluate to True for pipelines with no predecessors. + pipelines.append(pipeline) + pipelines_ids.append(pipeline.id) + pipelines_unsorted.remove(pipeline) + changed = True + if not changed: + # No changes are made during this iteration, which means that + # there is a circular dependency. + self.exit("A circular dependency between some pipelines was found.") + + return pipelines + + def submit_jobs(self, jobs): + """ + Submit a list of jobs to the DPU and return the DPU keys. + The jobs parameter should be a list of lists, where the order of the + lists determine their dependencies. Seen as a matrix, each column + will be a job that runs the tasks (rows) sequentially. All columns + are considered to be independent and, therefore, will be submitted + as independent DPU jobs. + """ + dpu_jobs = {} + dpu_job_keys = {'SUBMITTED': [], 'FAILED': [], 'DONE': []} + + # Get all "columns" of the jobs matrix. + for seq_jobs in zip(*jobs): + # TODO: use one thread per job submission to submit all at once (submitting jobs can take a couple of seconds) + + # Map the column to individual tasks and set the right node + # (i.e. where the data is stored) and the right mode for each task. + job = map(lambda job: {'DPU_JOBS':[job], 'DPU_NODES':[job.host], 'DPU_MODE':'SEQ'}, seq_jobs) + + # Request a DPU key and submit the job. + key = self.dpu.getkey() + if self.dpu.submitjobs(key, jobs=job, code=None): + dpu_job_keys['SUBMITTED'].append(key) + else: + print "Error while submitting job:", job.name + dpu_job_keys['FAILED'].append(key) + + return dpu_job_keys + + def wait_for_jobs(self, dpu_job_keys): + """ + This will start a loop that will run until all jobs have finished. + Once a job finishes, we put the corresponding key in an appropriate list + depending on the status of the job. + """ + + print "Waiting for all jobs to complete..." + while not len(dpu_job_keys['SUBMITTED']) == 0: + time.sleep(10) + for key in dpu_job_keys['SUBMITTED']: + status = self.dpu.getstatus(key) + if status.startswith('FINISHED'): + dpu_job_keys['SUBMITTED'].remove(key) + if status.endswith('0/0/0/0'): + dpu_job_keys['DONE'].append(key) + else: + dpu_job_keys['FAILED'].append(key) + + # TODO: retrieve jobs when done? What to do with logs? + print dpu_job_keys + + + def main(self): + """ + Main function that runs all the individual steps. + """ + + # Parse the input arguments. + xmlfile = self.parse_arguments() + + # Create a XML parser object and parse the given XML file. + self.xml_parser = pipeline_xml_parser() + if not(self.xml_parser.parse(xmlfile)): + self.exit("Error while parsing the XML file:\n%s" % self.xml_parser.parse_error) + + # Get all pipelines from the XML file and determine a correct order. + pipelines = self.xml_parser.get_pipelines() + pipelines = self.order_pipelines(pipelines) + + # Convert all pipelines into individual tasks. + jobs = [] + for p in pipelines: + jobs.append(p.get_tasks()) + + # Submit the jobs and wait for them to complete. + dpu_job_keys = self.submit_jobs(jobs) + self.wait_for_jobs(dpu_job_keys) + + return 0 + +if __name__ == '__main__': + sys.exit(dpu_xml_interface().main()) diff --git a/CEP/Pipeline/framework/lofarpipe/GRIDInterface/src/pipeline_job.py b/CEP/Pipeline/framework/lofarpipe/GRIDInterface/src/pipeline_job.py new file mode 100644 index 0000000000000000000000000000000000000000..7c19e4a4020d83e0d5f22a523ae772a2f6978350 --- /dev/null +++ b/CEP/Pipeline/framework/lofarpipe/GRIDInterface/src/pipeline_job.py @@ -0,0 +1,40 @@ +""" +DPU pipeline jobs that can be used by the DPU XML interface. +""" + +import subprocess +import time + +""" +Base class containing the main functionality for a pipeline job. +""" +class pipeline_job: + + def __init__(self, command='', parset={}, name=''): + self.command = command + self.parset_as_dict = parset + self.name = name + + def execute(self): + pass + + +""" +Pipeline job that can be used to run on the CEP cluster. It assumes that the +data is already stored on the node where the job is running and that an +appropriate startPython.sh script is available to start pipeline runs. +""" +class cep_pipeline_job(pipeline_job): + + def execute(self): + f = open(self.name, "w") + for key,value in self.parset_as_dict.items(): + f.write(key + "=" + str(value) + "\n") + f.close() + + #time.sleep(15) + + p = subprocess.Popen("startPython.sh " + self.command + " " + self.name + " 0 0 0", stdout=subprocess.PIPE, stderr=subprocess.PIPE, shell=True) + self.stdout, self.stderr = p.communicate() + # Clean up statefile etc + diff --git a/CEP/Pipeline/framework/lofarpipe/GRIDInterface/src/tar_cal.xml b/CEP/Pipeline/framework/lofarpipe/GRIDInterface/src/tar_cal.xml new file mode 100644 index 0000000000000000000000000000000000000000..a447100218b7bc745dbaadc5b922091e663d0d49 --- /dev/null +++ b/CEP/Pipeline/framework/lofarpipe/GRIDInterface/src/tar_cal.xml @@ -0,0 +1,2675 @@ +<?xml version="1.0" encoding="ISO-8859-1"?> +<pipeline_block> + <pipeline_block_id>f9304969b5104da6999a5b1db6c715dd</pipeline_block_id> + <dpu_block_config></dpu_block_config> + <comment>A valid batch pipeline block: calibration pipeline + target pipeline </comment> + <msss_calibration_pipeline> + <pipeline_id>observation64405</pipeline_id> + <comments></comments> + <predecessors></predecessors> + <inputs> + <Input_correlated> + <locations>ObsSW.Observation.DataProducts.Input_Correlated.locations</locations> + <filenames>ObsSW.Observation.DataProducts.Input_Correlated.filenames</filenames> + <skip>ObsSW.Observation.DataProducts.Input_Correlated.skip</skip> + </Input_correlated> + </inputs> + <outputs> + <Output_Correlated> + <filenames>ObsSW.Observation.DataProducts.Output_Correlated.filenames</filenames> + <locations>ObsSW.Observation.DataProducts.Output_Correlated.locations</locations> + <skip>ObsSW.Observation.DataProducts.Output_Correlated.skip</skip> + </Output_Correlated> + <Output_InstrumentModel> + <filenames>ObsSW.Observation.DataProducts.Output_InstrumentModel.filenames</filenames> + <locations>ObsSW.Observation.DataProducts.Output_InstrumentModel.locations</locations> + <skip>ObsSW.Observation.DataProducts.Output_InstrumentModel.skip</skip> + </Output_InstrumentModel> + </outputs> + <dpu_pipeline_config></dpu_pipeline_config> + <config> + <![CDATA[" +ObsSW.Observation.DataProducts.Input_Correlated.filenames=[L64371_SAP000_SB000_uv.MS,L64371_SAP000_SB001_uv.MS] +ObsSW.Observation.DataProducts.Input_Correlated.locations=[lce040:/data/scratch/klijn/calibrator_pipeline,lce041:/data/scratch/klijn/calibrator_pipeline] +ObsSW.Observation.DataProducts.Input_Correlated.skip=[0,0] +ObsSW.Observation.DataProducts.Output_InstrumentModel.filenames=[L64405_SAP000_SB000_inst.INST,L64405_SAP000_SB001_inst.INST] + +# BOB you should adapt this output location if running +ObsSW.Observation.DataProducts.Output_InstrumentModel.locations=[lce040:/data/scratch/droge/calibrator_test/,lce041:/data/scratch/droge/calibrator_test/] +# +ObsSW.Observation.DataProducts.Output_Correlated.filenames=[L64371_SAP000_SB000_dppp.MS,L64371_SAP000_SB001_dppp.MS] +ObsSW.Observation.DataProducts.Output_Correlated.locations=[lce040:/data/scratch/droge/calibrator_test/,lce041:/data/scratch/droge/calibrator_test/] +ObsSW.Observation.DataProducts.Output_Correlated.skip=[0,0] + +ObsSW.Observation.DataProducts.Output_InstrumentModel.skip=[0,0] +Clock160.channelWidth=610.3515625 +Clock160.samplesPerSecond=155648 +Clock160.subbandWidth=156.250 +Clock160.systemClock=160 +Clock200.channelWidth=762.939453125 +Clock200.samplesPerSecond=196608 +Clock200.subbandWidth=195.3125 +Clock200.systemClock=200 +ObsSW.Observation.Campaign.CO_I=Wise, Dr. Michael +ObsSW.Observation.Campaign.PI=Verhoef, Ir. Bastiaan +ObsSW.Observation.Campaign.contact=Verhoef, Ir. Bastiaan +ObsSW.Observation.Campaign.name=test-lofar +ObsSW.Observation.Campaign.title=test-lofar +ObsSW.Observation.DataProducts.Input_Beamformed.dirmask= +ObsSW.Observation.DataProducts.Input_Beamformed.enabled=false +ObsSW.Observation.DataProducts.Input_Beamformed.filenames=[] +ObsSW.Observation.DataProducts.Input_Beamformed.identifications=[] +ObsSW.Observation.DataProducts.Input_Beamformed.locations=[] +ObsSW.Observation.DataProducts.Input_Beamformed.mountpoints=[] +ObsSW.Observation.DataProducts.Input_Beamformed.namemask= +ObsSW.Observation.DataProducts.Input_Beamformed.skip=[] +ObsSW.Observation.DataProducts.Input_CoherentStokes.dirmask= +ObsSW.Observation.DataProducts.Input_CoherentStokes.enabled=false +ObsSW.Observation.DataProducts.Input_CoherentStokes.filenames=[] +ObsSW.Observation.DataProducts.Input_CoherentStokes.identifications=[] +ObsSW.Observation.DataProducts.Input_CoherentStokes.locations=[] +ObsSW.Observation.DataProducts.Input_CoherentStokes.mountpoints=[] +ObsSW.Observation.DataProducts.Input_CoherentStokes.namemask= +ObsSW.Observation.DataProducts.Input_CoherentStokes.skip=[] +ObsSW.Observation.DataProducts.Input_Correlated.dirmask=L${OBSID} +ObsSW.Observation.DataProducts.Input_Correlated.enabled=true +ObsSW.Observation.DataProducts.Input_IncoherentStokes.dirmask= +ObsSW.Observation.DataProducts.Input_IncoherentStokes.enabled=false +ObsSW.Observation.DataProducts.Input_IncoherentStokes.filenames=[] +ObsSW.Observation.DataProducts.Input_IncoherentStokes.identifications=[] +ObsSW.Observation.DataProducts.Input_IncoherentStokes.locations=[] +ObsSW.Observation.DataProducts.Input_IncoherentStokes.mountpoints=[] +ObsSW.Observation.DataProducts.Input_IncoherentStokes.namemask= +ObsSW.Observation.DataProducts.Input_IncoherentStokes.skip=[] +ObsSW.Observation.DataProducts.Input_InstrumentModel.dirmask= +ObsSW.Observation.DataProducts.Input_InstrumentModel.enabled=false +ObsSW.Observation.DataProducts.Input_InstrumentModel.filenames=[] +ObsSW.Observation.DataProducts.Input_InstrumentModel.identifications=[] +ObsSW.Observation.DataProducts.Input_InstrumentModel.locations=[] +ObsSW.Observation.DataProducts.Input_InstrumentModel.mountpoints=[] +ObsSW.Observation.DataProducts.Input_InstrumentModel.namemask= +ObsSW.Observation.DataProducts.Input_InstrumentModel.skip=[] +ObsSW.Observation.DataProducts.Input_SkyImage.dirmask= +ObsSW.Observation.DataProducts.Input_SkyImage.enabled=false +ObsSW.Observation.DataProducts.Input_SkyImage.filenames=[] +ObsSW.Observation.DataProducts.Input_SkyImage.identifications=[] +ObsSW.Observation.DataProducts.Input_SkyImage.locations=[] +ObsSW.Observation.DataProducts.Input_SkyImage.mountpoints=[] +ObsSW.Observation.DataProducts.Input_SkyImage.namemask= +ObsSW.Observation.DataProducts.Input_SkyImage.skip=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Offset.angle1=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Offset.angle2=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Offset.coordType=RA +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Offset.equinox=J2000 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Pointing.angle1=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Pointing.angle2=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Pointing.coordType=RA +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Pointing.equinox=J2000 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.SubArrayPointingIdentifier=MoM +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.beamNumber=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.centralFrequencies=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.channelWidth=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.dispersionMeasure=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.numberOfSubbands=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.stationSubbands=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordSystAF0=ITRF2005 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordSystAF1=ITRF2005 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordXAF0=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordXAF1=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordYAF0=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordYAF1=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordZAF0=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordZAF1=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.name= +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.nameAF0=LBA +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.nameAF1=LBA +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.nrAntennaField=1 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.stationType=Core +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.SubArrayPointingIdentifier=MoM +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.beamNumber=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.centralFrequencies=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.channelWidth=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.dispersionMeasure=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.numberOfSubbands=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.stationSubbands=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.SubArrayPointingIdentifier=MoM +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.beamNumber=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.centralFrequencies=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.channelWidth=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.dispersionMeasure=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.numberOfSubbands=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.stationSubbands=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.beamTypes=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.fileFormat=HDF5 +ObsSW.Observation.DataProducts.Output_BeamFormed_.filename= +ObsSW.Observation.DataProducts.Output_BeamFormed_.location= +ObsSW.Observation.DataProducts.Output_BeamFormed_.nrOfCoherentStokesBeams=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.nrOfFlysEyeBeams=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.nrOfIncoherentStokesBeams=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.percentageWritten=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.size=0 +ObsSW.Observation.DataProducts.Output_Beamformed.archived=false +ObsSW.Observation.DataProducts.Output_Beamformed.deleted=false +ObsSW.Observation.DataProducts.Output_Beamformed.dirmask= +ObsSW.Observation.DataProducts.Output_Beamformed.enabled=false +ObsSW.Observation.DataProducts.Output_Beamformed.filenames=[] +ObsSW.Observation.DataProducts.Output_Beamformed.identifications=[] +ObsSW.Observation.DataProducts.Output_Beamformed.locations=[] +ObsSW.Observation.DataProducts.Output_Beamformed.mountpoints=[] +ObsSW.Observation.DataProducts.Output_Beamformed.namemask= +ObsSW.Observation.DataProducts.Output_Beamformed.percentageWritten=[] +ObsSW.Observation.DataProducts.Output_Beamformed.retentiontime=14 +ObsSW.Observation.DataProducts.Output_Beamformed.skip=[] +ObsSW.Observation.DataProducts.Output_CoherentStokes.archived=false +ObsSW.Observation.DataProducts.Output_CoherentStokes.deleted=false +ObsSW.Observation.DataProducts.Output_CoherentStokes.dirmask= +ObsSW.Observation.DataProducts.Output_CoherentStokes.enabled=false +ObsSW.Observation.DataProducts.Output_CoherentStokes.filenames=[] +ObsSW.Observation.DataProducts.Output_CoherentStokes.identifications=[] +ObsSW.Observation.DataProducts.Output_CoherentStokes.locations=[] +ObsSW.Observation.DataProducts.Output_CoherentStokes.mountpoints=[] +ObsSW.Observation.DataProducts.Output_CoherentStokes.namemask= +ObsSW.Observation.DataProducts.Output_CoherentStokes.percentageWritten=[] +ObsSW.Observation.DataProducts.Output_CoherentStokes.retentiontime=14 +ObsSW.Observation.DataProducts.Output_CoherentStokes.skip=[] +ObsSW.Observation.DataProducts.Output_Correlated.archived=false +ObsSW.Observation.DataProducts.Output_Correlated.deleted=false +ObsSW.Observation.DataProducts.Output_Correlated.dirmask= +ObsSW.Observation.DataProducts.Output_Correlated.enabled=false +ObsSW.Observation.DataProducts.Output_Correlated.identifications=[mom_msss_131277.1.C.SAP000.dps] +ObsSW.Observation.DataProducts.Output_Correlated.mountpoints=[] +ObsSW.Observation.DataProducts.Output_Correlated.namemask= +ObsSW.Observation.DataProducts.Output_Correlated.percentageWritten=[] +ObsSW.Observation.DataProducts.Output_Correlated.retentiontime=14 +ObsSW.Observation.DataProducts.Output_Correlated_.centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_.channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_.channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_.duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_.fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_.filename= +ObsSW.Observation.DataProducts.Output_Correlated_.integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_.location= +ObsSW.Observation.DataProducts.Output_Correlated_.percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_.size=0 +ObsSW.Observation.DataProducts.Output_Correlated_.startTime= +ObsSW.Observation.DataProducts.Output_Correlated_.stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_.subband=0 +ObsSW.Observation.DataProducts.Output_IncoherentStokes.archived=false +ObsSW.Observation.DataProducts.Output_IncoherentStokes.deleted=false +ObsSW.Observation.DataProducts.Output_IncoherentStokes.dirmask= +ObsSW.Observation.DataProducts.Output_IncoherentStokes.enabled=false +ObsSW.Observation.DataProducts.Output_IncoherentStokes.filenames=[] +ObsSW.Observation.DataProducts.Output_IncoherentStokes.identifications=[] +ObsSW.Observation.DataProducts.Output_IncoherentStokes.locations=[] +ObsSW.Observation.DataProducts.Output_IncoherentStokes.mountpoints=[] +ObsSW.Observation.DataProducts.Output_IncoherentStokes.namemask= +ObsSW.Observation.DataProducts.Output_IncoherentStokes.percentageWritten=[] +ObsSW.Observation.DataProducts.Output_IncoherentStokes.retentiontime=14 +ObsSW.Observation.DataProducts.Output_IncoherentStokes.skip=[] +ObsSW.Observation.DataProducts.Output_InstrumentModel.archived=false +ObsSW.Observation.DataProducts.Output_InstrumentModel.deleted=false +ObsSW.Observation.DataProducts.Output_InstrumentModel.dirmask=L${OBSID} +ObsSW.Observation.DataProducts.Output_InstrumentModel.enabled=true +ObsSW.Observation.DataProducts.Output_InstrumentModel_[0].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[0].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[0].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[0].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[0].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[10].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[10].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[10].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[10].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[10].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[11].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[11].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[11].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[11].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[11].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[12].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[12].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[12].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[12].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[12].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[13].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[13].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[13].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[13].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[13].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[14].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[14].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[14].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[14].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[14].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[15].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[15].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[15].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[15].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[15].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[16].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[16].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[16].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[16].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[16].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[17].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[17].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[17].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[17].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[17].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[18].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[18].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[18].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[18].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[18].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[19].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[19].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[19].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[19].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[19].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[1].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[1].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[1].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[1].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[1].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[20].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[20].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[20].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[20].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[20].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[21].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[21].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[21].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[21].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[21].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[22].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[22].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[22].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[22].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[22].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[23].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[23].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[23].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[23].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[23].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[24].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[24].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[24].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[24].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[24].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[25].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[25].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[25].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[25].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[25].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[26].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[26].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[26].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[26].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[26].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[27].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[27].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[27].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[27].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[27].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[28].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[28].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[28].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[28].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[28].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[29].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[29].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[29].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[29].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[29].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[2].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[2].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[2].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[2].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[2].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[30].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[30].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[30].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[30].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[30].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[31].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[31].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[31].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[31].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[31].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[32].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[32].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[32].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[32].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[32].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[33].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[33].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[33].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[33].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[33].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[34].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[34].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[34].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[34].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[34].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[35].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[35].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[35].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[35].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[35].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[36].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[36].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[36].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[36].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[36].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[37].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[37].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[37].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[37].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[37].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[38].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[38].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[38].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[38].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[38].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[39].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[39].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[39].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[39].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[39].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[3].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[3].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[3].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[3].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[3].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[40].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[40].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[40].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[40].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[40].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[41].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[41].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[41].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[41].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[41].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[42].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[42].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[42].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[42].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[42].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[43].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[43].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[43].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[43].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[43].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[44].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[44].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[44].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[44].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[44].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[45].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[45].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[45].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[45].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[45].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[46].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[46].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[46].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[46].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[46].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[47].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[47].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[47].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[47].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[47].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[48].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[48].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[48].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[48].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[48].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[49].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[49].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[49].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[49].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[49].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[4].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[4].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[4].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[4].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[4].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[50].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[50].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[50].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[50].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[50].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[51].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[51].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[51].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[51].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[51].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[52].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[52].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[52].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[52].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[52].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[53].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[53].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[53].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[53].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[53].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[54].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[54].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[54].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[54].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[54].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[55].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[55].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[55].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[55].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[55].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[56].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[56].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[56].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[56].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[56].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[57].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[57].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[57].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[57].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[57].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[58].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[58].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[58].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[58].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[58].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[59].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[59].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[59].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[59].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[59].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[5].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[5].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[5].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[5].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[5].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[60].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[60].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[60].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[60].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[60].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[61].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[61].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[61].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[61].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[61].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[62].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[62].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[62].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[62].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[62].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[63].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[63].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[63].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[63].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[63].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[64].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[64].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[64].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[64].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[64].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[65].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[65].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[65].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[65].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[65].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[66].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[66].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[66].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[66].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[66].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[67].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[67].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[67].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[67].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[67].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[68].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[68].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[68].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[68].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[68].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[69].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[69].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[69].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[69].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[69].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[6].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[6].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[6].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[6].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[6].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[70].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[70].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[70].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[70].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[70].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[71].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[71].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[71].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[71].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[71].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[72].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[72].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[72].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[72].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[72].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[73].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[73].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[73].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[73].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[73].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[74].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[74].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[74].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[74].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[74].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[75].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[75].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[75].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[75].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[75].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[76].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[76].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[76].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[76].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[76].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[77].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[77].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[77].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[77].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[77].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[78].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[78].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[78].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[78].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[78].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[79].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[79].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[79].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[79].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[79].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[7].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[7].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[7].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[7].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[7].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[8].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[8].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[8].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[8].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[8].size=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[9].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_[9].filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[9].location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_[9].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_[9].size=0 +ObsSW.Observation.DataProducts.Output_SkyImage.archived=false +ObsSW.Observation.DataProducts.Output_SkyImage.deleted=false +ObsSW.Observation.DataProducts.Output_SkyImage.dirmask= +ObsSW.Observation.DataProducts.Output_SkyImage.enabled=false +ObsSW.Observation.DataProducts.Output_SkyImage.filenames=[] +ObsSW.Observation.DataProducts.Output_SkyImage.identifications=[] +ObsSW.Observation.DataProducts.Output_SkyImage.locations=[] +ObsSW.Observation.DataProducts.Output_SkyImage.mountpoints=[] +ObsSW.Observation.DataProducts.Output_SkyImage.namemask= +ObsSW.Observation.DataProducts.Output_SkyImage.percentageWritten=[] +ObsSW.Observation.DataProducts.Output_SkyImage.retentiontime=14 +ObsSW.Observation.DataProducts.Output_SkyImage.skip=[] +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.DirectionLinearAxis.increment=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.DirectionLinearAxis.length=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.DirectionLinearAxis.name= +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.DirectionLinearAxis.referencePixel=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.DirectionLinearAxis.referenceValue=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.DirectionLinearAxis.units= +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.PC0_0=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.PC0_1=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.PC1_0=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.PC1_1=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.equinox= +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.latitudePole=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.longitudePole=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.nrOfDirectionLinearAxes=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.projection= +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.projectionParameters=[] +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.raDecSystem=ICRS +ObsSW.Observation.DataProducts.Output_SkyImage_.Pointing.angle1=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.Pointing.angle2=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.Pointing.coordType=RA +ObsSW.Observation.DataProducts.Output_SkyImage_.Pointing.equinox=J2000 +ObsSW.Observation.DataProducts.Output_SkyImage_.PolarizationCoordinate.PolarizationTabularAxis.length=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.PolarizationCoordinate.PolarizationTabularAxis.name= +ObsSW.Observation.DataProducts.Output_SkyImage_.PolarizationCoordinate.PolarizationTabularAxis.units= +ObsSW.Observation.DataProducts.Output_SkyImage_.PolarizationCoordinate.polarizationType=["XX","XY","YX","YY"] +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralLinearAxis.increment=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralLinearAxis.length=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralLinearAxis.name= +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralLinearAxis.referencePixel=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralLinearAxis.referenceValue=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralLinearAxis.units= +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralTabularAxis.length=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralTabularAxis.name= +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralTabularAxis.units= +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.spectralAxisType=Linear +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.spectralQuantityType=Frequency +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.spectralQuantityValue=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_SkyImage_.filename= +ObsSW.Observation.DataProducts.Output_SkyImage_.location= +ObsSW.Observation.DataProducts.Output_SkyImage_.locationFrame=GEOCENTER +ObsSW.Observation.DataProducts.Output_SkyImage_.nrOfDirectionCoordinates=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.nrOfPolarizationCoordinates=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.nrOfSpectralCoordinates=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.numberOfAxes=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.percentageWritten=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.size=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.timeFrame= +ObsSW.Observation.DataProducts.nrOfOutput_BeamFormed_=0 +ObsSW.Observation.DataProducts.nrOfOutput_Correlated_=0 +ObsSW.Observation.DataProducts.nrOfOutput_InstrumentModels_=80 +ObsSW.Observation.DataProducts.nrOfOutput_SkyImages_=0 +ObsSW.Observation.KSPType=surveys +ObsSW.Observation.ObservationControl.PythonControl.AWimager.PBCut=1e-2 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.PsfImage= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.RefFreq= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.RowBlock=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.StepApplyElement=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.UseEJones=TRUE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.UseLIG=FALSE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.UseMasks=TRUE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.applyBeam=TRUE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.applyIonosphere=FALSE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.autoweight=FALSE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.cachesize=512 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.cellsize=1arcsec +ObsSW.Observation.ObservationControl.PythonControl.AWimager.chanmode=channel +ObsSW.Observation.ObservationControl.PythonControl.AWimager.chanstart=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.chanstep=1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.constrainflux=FALSE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.cyclefactor=1.5 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.cyclespeedup=-1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.data=DATA +ObsSW.Observation.ObservationControl.PythonControl.AWimager.displayprogress=FALSE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.field=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.filter= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.fits=no +ObsSW.Observation.ObservationControl.PythonControl.AWimager.fixed=FALSE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.gain=0.1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.hdf5=no +ObsSW.Observation.ObservationControl.PythonControl.AWimager.image= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.img_chanstart=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.img_chanstep=1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.img_nchan=1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.mask= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.maskblc=[0,0] +ObsSW.Observation.ObservationControl.PythonControl.AWimager.masktrc=[] +ObsSW.Observation.ObservationControl.PythonControl.AWimager.maskvalue=1.0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.maxsupport=1024 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.mode=mfs +ObsSW.Observation.ObservationControl.PythonControl.AWimager.model= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.ms= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.muellerdegrid=all +ObsSW.Observation.ObservationControl.PythonControl.AWimager.muellergrid=all +ObsSW.Observation.ObservationControl.PythonControl.AWimager.nchan=1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.nfacets=1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.niter=1000 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.noise=1.0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.npix=256 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.nscales=5 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.nterms=1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.operation=image +ObsSW.Observation.ObservationControl.PythonControl.AWimager.oversample=8 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.padding=1.0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.phasecenter= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.prefervelocity=TRUE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.prior= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.psf= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.residual= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.restored= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.robust=0.0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.select= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.sigma=0.001Jy +ObsSW.Observation.ObservationControl.PythonControl.AWimager.splitbeam=TRUE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.spwid=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.stokes=IQUV +ObsSW.Observation.ObservationControl.PythonControl.AWimager.targetflux=1.0Jy +ObsSW.Observation.ObservationControl.PythonControl.AWimager.threshold=0Jy +ObsSW.Observation.ObservationControl.PythonControl.AWimager.timewindow=300.0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.uservector=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.uvdist= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.verbose=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.weight=briggs +ObsSW.Observation.ObservationControl.PythonControl.AWimager.wmax=500.0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.wprojplanes=0 +ObsSW.Observation.ObservationControl.PythonControl.BBS.BBDB.Host=ldb001 +ObsSW.Observation.ObservationControl.PythonControl.BBS.BBDB.Name=lofarsys +ObsSW.Observation.ObservationControl.PythonControl.BBS.BBDB.Password= +ObsSW.Observation.ObservationControl.PythonControl.BBS.BBDB.Port=5432 +ObsSW.Observation.ObservationControl.PythonControl.BBS.BBDB.User=postgres +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Baselines=*& +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Correlations=[] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Bandpass.Enable=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Beam.ConjugateAF=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Beam.Element.Path=${LOFARROOT}/share +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Beam.Enable=T +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Beam.Mode=DEFAULT +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Cache.Enable=T +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.DirectionalGain.Enable=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Flagger.Enable=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Flagger.Threshold=0 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Gain.Enable=T +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Ionosphere.Degree=0 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Ionosphere.Enable=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Ionosphere.Type= +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Phasors.Enable=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Sources=[] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Operation=SOLVE +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Output.Column= +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Output.WriteCovariance=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Output.WriteFlags=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Algorithm=L2 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.CalibrationGroups=[] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.CellChunkSize=25 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.CellSize.Freq=0 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.CellSize.Time=1 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.EpsilonL1=[1e-4,1e-5,1e-6] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.ExclParms=[] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Log.Level=NONE +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Log.Name=solver_log +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Mode=COMPLEX +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Options.BalancedEqs=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Options.ColFactor=1e-9 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Options.EpsDerivative=1e-9 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Options.EpsValue=1e-9 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Options.LMFactor=1.0 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Options.MaxIter=50 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Options.UseSVD=T +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.OutlierRejection.Threshold=[7.0,5.0,4.0,3.5,3.0,2.8,2.6,2.4,2.2,2.5] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Parms=["Gain:0:0:*", "Gain:1:1:*"] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.PhaseShift.Direction=[] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.PhaseShift.Enable=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.PropagateSolutions=T +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Resample.CellSize.Freq=0 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Resample.CellSize.Time=0 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Resample.DensityThreshold=1.0 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.Resample.Enable=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Solve.UVRange=[] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.nrOfDefaultBBSStep=0 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Strategy.Baselines=*& +ObsSW.Observation.ObservationControl.PythonControl.BBS.Strategy.ChunkSize=100 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Strategy.Correlations=[] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Strategy.InputColumn=DATA +ObsSW.Observation.ObservationControl.PythonControl.BBS.Strategy.Steps=["DefaultBBSStep[0]"] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Strategy.TimeRange=[] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Strategy.UseSolver=F +ObsSW.Observation.ObservationControl.PythonControl.BDSM.advanced_opts=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.atrous_do=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.clobber=true +ObsSW.Observation.ObservationControl.PythonControl.BDSM.flagging_opts=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.interactive=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.mean_map=default +ObsSW.Observation.ObservationControl.PythonControl.BDSM.multichan_opts=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.output_opts=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.polarisation_do=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.psf_vary_do=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.quiet=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.rms_box=(15.0,9.0) +ObsSW.Observation.ObservationControl.PythonControl.BDSM.rms_map=true +ObsSW.Observation.ObservationControl.PythonControl.BDSM.shapelet_do=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.spectralindex_do=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.thresh=hard +ObsSW.Observation.ObservationControl.PythonControl.BDSM.thresh_isl=3.0 +ObsSW.Observation.ObservationControl.PythonControl.BDSM.thresh_pix=5.0 +ObsSW.Observation.ObservationControl.PythonControl.Calibration.SkyModel=3C295 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.autocorr=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.count.path=- +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.count.save=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.keepstatistics=T +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.memorymax=0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.memoryperc=0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.overlapmax=0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.overlapperc=-1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.pedantic=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.pulsar=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.timewindow=0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.type=aoflagger +ObsSW.Observation.ObservationControl.PythonControl.DPPP.averager.freqstep=4 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.averager.minperc=0.0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.averager.minpoints=0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.averager.timestep=1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.averager.type=averager +ObsSW.Observation.ObservationControl.PythonControl.DPPP.checkparset=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.counter.flagdata=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.counter.path=- +ObsSW.Observation.ObservationControl.PythonControl.DPPP.counter.save=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.counter.showfullyflagged=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.counter.type=counter +ObsSW.Observation.ObservationControl.PythonControl.DPPP.counter.warnperc=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.Solve.Options.BalancedEqs=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.Solve.Options.ColFactor=1e-9 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.Solve.Options.EpsDerivative=1e-9 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.Solve.Options.EpsValue=1e-9 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.Solve.Options.LMFactor=1.0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.Solve.Options.MaxIter=50 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.Solve.Options.UseSVD=T +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.demixfreqstep=64 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.demixtimestep=10 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.elevationcutoff=0.0deg +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.freqstep=64 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.instrumentmodel=instrument +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.modelsources=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.ntimechunk=0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.othersources=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.skymodel=sky +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.subtractsources= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.targetsource= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.timestep=10 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.type=demixer +ObsSW.Observation.ObservationControl.PythonControl.DPPP.madflagger.applyautocorr=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.madflagger.blmax=1e30 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.madflagger.blmin=-1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.madflagger.correlations=[0,3] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.madflagger.count.path=- +ObsSW.Observation.ObservationControl.PythonControl.DPPP.madflagger.count.save=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.madflagger.freqwindow=1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.madflagger.threshold=1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.madflagger.timewindow=1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.madflagger.type=madflagger +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.autoweight=TRUE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.band=-1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.baseline= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.datacolumn=DATA +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.missingdata=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.nchan=nchan +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.orderms=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.sort=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.startchan=0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.useflag=TRUE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msout.overwrite=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msout.tilenchan=8 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msout.tilesize=1024 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msout.vdsdir=A +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msout.writefullresflag=T +ObsSW.Observation.ObservationControl.PythonControl.DPPP.phaseshift.phasecenter= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.phaseshift.type=phaseshift +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].abstime=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].amplmax=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].amplmin=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].azimuth=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].baseline= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].blmax=-1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].blmin=-1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].chan=[0..nchan/32-1,31*nchan/32..nchan-1] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].corrtype= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].count.path=- +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].count.save=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].elevation=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].expr= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].freqrange=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].imagmax=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].imagmin=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].lst=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].phasemax=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].phasemin=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].realmax=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].realmin=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].reltime=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].timeofday=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].timeslot=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].type=preflagger +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].uvmmax=-1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].uvmmin=-1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].abstime=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].amplmax=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].amplmin=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].azimuth=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].baseline= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].blmax=-1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].blmin=-1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].chan=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].corrtype=auto +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].count.path=- +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].count.save=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].elevation=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].expr= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].freqrange=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].imagmax=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].imagmin=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].lst=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].phasemax=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].phasemin=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].realmax=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].realmin=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].reltime=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].timeofday=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].timeslot=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].type=preflagger +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].uvmmax=-1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].uvmmin=-1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.showprogress=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.showtimings=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.steps=[preflagger[0],preflagger[1],aoflagger,demixer] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uselogger=T +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.count.path=- +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.count.save=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.phasecenter=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.type=uvwflagger +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.ulambdamax=1e15 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.ulambdamin=0.0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.ulambdarange=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.ummax=1e15 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.ummin=0.0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.umrange=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.uvlambdamax=1e15 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.uvlambdamin=0.0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.uvlambdarange=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.uvmmax=1e15 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.uvmmin=0.0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.uvmrange=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.vlambdamax=1e15 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.vlambdamin=0.0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.vlambdarange=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.vmmax=1e15 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.vmmin=0.0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.vmrange=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.wlambdamax=1e15 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.wlambdamin=0.0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.wlambdarange=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.wmmax=1e15 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.wmmin=0.0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uvwflagger.wmrange=[] +ObsSW.Observation.ObservationControl.PythonControl.GSM.assoc_theta= +ObsSW.Observation.ObservationControl.PythonControl.GSM.monetdb_hostname=lbd002 +ObsSW.Observation.ObservationControl.PythonControl.GSM.monetdb_name=gsm +ObsSW.Observation.ObservationControl.PythonControl.GSM.monetdb_password=msss +ObsSW.Observation.ObservationControl.PythonControl.GSM.monetdb_port=51000 +ObsSW.Observation.ObservationControl.PythonControl.GSM.monetdb_user=gsm +ObsSW.Observation.ObservationControl.PythonControl.Imaging.mask_patch_size=1 +ObsSW.Observation.ObservationControl.PythonControl.Imaging.maxbaseline=10000 +ObsSW.Observation.ObservationControl.PythonControl.Imaging.number_of_major_cycles=3 +ObsSW.Observation.ObservationControl.PythonControl.Imaging.slices_per_image=1 +ObsSW.Observation.ObservationControl.PythonControl.Imaging.subbands_per_image=1 +ObsSW.Observation.ObservationControl.PythonControl._hostname=CCU001 +ObsSW.Observation.ObservationControl.PythonControl.canCommunicate=false +ObsSW.Observation.ObservationControl.PythonControl.observationDirectory=/data/L${OBSID} +ObsSW.Observation.ObservationControl.PythonControl.pythonHost=lhn001.cep2.lofar +ObsSW.Observation.ObservationControl.PythonControl.pythonProgram=msss_calibrator_pipeline.py +ObsSW.Observation.ObservationControl.PythonControl.resultDirectory=lexar001:/data/${MSNUMBER}/output +ObsSW.Observation.ObservationControl.PythonControl.runtimeDirectory=/home/pipeline/runtime/${MSNUMBER}/run +ObsSW.Observation.ObservationControl.PythonControl.workingDirectory=/data/scratch/${MSNUMBER}/work +ObsSW.Observation.ObservationControl.PythonControl.PreProcessing.SkyModel=Ateam_LBA_CC +ObsSW.Observation.ObservationControl.PythonControl.PreProcessing.demix_always= +ObsSW.Observation.ObservationControl.PythonControl.PreProcessing.demix_if_needed= +ObsSW.Observation.ObservationControl._hostname=MCU001 +ObsSW.Observation.ObservationControl.heartbeatInterval=10 +ObsSW.Observation.Scheduler.contactEmail= +ObsSW.Observation.Scheduler.contactName= +ObsSW.Observation.Scheduler.contactPhone= +ObsSW.Observation.Scheduler.firstPossibleDay=0 +ObsSW.Observation.Scheduler.fixedDay=false +ObsSW.Observation.Scheduler.fixedTime=false +ObsSW.Observation.Scheduler.lastPossibleDay=0 +ObsSW.Observation.Scheduler.late=false +ObsSW.Observation.Scheduler.nightTimeWeightFactor=0 +ObsSW.Observation.Scheduler.predMaxTimeDif= +ObsSW.Observation.Scheduler.predMinTimeDif= +ObsSW.Observation.Scheduler.predecessors=[M131279] +ObsSW.Observation.Scheduler.priority=0.0 +ObsSW.Observation.Scheduler.reason= +ObsSW.Observation.Scheduler.referenceFrame=0 +ObsSW.Observation.Scheduler.reservation=0 +ObsSW.Observation.Scheduler.storageSelectionMode=1 +ObsSW.Observation.Scheduler.taskDuration=3600 +ObsSW.Observation.Scheduler.taskID=127 +ObsSW.Observation.Scheduler.taskName=Calibration M51 +ObsSW.Observation.Scheduler.taskType=0 +ObsSW.Observation.Scheduler.windowMaximumTime= +ObsSW.Observation.Scheduler.windowMinimumTime= +ObsSW.Observation.VirtualInstrument.imageNodeList=[] +ObsSW.Observation.VirtualInstrument.minimalNrStations=1 +ObsSW.Observation.VirtualInstrument.partitionList=["R00"] +ObsSW.Observation.VirtualInstrument.stationList=[] +ObsSW.Observation.VirtualInstrument.stationSet= +ObsSW.Observation.VirtualInstrument.storageCapacity=760 +ObsSW.Observation.VirtualInstrument.storageNodeList=[] +ObsSW.Observation.antennaArray=LBA +ObsSW.Observation.antennaSet=LBA_INNER +ObsSW.Observation.bandFilter=LBA_30_90 +ObsSW.Observation.channelWidth=762.939453125 +ObsSW.Observation.channelsPerSubband=64 +ObsSW.Observation.claimPeriod=10 +ObsSW.Observation.clockMode=<<Clock200 +ObsSW.Observation.existingAntennaFields=["LBA","HBA","HBA0","HBA1"] +ObsSW.Observation.existingStations=["CS001","CS002","CS003","CS004","CS005","CS006","CS007","CS011","CS013","CS017","CS021","CS024","CS026","CS028","CS030","CS031","CS101","CS103","CS201","CS301","CS302","CS401","CS501","RS106","RS205","RS208","RS306","RS307","RS406","RS503","DE601","DE602","DE603","DE604","DE605","FR606","UK608"] +ObsSW.Observation.longBaselines=false +ObsSW.Observation.nrAnaBeams=0 +ObsSW.Observation.nrBeamformers=0 +ObsSW.Observation.nrBeams=0 +ObsSW.Observation.nrPolarisations=2 +ObsSW.Observation.nrSlotsInFrame=61 +ObsSW.Observation.nrTBBSettings=0 +ObsSW.Observation.preparePeriod=10 +ObsSW.Observation.processSubtype=Calibration Pipeline +ObsSW.Observation.processType=Pipeline +ObsSW.Observation.receiverList=[] +ObsSW.Observation.referencePhaseCenter=[3826577.110, 461022.900, 5064892.758] +ObsSW.Observation.sampleClock=200 +ObsSW.Observation.samplesPerSecond=196608 +ObsSW.Observation.startTime=2012-08-31 13:35:00 +ObsSW.Observation.stopTime=2012-08-31 14:35:00 +ObsSW.Observation.strategy=MSSS calibrator pipeline +ObsSW.Observation.subbandWidth=195.3125 +ObsSW.Observation.topologyID=mom_msss_131277.1.P1 +_DPname=LOFAR_ObsSW_TempObs0050 +prefix=LOFAR. + "]]> + </config> + </msss_calibration_pipeline> + <msss_target_pipeline> + <pipeline_id>observation64406</pipeline_id> + <comments></comments> + <predecessors>observation64405</predecessors> + <inputs> + <Input_InstrumentModel> + <locations>ObsSW.Observation.DataProducts.Input_InstrumentModel.locations</locations> + <filenames>ObsSW.Observation.DataProducts.Input_InstrumentModel.filenames</filenames> + <skip>ObsSW.Observation.DataProducts.Input_InstrumentModel.skip</skip> + </Input_InstrumentModel> + <Input_correlated> + <locations>ObsSW.Observation.DataProducts.Input_Correlated.locations</locations> + <filenames>ObsSW.Observation.DataProducts.Input_Correlated.filenames</filenames> + <skip>ObsSW.Observation.DataProducts.Input_Correlated.skip</skip> + </Input_correlated> + </inputs> + <outputs> + <Output_Correlated> + <filenames>ObsSW.Observation.DataProducts.Output_Correlated.filenames</filenames> + <locations>ObsSW.Observation.DataProducts.Output_Correlated.locations</locations> + <skip>ObsSW.Observation.DataProducts.Output_Correlated.skip</skip> + </Output_Correlated> + </outputs> + <dpu_pipeline_config></dpu_pipeline_config> + <config> + <![CDATA[" +ObsSW.Observation.DataProducts.Input_Correlated.filenames=[L64372_SAP000_SB000_uv.MS,L64372_SAP000_SB001_uv.MS] +ObsSW.Observation.DataProducts.Input_Correlated.locations=[lce040:/data/scratch/klijn/target_pipeline,lce041:/data/scratch/klijn/target_pipeline] +ObsSW.Observation.DataProducts.Input_Correlated.skip=[0,0] +ObsSW.Observation.DataProducts.Input_InstrumentModel.filenames=[L64405_SAP000_SB000_inst.INST,L64405_SAP000_SB001_inst.INST] +ObsSW.Observation.DataProducts.Input_InstrumentModel.locations=[lce040:/data/scratch/klijn/target_pipeline,lce041:/data/scratch/klijn/target_pipeline] +ObsSW.Observation.DataProducts.Input_InstrumentModel.skip=[0,0] +# Again the output locations should be changed to a location you can write to +ObsSW.Observation.DataProducts.Output_Correlated.filenames=[L64406_SB000_uv.dppp.MS,L64406_SB001_uv.dppp.MS] +ObsSW.Observation.DataProducts.Output_Correlated.locations=[lce040:/data/scratch/droge/target_pipeline,lce041:/data/scratch/droge/target_pipeline] +ObsSW.Observation.DataProducts.Output_Correlated.skip=[0,0] +# +Clock160.channelWidth=610.3515625 +Clock160.samplesPerSecond=155648 +Clock160.subbandWidth=156.250 +Clock160.systemClock=160 +Clock200.channelWidth=762.939453125 +Clock200.samplesPerSecond=196608 +Clock200.subbandWidth=195.3125 +Clock200.systemClock=200 +ObsSW.Observation.Campaign.CO_I=Wise, Dr. Michael +ObsSW.Observation.Campaign.PI=Verhoef, Ir. Bastiaan +ObsSW.Observation.Campaign.contact=Verhoef, Ir. Bastiaan +ObsSW.Observation.Campaign.name=test-lofar +ObsSW.Observation.Campaign.title=test-lofar +ObsSW.Observation.DataProducts.Input_Beamformed.dirmask= +ObsSW.Observation.DataProducts.Input_Beamformed.enabled=false +ObsSW.Observation.DataProducts.Input_Beamformed.filenames=[] +ObsSW.Observation.DataProducts.Input_Beamformed.identifications=[] +ObsSW.Observation.DataProducts.Input_Beamformed.locations=[] +ObsSW.Observation.DataProducts.Input_Beamformed.mountpoints=[] +ObsSW.Observation.DataProducts.Input_Beamformed.namemask= +ObsSW.Observation.DataProducts.Input_Beamformed.skip=[] +ObsSW.Observation.DataProducts.Input_CoherentStokes.dirmask= +ObsSW.Observation.DataProducts.Input_CoherentStokes.enabled=false +ObsSW.Observation.DataProducts.Input_CoherentStokes.filenames=[] +ObsSW.Observation.DataProducts.Input_CoherentStokes.identifications=[] +ObsSW.Observation.DataProducts.Input_CoherentStokes.locations=[] +ObsSW.Observation.DataProducts.Input_CoherentStokes.mountpoints=[] +ObsSW.Observation.DataProducts.Input_CoherentStokes.namemask= +ObsSW.Observation.DataProducts.Input_CoherentStokes.skip=[] +ObsSW.Observation.DataProducts.Input_Correlated.dirmask=L${OBSID} +ObsSW.Observation.DataProducts.Input_Correlated.enabled=true +ObsSW.Observation.DataProducts.Input_IncoherentStokes.dirmask= +ObsSW.Observation.DataProducts.Input_IncoherentStokes.enabled=false +ObsSW.Observation.DataProducts.Input_IncoherentStokes.filenames=[] +ObsSW.Observation.DataProducts.Input_IncoherentStokes.identifications=[] +ObsSW.Observation.DataProducts.Input_IncoherentStokes.locations=[] +ObsSW.Observation.DataProducts.Input_IncoherentStokes.mountpoints=[] +ObsSW.Observation.DataProducts.Input_IncoherentStokes.namemask= +ObsSW.Observation.DataProducts.Input_IncoherentStokes.skip=[] +ObsSW.Observation.DataProducts.Input_InstrumentModel.dirmask=L${OBSID} +ObsSW.Observation.DataProducts.Input_InstrumentModel.enabled=true +ObsSW.Observation.DataProducts.Input_SkyImage.dirmask= +ObsSW.Observation.DataProducts.Input_SkyImage.enabled=false +ObsSW.Observation.DataProducts.Input_SkyImage.filenames=[] +ObsSW.Observation.DataProducts.Input_SkyImage.identifications=[] +ObsSW.Observation.DataProducts.Input_SkyImage.locations=[] +ObsSW.Observation.DataProducts.Input_SkyImage.mountpoints=[] +ObsSW.Observation.DataProducts.Input_SkyImage.namemask= +ObsSW.Observation.DataProducts.Input_SkyImage.skip=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Offset.angle1=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Offset.angle2=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Offset.coordType=RA +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Offset.equinox=J2000 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Pointing.angle1=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Pointing.angle2=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Pointing.coordType=RA +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.Pointing.equinox=J2000 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.SubArrayPointingIdentifier=MoM +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.beamNumber=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.centralFrequencies=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.channelWidth=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.dispersionMeasure=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.numberOfSubbands=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.CoherentStokesBeam.stationSubbands=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordSystAF0=ITRF2005 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordSystAF1=ITRF2005 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordXAF0=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordXAF1=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordYAF0=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordYAF1=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordZAF0=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.coordZAF1=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.name= +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.nameAF0=LBA +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.nameAF1=LBA +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.nrAntennaField=1 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.Station.stationType=Core +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.SubArrayPointingIdentifier=MoM +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.beamNumber=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.centralFrequencies=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.channelWidth=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.dispersionMeasure=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.numberOfSubbands=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.FlysEyeBeam.stationSubbands=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.SubArrayPointingIdentifier=MoM +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.beamNumber=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.centralFrequencies=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.channelWidth=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.dispersionMeasure=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.numberOfSubbands=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.IncoherentStokesBeam.stationSubbands=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.beamTypes=[] +ObsSW.Observation.DataProducts.Output_BeamFormed_.fileFormat=HDF5 +ObsSW.Observation.DataProducts.Output_BeamFormed_.filename= +ObsSW.Observation.DataProducts.Output_BeamFormed_.location= +ObsSW.Observation.DataProducts.Output_BeamFormed_.nrOfCoherentStokesBeams=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.nrOfFlysEyeBeams=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.nrOfIncoherentStokesBeams=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.percentageWritten=0 +ObsSW.Observation.DataProducts.Output_BeamFormed_.size=0 +ObsSW.Observation.DataProducts.Output_Beamformed.archived=false +ObsSW.Observation.DataProducts.Output_Beamformed.deleted=false +ObsSW.Observation.DataProducts.Output_Beamformed.dirmask= +ObsSW.Observation.DataProducts.Output_Beamformed.enabled=false +ObsSW.Observation.DataProducts.Output_Beamformed.filenames=[] +ObsSW.Observation.DataProducts.Output_Beamformed.identifications=[] +ObsSW.Observation.DataProducts.Output_Beamformed.locations=[] +ObsSW.Observation.DataProducts.Output_Beamformed.mountpoints=[] +ObsSW.Observation.DataProducts.Output_Beamformed.namemask= +ObsSW.Observation.DataProducts.Output_Beamformed.percentageWritten=[] +ObsSW.Observation.DataProducts.Output_Beamformed.retentiontime=14 +ObsSW.Observation.DataProducts.Output_Beamformed.skip=[] +ObsSW.Observation.DataProducts.Output_CoherentStokes.archived=false +ObsSW.Observation.DataProducts.Output_CoherentStokes.deleted=false +ObsSW.Observation.DataProducts.Output_CoherentStokes.dirmask= +ObsSW.Observation.DataProducts.Output_CoherentStokes.enabled=false +ObsSW.Observation.DataProducts.Output_CoherentStokes.filenames=[] +ObsSW.Observation.DataProducts.Output_CoherentStokes.identifications=[] +ObsSW.Observation.DataProducts.Output_CoherentStokes.locations=[] +ObsSW.Observation.DataProducts.Output_CoherentStokes.mountpoints=[] +ObsSW.Observation.DataProducts.Output_CoherentStokes.namemask= +ObsSW.Observation.DataProducts.Output_CoherentStokes.percentageWritten=[] +ObsSW.Observation.DataProducts.Output_CoherentStokes.retentiontime=14 +ObsSW.Observation.DataProducts.Output_CoherentStokes.skip=[] +ObsSW.Observation.DataProducts.Output_Correlated.archived=false +ObsSW.Observation.DataProducts.Output_Correlated.deleted=false +ObsSW.Observation.DataProducts.Output_Correlated.dirmask=L${OBSID} +ObsSW.Observation.DataProducts.Output_Correlated.enabled=true +ObsSW.Observation.DataProducts.Output_Correlated_[0].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[0].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[0].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[0].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[0].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[0].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[0].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[0].location= +ObsSW.Observation.DataProducts.Output_Correlated_[0].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[0].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[0].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[0].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[0].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[10].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[10].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[10].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[10].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[10].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[10].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[10].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[10].location= +ObsSW.Observation.DataProducts.Output_Correlated_[10].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[10].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[10].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[10].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[10].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[11].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[11].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[11].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[11].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[11].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[11].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[11].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[11].location= +ObsSW.Observation.DataProducts.Output_Correlated_[11].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[11].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[11].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[11].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[11].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[12].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[12].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[12].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[12].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[12].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[12].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[12].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[12].location= +ObsSW.Observation.DataProducts.Output_Correlated_[12].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[12].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[12].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[12].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[12].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[13].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[13].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[13].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[13].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[13].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[13].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[13].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[13].location= +ObsSW.Observation.DataProducts.Output_Correlated_[13].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[13].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[13].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[13].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[13].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[14].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[14].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[14].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[14].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[14].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[14].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[14].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[14].location= +ObsSW.Observation.DataProducts.Output_Correlated_[14].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[14].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[14].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[14].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[14].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[15].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[15].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[15].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[15].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[15].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[15].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[15].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[15].location= +ObsSW.Observation.DataProducts.Output_Correlated_[15].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[15].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[15].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[15].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[15].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[16].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[16].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[16].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[16].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[16].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[16].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[16].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[16].location= +ObsSW.Observation.DataProducts.Output_Correlated_[16].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[16].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[16].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[16].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[16].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[17].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[17].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[17].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[17].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[17].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[17].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[17].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[17].location= +ObsSW.Observation.DataProducts.Output_Correlated_[17].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[17].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[17].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[17].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[17].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[18].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[18].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[18].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[18].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[18].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[18].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[18].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[18].location= +ObsSW.Observation.DataProducts.Output_Correlated_[18].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[18].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[18].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[18].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[18].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[19].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[19].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[19].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[19].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[19].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[19].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[19].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[19].location= +ObsSW.Observation.DataProducts.Output_Correlated_[19].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[19].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[19].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[19].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[19].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[1].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[1].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[1].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[1].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[1].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[1].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[1].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[1].location= +ObsSW.Observation.DataProducts.Output_Correlated_[1].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[1].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[1].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[1].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[1].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[20].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[20].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[20].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[20].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[20].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[20].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[20].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[20].location= +ObsSW.Observation.DataProducts.Output_Correlated_[20].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[20].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[20].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[20].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[20].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[21].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[21].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[21].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[21].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[21].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[21].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[21].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[21].location= +ObsSW.Observation.DataProducts.Output_Correlated_[21].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[21].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[21].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[21].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[21].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[22].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[22].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[22].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[22].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[22].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[22].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[22].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[22].location= +ObsSW.Observation.DataProducts.Output_Correlated_[22].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[22].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[22].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[22].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[22].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[23].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[23].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[23].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[23].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[23].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[23].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[23].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[23].location= +ObsSW.Observation.DataProducts.Output_Correlated_[23].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[23].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[23].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[23].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[23].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[24].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[24].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[24].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[24].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[24].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[24].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[24].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[24].location= +ObsSW.Observation.DataProducts.Output_Correlated_[24].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[24].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[24].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[24].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[24].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[25].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[25].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[25].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[25].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[25].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[25].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[25].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[25].location= +ObsSW.Observation.DataProducts.Output_Correlated_[25].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[25].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[25].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[25].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[25].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[26].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[26].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[26].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[26].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[26].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[26].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[26].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[26].location= +ObsSW.Observation.DataProducts.Output_Correlated_[26].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[26].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[26].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[26].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[26].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[27].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[27].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[27].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[27].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[27].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[27].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[27].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[27].location= +ObsSW.Observation.DataProducts.Output_Correlated_[27].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[27].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[27].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[27].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[27].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[28].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[28].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[28].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[28].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[28].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[28].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[28].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[28].location= +ObsSW.Observation.DataProducts.Output_Correlated_[28].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[28].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[28].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[28].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[28].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[29].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[29].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[29].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[29].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[29].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[29].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[29].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[29].location= +ObsSW.Observation.DataProducts.Output_Correlated_[29].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[29].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[29].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[29].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[29].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[2].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[2].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[2].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[2].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[2].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[2].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[2].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[2].location= +ObsSW.Observation.DataProducts.Output_Correlated_[2].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[2].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[2].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[2].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[2].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[30].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[30].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[30].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[30].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[30].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[30].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[30].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[30].location= +ObsSW.Observation.DataProducts.Output_Correlated_[30].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[30].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[30].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[30].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[30].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[31].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[31].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[31].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[31].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[31].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[31].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[31].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[31].location= +ObsSW.Observation.DataProducts.Output_Correlated_[31].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[31].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[31].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[31].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[31].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[32].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[32].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[32].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[32].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[32].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[32].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[32].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[32].location= +ObsSW.Observation.DataProducts.Output_Correlated_[32].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[32].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[32].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[32].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[32].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[33].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[33].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[33].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[33].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[33].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[33].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[33].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[33].location= +ObsSW.Observation.DataProducts.Output_Correlated_[33].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[33].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[33].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[33].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[33].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[34].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[34].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[34].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[34].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[34].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[34].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[34].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[34].location= +ObsSW.Observation.DataProducts.Output_Correlated_[34].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[34].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[34].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[34].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[34].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[35].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[35].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[35].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[35].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[35].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[35].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[35].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[35].location= +ObsSW.Observation.DataProducts.Output_Correlated_[35].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[35].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[35].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[35].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[35].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[36].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[36].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[36].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[36].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[36].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[36].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[36].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[36].location= +ObsSW.Observation.DataProducts.Output_Correlated_[36].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[36].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[36].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[36].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[36].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[37].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[37].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[37].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[37].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[37].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[37].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[37].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[37].location= +ObsSW.Observation.DataProducts.Output_Correlated_[37].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[37].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[37].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[37].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[37].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[38].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[38].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[38].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[38].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[38].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[38].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[38].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[38].location= +ObsSW.Observation.DataProducts.Output_Correlated_[38].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[38].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[38].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[38].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[38].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[39].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[39].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[39].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[39].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[39].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[39].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[39].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[39].location= +ObsSW.Observation.DataProducts.Output_Correlated_[39].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[39].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[39].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[39].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[39].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[3].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[3].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[3].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[3].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[3].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[3].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[3].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[3].location= +ObsSW.Observation.DataProducts.Output_Correlated_[3].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[3].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[3].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[3].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[3].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[40].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[40].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[40].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[40].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[40].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[40].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[40].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[40].location= +ObsSW.Observation.DataProducts.Output_Correlated_[40].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[40].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[40].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[40].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[40].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[41].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[41].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[41].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[41].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[41].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[41].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[41].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[41].location= +ObsSW.Observation.DataProducts.Output_Correlated_[41].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[41].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[41].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[41].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[41].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[42].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[42].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[42].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[42].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[42].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[42].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[42].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[42].location= +ObsSW.Observation.DataProducts.Output_Correlated_[42].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[42].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[42].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[42].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[42].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[43].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[43].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[43].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[43].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[43].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[43].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[43].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[43].location= +ObsSW.Observation.DataProducts.Output_Correlated_[43].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[43].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[43].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[43].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[43].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[44].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[44].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[44].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[44].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[44].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[44].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[44].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[44].location= +ObsSW.Observation.DataProducts.Output_Correlated_[44].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[44].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[44].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[44].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[44].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[45].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[45].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[45].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[45].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[45].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[45].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[45].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[45].location= +ObsSW.Observation.DataProducts.Output_Correlated_[45].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[45].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[45].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[45].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[45].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[46].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[46].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[46].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[46].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[46].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[46].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[46].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[46].location= +ObsSW.Observation.DataProducts.Output_Correlated_[46].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[46].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[46].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[46].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[46].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[47].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[47].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[47].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[47].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[47].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[47].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[47].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[47].location= +ObsSW.Observation.DataProducts.Output_Correlated_[47].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[47].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[47].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[47].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[47].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[48].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[48].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[48].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[48].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[48].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[48].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[48].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[48].location= +ObsSW.Observation.DataProducts.Output_Correlated_[48].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[48].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[48].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[48].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[48].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[49].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[49].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[49].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[49].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[49].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[49].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[49].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[49].location= +ObsSW.Observation.DataProducts.Output_Correlated_[49].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[49].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[49].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[49].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[49].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[4].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[4].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[4].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[4].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[4].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[4].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[4].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[4].location= +ObsSW.Observation.DataProducts.Output_Correlated_[4].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[4].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[4].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[4].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[4].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[50].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[50].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[50].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[50].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[50].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[50].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[50].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[50].location= +ObsSW.Observation.DataProducts.Output_Correlated_[50].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[50].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[50].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[50].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[50].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[51].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[51].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[51].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[51].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[51].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[51].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[51].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[51].location= +ObsSW.Observation.DataProducts.Output_Correlated_[51].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[51].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[51].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[51].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[51].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[52].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[52].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[52].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[52].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[52].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[52].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[52].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[52].location= +ObsSW.Observation.DataProducts.Output_Correlated_[52].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[52].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[52].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[52].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[52].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[53].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[53].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[53].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[53].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[53].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[53].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[53].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[53].location= +ObsSW.Observation.DataProducts.Output_Correlated_[53].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[53].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[53].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[53].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[53].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[54].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[54].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[54].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[54].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[54].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[54].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[54].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[54].location= +ObsSW.Observation.DataProducts.Output_Correlated_[54].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[54].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[54].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[54].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[54].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[55].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[55].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[55].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[55].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[55].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[55].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[55].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[55].location= +ObsSW.Observation.DataProducts.Output_Correlated_[55].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[55].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[55].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[55].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[55].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[56].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[56].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[56].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[56].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[56].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[56].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[56].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[56].location= +ObsSW.Observation.DataProducts.Output_Correlated_[56].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[56].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[56].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[56].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[56].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[57].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[57].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[57].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[57].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[57].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[57].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[57].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[57].location= +ObsSW.Observation.DataProducts.Output_Correlated_[57].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[57].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[57].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[57].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[57].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[58].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[58].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[58].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[58].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[58].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[58].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[58].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[58].location= +ObsSW.Observation.DataProducts.Output_Correlated_[58].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[58].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[58].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[58].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[58].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[59].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[59].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[59].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[59].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[59].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[59].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[59].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[59].location= +ObsSW.Observation.DataProducts.Output_Correlated_[59].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[59].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[59].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[59].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[59].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[5].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[5].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[5].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[5].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[5].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[5].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[5].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[5].location= +ObsSW.Observation.DataProducts.Output_Correlated_[5].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[5].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[5].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[5].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[5].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[60].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[60].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[60].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[60].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[60].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[60].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[60].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[60].location= +ObsSW.Observation.DataProducts.Output_Correlated_[60].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[60].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[60].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[60].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[60].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[61].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[61].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[61].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[61].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[61].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[61].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[61].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[61].location= +ObsSW.Observation.DataProducts.Output_Correlated_[61].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[61].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[61].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[61].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[61].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[62].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[62].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[62].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[62].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[62].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[62].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[62].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[62].location= +ObsSW.Observation.DataProducts.Output_Correlated_[62].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[62].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[62].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[62].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[62].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[63].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[63].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[63].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[63].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[63].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[63].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[63].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[63].location= +ObsSW.Observation.DataProducts.Output_Correlated_[63].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[63].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[63].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[63].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[63].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[64].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[64].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[64].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[64].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[64].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[64].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[64].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[64].location= +ObsSW.Observation.DataProducts.Output_Correlated_[64].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[64].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[64].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[64].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[64].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[65].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[65].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[65].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[65].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[65].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[65].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[65].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[65].location= +ObsSW.Observation.DataProducts.Output_Correlated_[65].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[65].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[65].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[65].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[65].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[66].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[66].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[66].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[66].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[66].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[66].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[66].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[66].location= +ObsSW.Observation.DataProducts.Output_Correlated_[66].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[66].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[66].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[66].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[66].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[67].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[67].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[67].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[67].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[67].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[67].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[67].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[67].location= +ObsSW.Observation.DataProducts.Output_Correlated_[67].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[67].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[67].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[67].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[67].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[68].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[68].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[68].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[68].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[68].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[68].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[68].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[68].location= +ObsSW.Observation.DataProducts.Output_Correlated_[68].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[68].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[68].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[68].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[68].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[69].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[69].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[69].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[69].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[69].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[69].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[69].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[69].location= +ObsSW.Observation.DataProducts.Output_Correlated_[69].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[69].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[69].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[69].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[69].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[6].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[6].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[6].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[6].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[6].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[6].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[6].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[6].location= +ObsSW.Observation.DataProducts.Output_Correlated_[6].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[6].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[6].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[6].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[6].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[70].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[70].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[70].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[70].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[70].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[70].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[70].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[70].location= +ObsSW.Observation.DataProducts.Output_Correlated_[70].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[70].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[70].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[70].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[70].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[71].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[71].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[71].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[71].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[71].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[71].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[71].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[71].location= +ObsSW.Observation.DataProducts.Output_Correlated_[71].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[71].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[71].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[71].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[71].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[72].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[72].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[72].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[72].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[72].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[72].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[72].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[72].location= +ObsSW.Observation.DataProducts.Output_Correlated_[72].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[72].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[72].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[72].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[72].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[73].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[73].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[73].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[73].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[73].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[73].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[73].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[73].location= +ObsSW.Observation.DataProducts.Output_Correlated_[73].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[73].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[73].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[73].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[73].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[74].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[74].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[74].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[74].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[74].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[74].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[74].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[74].location= +ObsSW.Observation.DataProducts.Output_Correlated_[74].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[74].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[74].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[74].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[74].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[75].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[75].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[75].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[75].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[75].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[75].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[75].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[75].location= +ObsSW.Observation.DataProducts.Output_Correlated_[75].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[75].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[75].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[75].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[75].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[76].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[76].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[76].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[76].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[76].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[76].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[76].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[76].location= +ObsSW.Observation.DataProducts.Output_Correlated_[76].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[76].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[76].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[76].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[76].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[77].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[77].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[77].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[77].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[77].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[77].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[77].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[77].location= +ObsSW.Observation.DataProducts.Output_Correlated_[77].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[77].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[77].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[77].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[77].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[78].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[78].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[78].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[78].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[78].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[78].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[78].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[78].location= +ObsSW.Observation.DataProducts.Output_Correlated_[78].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[78].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[78].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[78].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[78].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[79].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[79].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[79].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[79].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[79].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[79].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[79].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[79].location= +ObsSW.Observation.DataProducts.Output_Correlated_[79].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[79].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[79].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[79].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[79].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[7].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[7].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[7].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[7].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[7].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[7].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[7].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[7].location= +ObsSW.Observation.DataProducts.Output_Correlated_[7].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[7].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[7].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[7].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[7].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[8].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[8].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[8].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[8].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[8].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[8].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[8].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[8].location= +ObsSW.Observation.DataProducts.Output_Correlated_[8].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[8].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[8].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[8].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[8].subband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[9].centralFrequency=0 +ObsSW.Observation.DataProducts.Output_Correlated_[9].channelWidth=0 +ObsSW.Observation.DataProducts.Output_Correlated_[9].channelsPerSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[9].duration=0 +ObsSW.Observation.DataProducts.Output_Correlated_[9].fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_Correlated_[9].filename= +ObsSW.Observation.DataProducts.Output_Correlated_[9].integrationInterval=0 +ObsSW.Observation.DataProducts.Output_Correlated_[9].location= +ObsSW.Observation.DataProducts.Output_Correlated_[9].percentageWritten=0 +ObsSW.Observation.DataProducts.Output_Correlated_[9].size=0 +ObsSW.Observation.DataProducts.Output_Correlated_[9].startTime= +ObsSW.Observation.DataProducts.Output_Correlated_[9].stationSubband=0 +ObsSW.Observation.DataProducts.Output_Correlated_[9].subband=0 +ObsSW.Observation.DataProducts.Output_IncoherentStokes.archived=false +ObsSW.Observation.DataProducts.Output_IncoherentStokes.deleted=false +ObsSW.Observation.DataProducts.Output_IncoherentStokes.dirmask= +ObsSW.Observation.DataProducts.Output_IncoherentStokes.enabled=false +ObsSW.Observation.DataProducts.Output_IncoherentStokes.filenames=[] +ObsSW.Observation.DataProducts.Output_IncoherentStokes.identifications=[] +ObsSW.Observation.DataProducts.Output_IncoherentStokes.locations=[] +ObsSW.Observation.DataProducts.Output_IncoherentStokes.mountpoints=[] +ObsSW.Observation.DataProducts.Output_IncoherentStokes.namemask= +ObsSW.Observation.DataProducts.Output_IncoherentStokes.percentageWritten=[] +ObsSW.Observation.DataProducts.Output_IncoherentStokes.retentiontime=14 +ObsSW.Observation.DataProducts.Output_IncoherentStokes.skip=[] +ObsSW.Observation.DataProducts.Output_InstrumentModel.archived=false +ObsSW.Observation.DataProducts.Output_InstrumentModel.deleted=false +ObsSW.Observation.DataProducts.Output_InstrumentModel.dirmask= +ObsSW.Observation.DataProducts.Output_InstrumentModel.enabled=false +ObsSW.Observation.DataProducts.Output_InstrumentModel.filenames=[] +ObsSW.Observation.DataProducts.Output_InstrumentModel.identifications=[] +ObsSW.Observation.DataProducts.Output_InstrumentModel.locations=[] +ObsSW.Observation.DataProducts.Output_InstrumentModel.mountpoints=[] +ObsSW.Observation.DataProducts.Output_InstrumentModel.namemask= +ObsSW.Observation.DataProducts.Output_InstrumentModel.percentageWritten=[] +ObsSW.Observation.DataProducts.Output_InstrumentModel.retentiontime=14 +ObsSW.Observation.DataProducts.Output_InstrumentModel.skip=[] +ObsSW.Observation.DataProducts.Output_InstrumentModel_.fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_InstrumentModel_.filename= +ObsSW.Observation.DataProducts.Output_InstrumentModel_.location= +ObsSW.Observation.DataProducts.Output_InstrumentModel_.percentageWritten=0 +ObsSW.Observation.DataProducts.Output_InstrumentModel_.size=0 +ObsSW.Observation.DataProducts.Output_SkyImage.archived=false +ObsSW.Observation.DataProducts.Output_SkyImage.deleted=false +ObsSW.Observation.DataProducts.Output_SkyImage.dirmask= +ObsSW.Observation.DataProducts.Output_SkyImage.enabled=false +ObsSW.Observation.DataProducts.Output_SkyImage.filenames=[] +ObsSW.Observation.DataProducts.Output_SkyImage.identifications=[] +ObsSW.Observation.DataProducts.Output_SkyImage.locations=[] +ObsSW.Observation.DataProducts.Output_SkyImage.mountpoints=[] +ObsSW.Observation.DataProducts.Output_SkyImage.namemask= +ObsSW.Observation.DataProducts.Output_SkyImage.percentageWritten=[] +ObsSW.Observation.DataProducts.Output_SkyImage.retentiontime=14 +ObsSW.Observation.DataProducts.Output_SkyImage.skip=[] +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.DirectionLinearAxis.increment=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.DirectionLinearAxis.length=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.DirectionLinearAxis.name= +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.DirectionLinearAxis.referencePixel=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.DirectionLinearAxis.referenceValue=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.DirectionLinearAxis.units= +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.PC0_0=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.PC0_1=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.PC1_0=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.PC1_1=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.equinox= +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.latitudePole=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.longitudePole=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.nrOfDirectionLinearAxes=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.projection= +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.projectionParameters=[] +ObsSW.Observation.DataProducts.Output_SkyImage_.DirectionCoordinate.raDecSystem=ICRS +ObsSW.Observation.DataProducts.Output_SkyImage_.Pointing.angle1=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.Pointing.angle2=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.Pointing.coordType=RA +ObsSW.Observation.DataProducts.Output_SkyImage_.Pointing.equinox=J2000 +ObsSW.Observation.DataProducts.Output_SkyImage_.PolarizationCoordinate.PolarizationTabularAxis.length=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.PolarizationCoordinate.PolarizationTabularAxis.name= +ObsSW.Observation.DataProducts.Output_SkyImage_.PolarizationCoordinate.PolarizationTabularAxis.units= +ObsSW.Observation.DataProducts.Output_SkyImage_.PolarizationCoordinate.polarizationType=["XX","XY","YX","YY"] +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralLinearAxis.increment=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralLinearAxis.length=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralLinearAxis.name= +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralLinearAxis.referencePixel=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralLinearAxis.referenceValue=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralLinearAxis.units= +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralTabularAxis.length=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralTabularAxis.name= +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.SpectralTabularAxis.units= +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.spectralAxisType=Linear +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.spectralQuantityType=Frequency +ObsSW.Observation.DataProducts.Output_SkyImage_.SpectralCoordinate.spectralQuantityValue=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.fileFormat=AIPS +ObsSW.Observation.DataProducts.Output_SkyImage_.filename= +ObsSW.Observation.DataProducts.Output_SkyImage_.location= +ObsSW.Observation.DataProducts.Output_SkyImage_.locationFrame=GEOCENTER +ObsSW.Observation.DataProducts.Output_SkyImage_.nrOfDirectionCoordinates=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.nrOfPolarizationCoordinates=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.nrOfSpectralCoordinates=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.numberOfAxes=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.percentageWritten=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.size=0 +ObsSW.Observation.DataProducts.Output_SkyImage_.timeFrame= +ObsSW.Observation.DataProducts.nrOfOutput_BeamFormed_=0 +ObsSW.Observation.DataProducts.nrOfOutput_Correlated_=80 +ObsSW.Observation.DataProducts.nrOfOutput_InstrumentModels_=0 +ObsSW.Observation.DataProducts.nrOfOutput_SkyImages_=0 +ObsSW.Observation.KSPType=surveys +ObsSW.Observation.ObservationControl.PythonControl.AWimager.PBCut=1e-2 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.PsfImage= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.RefFreq= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.RowBlock=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.StepApplyElement=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.UseEJones=TRUE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.UseLIG=FALSE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.UseMasks=TRUE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.applyBeam=TRUE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.applyIonosphere=FALSE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.autoweight=FALSE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.cachesize=512 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.cellsize=1arcsec +ObsSW.Observation.ObservationControl.PythonControl.AWimager.chanmode=channel +ObsSW.Observation.ObservationControl.PythonControl.AWimager.chanstart=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.chanstep=1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.constrainflux=FALSE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.cyclefactor=1.5 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.cyclespeedup=-1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.data=DATA +ObsSW.Observation.ObservationControl.PythonControl.AWimager.displayprogress=FALSE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.field=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.filter= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.fits=no +ObsSW.Observation.ObservationControl.PythonControl.AWimager.fixed=FALSE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.gain=0.1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.hdf5=no +ObsSW.Observation.ObservationControl.PythonControl.AWimager.image= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.img_chanstart=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.img_chanstep=1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.img_nchan=1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.mask= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.maskblc=[0,0] +ObsSW.Observation.ObservationControl.PythonControl.AWimager.masktrc=[] +ObsSW.Observation.ObservationControl.PythonControl.AWimager.maskvalue=1.0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.maxsupport=1024 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.mode=mfs +ObsSW.Observation.ObservationControl.PythonControl.AWimager.model= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.ms= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.muellerdegrid=all +ObsSW.Observation.ObservationControl.PythonControl.AWimager.muellergrid=all +ObsSW.Observation.ObservationControl.PythonControl.AWimager.nchan=1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.nfacets=1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.niter=1000 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.noise=1.0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.npix=256 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.nscales=5 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.nterms=1 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.operation=image +ObsSW.Observation.ObservationControl.PythonControl.AWimager.oversample=8 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.padding=1.0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.phasecenter= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.prefervelocity=TRUE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.prior= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.psf= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.residual= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.restored= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.robust=0.0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.select= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.sigma=0.001Jy +ObsSW.Observation.ObservationControl.PythonControl.AWimager.splitbeam=TRUE +ObsSW.Observation.ObservationControl.PythonControl.AWimager.spwid=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.stokes=IQUV +ObsSW.Observation.ObservationControl.PythonControl.AWimager.targetflux=1.0Jy +ObsSW.Observation.ObservationControl.PythonControl.AWimager.threshold=0Jy +ObsSW.Observation.ObservationControl.PythonControl.AWimager.timewindow=300.0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.uservector=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.uvdist= +ObsSW.Observation.ObservationControl.PythonControl.AWimager.verbose=0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.weight=briggs +ObsSW.Observation.ObservationControl.PythonControl.AWimager.wmax=500.0 +ObsSW.Observation.ObservationControl.PythonControl.AWimager.wprojplanes=0 +ObsSW.Observation.ObservationControl.PythonControl.BBS.BBDB.Host=ldb001 +ObsSW.Observation.ObservationControl.PythonControl.BBS.BBDB.Name=lofarsys +ObsSW.Observation.ObservationControl.PythonControl.BBS.BBDB.Password= +ObsSW.Observation.ObservationControl.PythonControl.BBS.BBDB.Port=5432 +ObsSW.Observation.ObservationControl.PythonControl.BBS.BBDB.User=postgres +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Baselines=*& +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Correlations=[] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Bandpass.Enable=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Beam.ConjugateAF=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Beam.Element.Path=${LOFARROOT}/share +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Beam.Enable=T +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Beam.Mode=DEFAULT +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Cache.Enable=T +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.DirectionalGain.Enable=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Flagger.Enable=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Flagger.Threshold=0 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Gain.Enable=T +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Ionosphere.Degree=0 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Ionosphere.Enable=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Ionosphere.Type= +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Phasors.Enable=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Model.Sources=[] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Operation=CORRECT +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Output.Column=CORRECTED_DATA +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Output.WriteCovariance=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.DefaultBBSStep[0].Output.WriteFlags=F +ObsSW.Observation.ObservationControl.PythonControl.BBS.Step.nrOfDefaultBBSStep=0 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Strategy.Baselines=*& +ObsSW.Observation.ObservationControl.PythonControl.BBS.Strategy.ChunkSize=100 +ObsSW.Observation.ObservationControl.PythonControl.BBS.Strategy.Correlations=[] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Strategy.InputColumn=DATA +ObsSW.Observation.ObservationControl.PythonControl.BBS.Strategy.Steps=["DefaultBBSStep[0]"] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Strategy.TimeRange=[] +ObsSW.Observation.ObservationControl.PythonControl.BBS.Strategy.UseSolver=F +ObsSW.Observation.ObservationControl.PythonControl.BDSM.advanced_opts=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.atrous_do=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.clobber=true +ObsSW.Observation.ObservationControl.PythonControl.BDSM.flagging_opts=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.interactive=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.mean_map=default +ObsSW.Observation.ObservationControl.PythonControl.BDSM.multichan_opts=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.output_opts=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.polarisation_do=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.psf_vary_do=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.quiet=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.rms_box=(15.0,9.0) +ObsSW.Observation.ObservationControl.PythonControl.BDSM.rms_map=true +ObsSW.Observation.ObservationControl.PythonControl.BDSM.shapelet_do=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.spectralindex_do=false +ObsSW.Observation.ObservationControl.PythonControl.BDSM.thresh=hard +ObsSW.Observation.ObservationControl.PythonControl.BDSM.thresh_isl=3.0 +ObsSW.Observation.ObservationControl.PythonControl.BDSM.thresh_pix=5.0 +ObsSW.Observation.ObservationControl.PythonControl.Calibration.CalibratorSource=3C295 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.autocorr=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.count.path=- +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.count.save=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.keepstatistics=T +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.memorymax=0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.memoryperc=50 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.overlapmax=0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.overlapperc=0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.pedantic=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.pulsar=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.timewindow=0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.aoflagger.type=aoflagger +ObsSW.Observation.ObservationControl.PythonControl.DPPP.checkparset=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.Solve.Options.BalancedEqs=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.Solve.Options.ColFactor=1e-9 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.Solve.Options.EpsDerivative=1e-9 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.Solve.Options.EpsValue=1e-9 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.Solve.Options.LMFactor=1.0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.Solve.Options.MaxIter=0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.Solve.Options.UseSVD=T +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.demixfreqstep=64 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.demixtimestep=10 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.elevationcutoff=0.0deg +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.freqstep=64 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.instrumentmodel=instrument +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.modelsources=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.ntimechunk=0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.othersources=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.skymodel=sky +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.subtractsources= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.targetsource= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.timestep=10 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.demixer.type=demixer +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.autoweight=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.band=-1 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.baseline= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.datacolumn=DATA +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.missingdata=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.nchan=nchan +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.orderms=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.sort=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.startchan=0 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msin.useflag=TRUE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msout.overwrite=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msout.tilenchan=8 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msout.tilesize=1024 +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msout.vdsdir=A +ObsSW.Observation.ObservationControl.PythonControl.DPPP.msout.writefullresflag=T +ObsSW.Observation.ObservationControl.PythonControl.DPPP.phaseshift.phasecenter= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.phaseshift.type=phaseshift +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].abstime=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].azimuth=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].baseline= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].chan=[0..nchan/32-1,31*nchan/32..nchan-1] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].corrtype= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].count.path=- +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].count.save=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].elevation=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].expr= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].freqrange=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].lst=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].reltime=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].timeofday=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].timeslot=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[0].type=preflagger +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].abstime=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].azimuth=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].baseline= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].chan=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].corrtype=auto +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].count.path=- +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].count.save=FALSE +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].elevation=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].expr= +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].freqrange=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].lst=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].reltime=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].timeofday=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].timeslot=[] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.preflagger[1].type=preflagger +ObsSW.Observation.ObservationControl.PythonControl.DPPP.showprogress=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.showtimings=F +ObsSW.Observation.ObservationControl.PythonControl.DPPP.steps=[preflagger[0],preflagger[1],aoflagger,demixer] +ObsSW.Observation.ObservationControl.PythonControl.DPPP.uselogger=T +ObsSW.Observation.ObservationControl.PythonControl.GSM.assoc_theta= +ObsSW.Observation.ObservationControl.PythonControl.GSM.monetdb_hostname=lbd002 +ObsSW.Observation.ObservationControl.PythonControl.GSM.monetdb_name=gsm +ObsSW.Observation.ObservationControl.PythonControl.GSM.monetdb_password=msss +ObsSW.Observation.ObservationControl.PythonControl.GSM.monetdb_port=51000 +ObsSW.Observation.ObservationControl.PythonControl.GSM.monetdb_user=gsm +ObsSW.Observation.ObservationControl.PythonControl.Imaging.mask_patch_size=1 +ObsSW.Observation.ObservationControl.PythonControl.Imaging.maxbaseline=10000 +ObsSW.Observation.ObservationControl.PythonControl.Imaging.number_of_major_cycles=3 +ObsSW.Observation.ObservationControl.PythonControl.Imaging.slices_per_image=1 +ObsSW.Observation.ObservationControl.PythonControl.Imaging.subbands_per_image=1 +ObsSW.Observation.ObservationControl.PythonControl.PreProcessing.SkyModel=Ateam_LBA_CC +ObsSW.Observation.ObservationControl.PythonControl.PreProcessing.demix_always=[CasA,CygA] +ObsSW.Observation.ObservationControl.PythonControl.PreProcessing.demix_if_needed=[] +ObsSW.Observation.ObservationControl.PythonControl._hostname=CCU001 +ObsSW.Observation.ObservationControl.PythonControl.canCommunicate=false +ObsSW.Observation.ObservationControl.PythonControl.observationDirectory=/data/L${OBSID} +ObsSW.Observation.ObservationControl.PythonControl.pythonHost=lhn001.cep2.lofar +ObsSW.Observation.ObservationControl.PythonControl.pythonProgram=msss_target_pipeline.py +ObsSW.Observation.ObservationControl.PythonControl.resultDirectory=lexar001:/data/${MSNUMBER}/output +ObsSW.Observation.ObservationControl.PythonControl.runtimeDirectory=/home/pipeline/runtime/${MSNUMBER}/run +ObsSW.Observation.ObservationControl.PythonControl.workingDirectory=/data/scratch/${MSNUMBER}/work +ObsSW.Observation.ObservationControl._hostname=MCU001 +ObsSW.Observation.ObservationControl.heartbeatInterval=10 +ObsSW.Observation.Scheduler.contactEmail= +ObsSW.Observation.Scheduler.contactName= +ObsSW.Observation.Scheduler.contactPhone= +ObsSW.Observation.Scheduler.firstPossibleDay=0 +ObsSW.Observation.Scheduler.fixedDay=false +ObsSW.Observation.Scheduler.fixedTime=false +ObsSW.Observation.Scheduler.lastPossibleDay=0 +ObsSW.Observation.Scheduler.late=false +ObsSW.Observation.Scheduler.nightTimeWeightFactor=0 +ObsSW.Observation.Scheduler.predMaxTimeDif= +ObsSW.Observation.Scheduler.predMinTimeDif= +ObsSW.Observation.Scheduler.predecessors=[M131281,M131282] +ObsSW.Observation.Scheduler.priority=0.0 +ObsSW.Observation.Scheduler.reason= +ObsSW.Observation.Scheduler.referenceFrame=0 +ObsSW.Observation.Scheduler.reservation=0 +ObsSW.Observation.Scheduler.storageSelectionMode=1 +ObsSW.Observation.Scheduler.taskDuration=10800 +ObsSW.Observation.Scheduler.taskID=128 +ObsSW.Observation.Scheduler.taskName=Target Pipeline M51 +ObsSW.Observation.Scheduler.taskType=0 +ObsSW.Observation.Scheduler.windowMaximumTime= +ObsSW.Observation.Scheduler.windowMinimumTime= +ObsSW.Observation.VirtualInstrument.imageNodeList=[] +ObsSW.Observation.VirtualInstrument.minimalNrStations=1 +ObsSW.Observation.VirtualInstrument.partitionList=["R00"] +ObsSW.Observation.VirtualInstrument.stationList=[] +ObsSW.Observation.VirtualInstrument.stationSet= +ObsSW.Observation.VirtualInstrument.storageCapacity=760 +ObsSW.Observation.VirtualInstrument.storageNodeList=[] +ObsSW.Observation.antennaArray=LBA +ObsSW.Observation.antennaSet=LBA_INNER +ObsSW.Observation.bandFilter=LBA_30_90 +ObsSW.Observation.channelWidth=762.939453125 +ObsSW.Observation.channelsPerSubband=64 +ObsSW.Observation.claimPeriod=1 +ObsSW.Observation.clockMode=<<Clock200 +ObsSW.Observation.existingAntennaFields=["LBA","HBA","HBA0","HBA1"] +ObsSW.Observation.existingStations=["CS001","CS002","CS003","CS004","CS005","CS006","CS007","CS011","CS013","CS017","CS021","CS024","CS026","CS028","CS030","CS031","CS101","CS103","CS201","CS301","CS302","CS401","CS501","RS106","RS205","RS208","RS306","RS307","RS406","RS503","DE601","DE602","DE603","DE604","DE605","FR606","UK608"] +ObsSW.Observation.longBaselines=false +ObsSW.Observation.nrAnaBeams=0 +ObsSW.Observation.nrBeamformers=0 +ObsSW.Observation.nrBeams=0 +ObsSW.Observation.nrPolarisations=2 +ObsSW.Observation.nrSlotsInFrame=61 +ObsSW.Observation.nrTBBSettings=0 +ObsSW.Observation.preparePeriod=1 +ObsSW.Observation.processSubtype=Calibration Pipeline +ObsSW.Observation.processType=Pipeline +ObsSW.Observation.receiverList=[] +ObsSW.Observation.referencePhaseCenter=[3826577.110, 461022.900, 5064892.758] +ObsSW.Observation.sampleClock=200 +ObsSW.Observation.samplesPerSecond=196608 +ObsSW.Observation.startTime=2012-08-31 16:40:00 +ObsSW.Observation.stopTime=2012-08-31 19:40:00 +ObsSW.Observation.strategy=MSSS target pre-processing +ObsSW.Observation.subbandWidth=195.3125 +ObsSW.Observation.topologyID=mom_msss_131277.1.P2 +_DPname=LOFAR_ObsSW_TempObs0021 +prefix=LOFAR. + "]]> + </config> + </msss_target_pipeline> +</pipeline_block>