22 from __future__
import annotations
27 "GroupExposuresConfig",
29 "VisitDefinitionData",
32 from abc
import ABCMeta, abstractmethod
33 from collections
import defaultdict
36 from typing
import Any, Dict, Iterable, List, Optional, Tuple
37 from multiprocessing
import Pool
39 from lsst.daf.butler
import (
50 from lsst.pex.config import Config, Field, makeRegistry, registerConfigurable
53 from lsst.sphgeom import ConvexPolygon, Region, UnitVector3d
54 from ._instrument
import loadCamera, Instrument
57 @dataclasses.dataclass
59 """Struct representing a group of exposures that will be used to define a
64 """Name of the instrument this visit will be associated with.
68 """Integer ID of the visit.
70 This must be unique across all visit systems for the instrument.
74 """String name for the visit.
76 This must be unique across all visit systems for the instrument.
79 exposures: List[DimensionRecord] = dataclasses.field(default_factory=list)
80 """Dimension records for the exposures that are part of this visit.
84 @dataclasses.dataclass
86 """Struct containing the dimension records associated with a visit.
89 visit: DimensionRecord
90 """Record for the 'visit' dimension itself.
93 visit_definition: List[DimensionRecord]
94 """Records for 'visit_definition', which relates 'visit' to 'exposure'.
97 visit_detector_region: List[DimensionRecord]
98 """Records for 'visit_detector_region', which associates the combination
99 of a 'visit' and a 'detector' with a region on the sky.
107 class GroupExposuresTask(Task, metaclass=ABCMeta):
108 """Abstract base class for the subtask of `DefineVisitsTask` that is
109 responsible for grouping exposures into visits.
111 Subclasses should be registered with `GroupExposuresTask.registry` to
112 enable use by `DefineVisitsTask`, and should generally correspond to a
113 particular 'visit_system' dimension value. They are also responsible for
114 defining visit IDs and names that are unique across all visit systems in
115 use by an instrument.
119 config : `GroupExposuresConfig`
120 Configuration information.
122 Additional keyword arguments forwarded to the `Task` constructor.
124 def __init__(self, config: GroupExposuresConfig, **kwargs: Any):
125 Task.__init__(self, config=config, **kwargs)
127 ConfigClass = GroupExposuresConfig
129 _DefaultName =
"groupExposures"
132 doc=
"Registry of algorithms for grouping exposures into visits.",
133 configBaseType=GroupExposuresConfig,
137 def group(self, exposures: List[DimensionRecord]) -> Iterable[VisitDefinitionData]:
138 """Group the given exposures into visits.
142 exposures : `list` [ `DimensionRecord` ]
143 DimensionRecords (for the 'exposure' dimension) describing the
148 visits : `Iterable` [ `VisitDefinitionData` ]
149 Structs identifying the visits and the exposures associated with
150 them. This may be an iterator or a container.
152 raise NotImplementedError()
156 """Return identifiers for the 'visit_system' dimension this
157 algorithm implements.
162 Integer ID for the visit system (given an instrument).
164 Unique string identifier for the visit system (given an
167 raise NotImplementedError()
174 doc=(
"Pad raw image bounding boxes with specified number of pixels "
175 "when calculating their (conservatively large) region on the "
181 """Abstract base class for the subtask of `DefineVisitsTask` that is
182 responsible for extracting spatial regions for visits and visit+detector
185 Subclasses should be registered with `ComputeVisitRegionsTask.registry` to
186 enable use by `DefineVisitsTask`.
190 config : `ComputeVisitRegionsConfig`
191 Configuration information.
192 butler : `lsst.daf.butler.Butler`
195 Additional keyword arguments forwarded to the `Task` constructor.
197 def __init__(self, config: ComputeVisitRegionsConfig, *, butler: Butler, **kwargs: Any):
198 Task.__init__(self, config=config, **kwargs)
202 ConfigClass = ComputeVisitRegionsConfig
204 _DefaultName =
"computeVisitRegions"
207 doc=(
"Registry of algorithms for computing on-sky regions for visits "
208 "and visit+detector combinations."),
209 configBaseType=ComputeVisitRegionsConfig,
213 """Retrieve an `~lsst.obs.base.Instrument` associated with this
218 instrumentName : `str`
219 The name of the instrument.
223 instrument : `~lsst.obs.base.Instrument`
224 The associated instrument object.
228 The result is cached.
230 instrument = self.
instrumentMapinstrumentMap.get(instrumentName)
231 if instrument
is None:
232 instrument = Instrument.fromName(instrumentName, self.
butlerbutler.registry)
237 def compute(self, visit: VisitDefinitionData, *, collections: Any =
None
238 ) -> Tuple[Region, Dict[int, Region]]:
239 """Compute regions for the given visit and all detectors in that visit.
243 visit : `VisitDefinitionData`
244 Struct describing the visit and the exposures associated with it.
245 collections : Any, optional
246 Collections to be searched for raws and camera geometry, overriding
247 ``self.butler.collections``.
248 Can be any of the types supported by the ``collections`` argument
249 to butler construction.
253 visitRegion : `lsst.sphgeom.Region`
254 Region for the full visit.
255 visitDetectorRegions : `dict` [ `int`, `lsst.sphgeom.Region` ]
256 Dictionary mapping detector ID to the region for that detector.
257 Should include all detectors in the visit.
259 raise NotImplementedError()
263 groupExposures = GroupExposuresTask.registry.makeField(
264 doc=
"Algorithm for grouping exposures into visits.",
265 default=
"one-to-one",
267 computeVisitRegions = ComputeVisitRegionsTask.registry.makeField(
268 doc=
"Algorithm from computing visit and visit+detector regions.",
269 default=
"single-raw-wcs",
272 doc=(
"If True, silently ignore input exposures that do not have "
273 "observation_type=SCIENCE. If False, raise an exception if one "
282 """Driver Task for defining visits (and their spatial regions) in Gen3
287 config : `DefineVisitsConfig`
288 Configuration for the task.
289 butler : `~lsst.daf.butler.Butler`
290 Writeable butler instance. Will be used to read `raw.wcs` and `camera`
291 datasets and insert/sync dimension data.
293 Additional keyword arguments are forwarded to the `lsst.pipe.base.Task`
298 Each instance of `DefineVisitsTask` reads from / writes to the same Butler.
299 Each invocation of `DefineVisitsTask.run` processes an independent group of
300 exposures into one or more new vists, all belonging to the same visit
301 system and instrument.
303 The actual work of grouping exposures and computing regions is delegated
304 to pluggable subtasks (`GroupExposuresTask` and `ComputeVisitRegionsTask`),
305 respectively. The defaults are to create one visit for every exposure,
306 and to use exactly one (arbitrary) detector-level raw dataset's WCS along
307 with camera geometry to compute regions for all detectors. Other
308 implementations can be created and configured for instruments for which
309 these choices are unsuitable (e.g. because visits and exposures are not
310 one-to-one, or because ``raw.wcs`` datasets for different detectors may not
311 be consistent with camera geomery).
313 It is not necessary in general to ingest all raws for an exposure before
314 defining a visit that includes the exposure; this depends entirely on the
315 `ComputeVisitRegionTask` subclass used. For the default configuration,
316 a single raw for each exposure is sufficient.
318 Defining the same visit the same way multiple times (e.g. via multiple
319 invocations of this task on the same exposures, with the same
320 configuration) is safe, but it may be inefficient, as most of the work must
321 be done before new visits can be compared to existing visits.
323 def __init__(self, config: Optional[DefineVisitsConfig] =
None, *, butler: Butler, **kwargs: Any):
331 def _reduce_kwargs(self):
333 return dict(**super()._reduce_kwargs(), butler=self.
butlerbutler)
335 ConfigClass = DefineVisitsConfig
337 _DefaultName =
"defineVisits"
339 def _buildVisitRecords(self, definition: VisitDefinitionData, *,
340 collections: Any =
None) -> _VisitRecords:
341 """Build the DimensionRecords associated with a visit.
345 definition : `VisitDefinition`
346 Struct with identifiers for the visit and records for its
347 constituent exposures.
348 collections : Any, optional
349 Collections to be searched for raws and camera geometry, overriding
350 ``self.butler.collections``.
351 Can be any of the types supported by the ``collections`` argument
352 to butler construction.
356 records : `_VisitRecords`
357 Struct containing DimensionRecords for the visit, including
358 associated dimension elements.
361 visitRegion, visitDetectorRegions = self.computeVisitRegions.compute(definition,
362 collections=collections)
365 begin=_reduceOrNone(min, (e.timespan.begin
for e
in definition.exposures)),
366 end=_reduceOrNone(max, (e.timespan.end
for e
in definition.exposures)),
368 exposure_time = _reduceOrNone(sum, (e.exposure_time
for e
in definition.exposures))
369 physical_filter = _reduceOrNone(
lambda a, b: a
if a == b
else None,
370 (e.physical_filter
for e
in definition.exposures))
371 target_name = _reduceOrNone(
lambda a, b: a
if a == b
else None,
372 (e.target_name
for e
in definition.exposures))
373 science_program = _reduceOrNone(
lambda a, b: a
if a == b
else None,
374 (e.science_program
for e
in definition.exposures))
378 observing_day = _reduceOrNone(min, (e.day_obs
for e
in definition.exposures))
379 observation_reason = _reduceOrNone(
lambda a, b: a
if a == b
else None,
380 (e.observation_reason
for e
in definition.exposures))
381 if observation_reason
is None:
383 observation_reason =
"various"
386 zenith_angle = _reduceOrNone(sum, (e.zenith_angle
for e
in definition.exposures))
387 if zenith_angle
is not None:
388 zenith_angle /= len(definition.exposures)
392 visit=self.
universeuniverse[
"visit"].RecordClass(
393 instrument=definition.instrument,
395 name=definition.name,
396 physical_filter=physical_filter,
397 target_name=target_name,
398 science_program=science_program,
399 observation_reason=observation_reason,
400 day_obs=observing_day,
401 zenith_angle=zenith_angle,
402 visit_system=self.groupExposures.getVisitSystem()[0],
403 exposure_time=exposure_time,
411 self.
universeuniverse[
"visit_definition"].RecordClass(
412 instrument=definition.instrument,
414 exposure=exposure.id,
415 visit_system=self.groupExposures.getVisitSystem()[0],
417 for exposure
in definition.exposures
419 visit_detector_region=[
420 self.
universeuniverse[
"visit_detector_region"].RecordClass(
421 instrument=definition.instrument,
424 region=detectorRegion,
426 for detectorId, detectorRegion
in visitDetectorRegions.items()
430 def _expandExposureId(self, dataId: DataId) -> DataCoordinate:
431 """Return the expanded version of an exposure ID.
433 A private method to allow ID expansion in a pool without resorting
438 dataId : `dict` or `DataCoordinate`
439 Exposure-level data ID.
443 expanded : `DataCoordinate`
444 A data ID that includes full metadata for all exposure dimensions.
446 dimensions = DimensionGraph(self.
universeuniverse, names=[
"exposure"])
447 return self.
butlerbutler.registry.expandDataId(dataId, graph=dimensions)
449 def _buildVisitRecordsSingle(self, args) -> _VisitRecords:
450 """Build the DimensionRecords associated with a visit and collection.
452 A wrapper for `_buildVisitRecords` to allow it to be run as part of
453 a pool without resorting to local callables.
457 args : `tuple` [`VisitDefinition`, any]
458 A tuple consisting of the ``definition`` and ``collections``
459 arguments to `_buildVisitRecords`, in that order.
463 records : `_VisitRecords`
464 Struct containing DimensionRecords for the visit, including
465 associated dimension elements.
469 def run(self, dataIds: Iterable[DataId], *,
470 pool: Optional[Pool] =
None,
472 collections: Optional[str] =
None):
473 """Add visit definitions to the registry for the given exposures.
477 dataIds : `Iterable` [ `dict` or `DataCoordinate` ]
478 Exposure-level data IDs. These must all correspond to the same
479 instrument, and are expected to be on-sky science exposures.
480 pool : `multiprocessing.Pool`, optional
481 If not `None`, a process pool with which to parallelize some
483 processes : `int`, optional
484 The number of processes to use. Ignored if ``pool`` is not `None`.
485 collections : Any, optional
486 Collections to be searched for raws and camera geometry, overriding
487 ``self.butler.collections``.
488 Can be any of the types supported by the ``collections`` argument
489 to butler construction.
493 lsst.daf.butler.registry.ConflictingDefinitionError
494 Raised if a visit ID conflict is detected and the existing visit
495 differs from the new one.
498 if pool
is None and processes > 1:
499 pool = Pool(processes)
500 mapFunc = map
if pool
is None else pool.imap_unordered
502 self.
loglog.
info(
"Preprocessing data IDs.")
505 raise RuntimeError(
"No exposures given.")
510 for dataId
in dataIds:
511 record = dataId.records[
"exposure"]
512 if record.observation_type !=
"science":
513 if self.
configconfig.ignoreNonScienceExposures:
516 raise RuntimeError(f
"Input exposure {dataId} has observation_type "
517 f
"{record.observation_type}, not 'science'.")
518 instruments.add(dataId[
"instrument"])
519 exposures.append(record)
521 self.
loglog.
info(
"No science exposures found after filtering.")
523 if len(instruments) > 1:
525 f
"All data IDs passed to DefineVisitsTask.run must be "
526 f
"from the same instrument; got {instruments}."
528 instrument, = instruments
531 visitSystemId, visitSystemName = self.groupExposures.getVisitSystem()
532 self.
loglog.
info(
"Registering visit_system %d: %s.", visitSystemId, visitSystemName)
533 self.
butlerbutler.registry.syncDimensionData(
535 {
"instrument": instrument,
"id": visitSystemId,
"name": visitSystemName}
538 self.
loglog.
info(
"Grouping %d exposure(s) into visits.", len(exposures))
539 definitions =
list(self.groupExposures.
group(exposures))
543 self.
loglog.
info(
"Computing regions and other metadata for %d visit(s).", len(definitions))
545 zip(definitions, itertools.repeat(collections)))
548 for visitRecords
in allRecords:
549 with self.
butlerbutler.registry.transaction():
550 if self.
butlerbutler.registry.syncDimensionData(
"visit", visitRecords.visit):
551 self.
butlerbutler.registry.insertDimensionData(
"visit_definition",
552 *visitRecords.visit_definition)
553 self.
butlerbutler.registry.insertDimensionData(
"visit_detector_region",
554 *visitRecords.visit_detector_region)
557 def _reduceOrNone(func, iterable):
558 """Apply a binary function to pairs of elements in an iterable until a
559 single value is returned, but return `None` if any element is `None` or
560 there are no elements.
575 doc=(
"Integer ID of the visit_system implemented by this grouping "
581 doc=(
"String name of the visit_system implemented by this grouping "
584 default=
"one-to-one",
588 @registerConfigurable("one-to-one", GroupExposuresTask.registry)
590 """An exposure grouping algorithm that simply defines one visit for each
591 exposure, reusing the exposures identifiers for the visit.
594 ConfigClass = _GroupExposuresOneToOneConfig
596 def group(self, exposures: List[DimensionRecord]) -> Iterable[VisitDefinitionData]:
598 for exposure
in exposures:
600 instrument=exposure.instrument,
602 name=exposure.obs_id,
603 exposures=[exposure],
608 return (self.
configconfig.visitSystemId, self.
configconfig.visitSystemName)
613 doc=(
"Integer ID of the visit_system implemented by this grouping "
619 doc=(
"String name of the visit_system implemented by this grouping "
622 default=
"by-group-metadata",
626 @registerConfigurable("by-group-metadata", GroupExposuresTask.registry)
628 """An exposure grouping algorithm that uses exposure.group_name and
631 This algorithm _assumes_ exposure.group_id (generally populated from
632 `astro_metadata_translator.ObservationInfo.visit_id`) is not just unique,
633 but disjoint from all `ObservationInfo.exposure_id` values - if it isn't,
634 it will be impossible to ever use both this grouping algorithm and the
635 one-to-one algorithm for a particular camera in the same data repository.
638 ConfigClass = _GroupExposuresByGroupMetadataConfig
640 def group(self, exposures: List[DimensionRecord]) -> Iterable[VisitDefinitionData]:
642 groups = defaultdict(list)
643 for exposure
in exposures:
644 groups[exposure.group_name].
append(exposure)
645 for visitName, exposuresInGroup
in groups.items():
646 instrument = exposuresInGroup[0].instrument
647 visitId = exposuresInGroup[0].group_id
648 assert all(e.group_id == visitId
for e
in exposuresInGroup), \
649 "Grouping by exposure.group_name does not yield consistent group IDs"
651 exposures=exposuresInGroup)
655 return (self.
configconfig.visitSystemId, self.
configconfig.visitSystemName)
660 doc=(
"If True, merge per-detector regions over all exposures in a "
661 "visit (via convex hull) instead of using the first exposure and "
662 "assuming its regions are valid for all others."),
667 doc=(
"Load the WCS for the detector with this ID. If None, use an "
668 "arbitrary detector (the first found in a query of the data "
669 "repository for each exposure (or all exposures, if "
670 "mergeExposures is True)."),
676 doc=(
"If True, raise LookupError if version camera geometry cannot be "
677 "loaded for an exposure. If False, use the nominal camera from "
678 "the Instrument class instead."),
685 @registerConfigurable("single-raw-wcs", ComputeVisitRegionsTask.registry)
687 """A visit region calculator that uses a single raw WCS and a camera to
688 project the bounding boxes of all detectors onto the sky, relating
689 different detectors by their positions in focal plane coordinates.
693 Most instruments should have their raw WCSs determined from a combination
694 of boresight angle, rotator angle, and camera geometry, and hence this
695 algorithm should produce stable results regardless of which detector the
696 raw corresponds to. If this is not the case (e.g. because a per-file FITS
697 WCS is used instead), either the ID of the detector should be fixed (see
698 the ``detectorId`` config parameter) or a different algorithm used.
701 ConfigClass = _ComputeVisitRegionsFromSingleRawWcsConfig
704 ) -> Dict[int, List[UnitVector3d]]:
705 """Compute the lists of unit vectors on the sphere that correspond to
706 the sky positions of detector corners.
710 exposure : `DimensionRecord`
711 Dimension record for the exposure.
712 collections : Any, optional
713 Collections to be searched for raws and camera geometry, overriding
714 ``self.butler.collections``.
715 Can be any of the types supported by the ``collections`` argument
716 to butler construction.
721 Dictionary mapping detector ID to a list of unit vectors on the
722 sphere representing that detector's corners projected onto the sky.
724 if collections
is None:
725 collections = self.
butlerbutler.collections
726 camera, versioned =
loadCamera(self.
butlerbutler, exposure.dataId, collections=collections)
727 if not versioned
and self.
configconfig.requireVersionedCamera:
728 raise LookupError(f
"No versioned camera found for exposure {exposure.dataId}.")
736 except AttributeError:
740 if self.
configconfig.detectorId
is None:
741 detectorId =
next(camera.getIdIter())
743 detectorId = self.
configconfig.detectorId
744 wcsDetector = camera[detectorId]
748 instrument = self.
getInstrumentgetInstrument(exposure.instrument)
749 rawFormatter = instrument.getRawFormatter({
"detector": detectorId})
750 wcs = rawFormatter.makeRawSkyWcsFromBoresight(radec, orientation, wcsDetector)
753 if self.
configconfig.detectorId
is None:
754 wcsRefsIter = self.
butlerbutler.registry.queryDatasets(
"raw.wcs", dataId=exposure.dataId,
755 collections=collections)
757 raise LookupError(f
"No raw.wcs datasets found for data ID {exposure.dataId} "
758 f
"in collections {collections}.")
760 wcsDetector = camera[wcsRef.dataId[
"detector"]]
761 wcs = self.
butlerbutler.getDirect(wcsRef)
763 wcsDetector = camera[self.
configconfig.detectorId]
764 wcs = self.
butlerbutler.get(
"raw.wcs", dataId=exposure.dataId, detector=self.
configconfig.detectorId,
765 collections=collections)
766 fpToSky = wcsDetector.getTransform(FOCAL_PLANE, PIXELS).
then(wcs.getTransform())
768 for detector
in camera:
769 pixelsToSky = detector.getTransform(PIXELS, FOCAL_PLANE).
then(fpToSky)
770 pixCorners =
Box2D(detector.getBBox().dilatedBy(self.
configconfig.padding)).getCorners()
771 bounds[detector.getId()] = [
772 skyCorner.getVector()
for skyCorner
in pixelsToSky.applyForward(pixCorners)
776 def compute(self, visit: VisitDefinitionData, *, collections: Any =
None
777 ) -> Tuple[Region, Dict[int, Region]]:
779 if self.
configconfig.mergeExposures:
780 detectorBounds = defaultdict(list)
781 for exposure
in visit.exposures:
782 exposureDetectorBounds = self.
computeExposureBoundscomputeExposureBounds(exposure, collections=collections)
783 for detectorId, bounds
in exposureDetectorBounds.items():
784 detectorBounds[detectorId].extend(bounds)
786 detectorBounds = self.
computeExposureBoundscomputeExposureBounds(visit.exposures[0], collections=collections)
789 for detectorId, bounds
in detectorBounds.items():
790 detectorRegions[detectorId] = ConvexPolygon.convexHull(bounds)
791 visitBounds.extend(bounds)
792 return ConvexPolygon.convexHull(visitBounds), detectorRegions
A class representing an angle.
A floating-point coordinate rectangle geometry.
Point in an unspecified spherical coordinate system.
Dict[int, List[UnitVector3d]] computeExposureBounds(self, DimensionRecord exposure, *Any collections=None)
Tuple[Region, Dict[int, Region]] compute(self, VisitDefinitionData visit, *Any collections=None)
Iterable[VisitDefinitionData] group(self, List[DimensionRecord] exposures)
Tuple[int, str] getVisitSystem(self)
Instrument getInstrument(self, instrumentName)
Tuple[Region, Dict[int, Region]] compute(self, VisitDefinitionData visit, *Any collections=None)
def __init__(self, ComputeVisitRegionsConfig config, *Butler butler, **Any kwargs)
_VisitRecords _buildVisitRecordsSingle(self, args)
def __init__(self, Optional[DefineVisitsConfig] config=None, *Butler butler, **Any kwargs)
_VisitRecords _buildVisitRecords(self, VisitDefinitionData definition, *Any collections=None)
DataCoordinate _expandExposureId(self, DataId dataId)
def run(self, Iterable[DataId] dataIds, *Optional[Pool] pool=None, int processes=1, Optional[str] collections=None)
Iterable[VisitDefinitionData] group(self, List[DimensionRecord] exposures)
def __init__(self, GroupExposuresConfig config, **Any kwargs)
Tuple[int, str] getVisitSystem(self)
def makeSubtask(self, name, **keyArgs)
std::shared_ptr< FrameSet > append(FrameSet const &first, FrameSet const &second)
Construct a FrameSet that performs two transformations in series.
bool all(CoordinateExpr< N > const &expr) noexcept
Return true if all elements are true.
Tuple[Camera, bool] loadCamera(Butler butler, DataId dataId, *Any collections=None)
def makeRegistry(doc, configBaseType=Config)
daf::base::PropertyList * list
daf::base::PropertySet * set
table::Key< table::Array< int > > group